Commit Graph

120486 Commits

Author SHA1 Message Date
Alexey Milovidov
7ac5c421ad
Merge pull request #49343 from ClickHouse/sleep-each-row-max-time
Merging #34909
2023-07-26 00:03:27 +03:00
Sema Checherinda
83d869860e
Merge pull request #51946 from arenadata/ADQM-940
Expose Peak memory usage in query statistics.
2023-07-25 22:17:58 +03:00
Nikita Mikhaylov
1dc9ca2c24
Merge pull request #52549 from ClickHouse/whitespace-before-comma
Check for punctuation
2023-07-25 20:30:36 +02:00
Rich Raposa
2ecfde96b6
Merge pull request #52119 from ClickHouse/DanRoscigno-patch-4
Update s3.md regarding partitioned data
2023-07-25 11:14:44 -06:00
robot-ch-test-poll1
49a60b27a0
Merge pull request #51076 from priera/50727_currentDatabase_alias
#50727 new alias for current_database and added current_schemas
2023-07-25 18:22:48 +02:00
robot-ch-test-poll3
5fa2f64f84
Merge pull request #52180 from jinjunzh/iaadeflate_upgrade_qpl_v1.2.0
Upgrade QPL to v1.2.0 and accel-config to v4.0
2023-07-25 18:10:59 +02:00
Igor Nikonov
9b4357723f
Merge pull request #47135 from ClickHouse/remove-perf-test-duplicate-order-by-and-distinct
Remove duplicate_order_by_and_distinct optimization
2023-07-25 17:26:22 +02:00
Yarik Briukhovetskyi
4c2b37bf6d
Merge pull request #52576 from ClickHouse/revert-52004-rewrite_uniq_to_count
Revert "Rewrite uniq to count"
2023-07-25 17:01:56 +02:00
Yarik Briukhovetskyi
11016d4c5f
Revert "Rewrite uniq to count" 2023-07-25 16:46:50 +02:00
Azat Khuzhin
85082ad8f8
Fix data-race DatabaseReplicated::startupTables()/canExecuteReplicatedMetadataAlter() (#52490)
CI founds [1]:

    Exception: Sanitizer assert found for instance ==================
    WARNING: ThreadSanitizer: data race (pid=348)
      Write of size 8 at 0x7b58000044a0 by main thread:
        2 DB::DatabaseReplicated::startupTables(ThreadPoolImpl<ThreadFromGlobalPoolImpl<false>>&, DB::LoadingStrictnessLevel) build_docker/./src/Databases/DatabaseReplicated.cpp:526:16 (clickhouse+0x1ec45092)
        3 DB::TablesLoader::startupTables() build_docker/./src/Databases/TablesLoader.cpp:87:26 (clickhouse+0x1f9258ab) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        4 DB::loadMetadata(std::__1::shared_ptr<DB::Context>, std::__1::basic_string<char, std::__1::char_traits<char>, std::__1::allocator<char>> const&) build_docker/./src/Interpreters/loadMetadata.cpp:234:12 (clickhouse+0x1fff3834) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        5 DB::Server::main() build_docker/./programs/server/Server.cpp:1615:9 (clickhouse+0x163e7f78) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        6 Poco::Util::Application::run() build_docker/./base/poco/Util/src/Application.cpp:315:8 (clickhouse+0x257608fe) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        7 DB::Server::run() build_docker/./programs/server/Server.cpp:391:25 (clickhouse+0x163d7d7c) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        8 Poco::Util::ServerApplication::run(int, char**) build_docker/./base/poco/Util/src/ServerApplication.cpp:131:9 (clickhouse+0x25780114) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        9 mainEntryClickHouseServer(int, char**) build_docker/./programs/server/Server.cpp:196:20 (clickhouse+0x163d4c23) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        10 main build_docker/./programs/main.cpp:487:12 (clickhouse+0xdf8c877) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)

      Previous read of size 8 at 0x7b58000044a0 by thread T27 (mutexes: write M0, write M1):
        1 DB::DatabaseReplicated::canExecuteReplicatedMetadataAlter() const build_docker/./src/Databases/DatabaseReplicated.cpp:1303:12 (clickhouse+0x1ec5c5bd)
        2 DB::ReplicatedMergeTreeQueue::shouldExecuteLogEntry() const build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1471:24 (clickhouse+0x2115fb56) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        3 DB::ReplicatedMergeTreeQueue::selectEntryToProcess(DB::MergeTreeDataMergerMutator&, DB::MergeTreeData&) build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:1676:13 (clickhouse+0x21163c58) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        4 DB::StorageReplicatedMergeTree::selectQueueEntry() build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3240:26 (clickhouse+0x20823db2) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)
        5 DB::StorageReplicatedMergeTree::scheduleDataProcessingJob(DB::BackgroundJobsAssignee&) build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3304:65 (clickhouse+0x208240fc) (BuildId: 7d4ce55d33d4c3e3df9fd39b304e67e53eb61a63)

  [1]: https://s3.amazonaws.com/clickhouse-test-reports/52395/0b258dda4ee618a4d002e2b5246d68bbd2c77c7e/integration_tests__tsan__[5_6].html

Add ddl_worker_initialized flag to avoid this race.

Note, that it should be enough to check this flag only in
canExecuteReplicatedMetadataAlter() since only it can be run in parallel
with ctor before it had been finished.

v0: initialize ddl before startupTables()
v2: ddl_worker_initialized

Signed-off-by: Azat Khuzhin <a.khuzhin@semrush.com>
Co-authored-by: Alexander Tokmakov <tavplubix@clickhouse.com>
2023-07-25 17:35:01 +03:00
Azat Khuzhin
79d0343bec
tests: fix 01821_join_table_race_long flakiness (#52559)
By grouping multiple queries into one clickhouse-client invocation,
since each execve of the binary can take ~1 second in debug builds.

But this slightly changes the logic, so be aware.

Signed-off-by: Azat Khuzhin <a.khuzhin@semrush.com>
Co-authored-by: Alexander Tokmakov <tavplubix@clickhouse.com>
2023-07-25 17:34:40 +03:00
Alexander Tokmakov
a6cf769222
Merge pull request #52558 from azat/tests/00719_parallel_ddl_table
tests: fix 00719_parallel_ddl_table flakiness in debug builds
2023-07-25 17:25:24 +03:00
Alexander Tokmakov
7d871dadd7
Merge pull request #52556 from azat/tests/fix-01035_avg_weighted_long
tests: fix 01035_avg_weighted_long flakiness
2023-07-25 17:21:29 +03:00
Anton Popov
073dea6eef
Merge pull request #49160 from CurtizJ/flush-async-insert-queue
Allow to flush asynchronous insert queue
2023-07-25 15:58:20 +02:00
Anton Popov
4531b105ac
Merge branch 'master' into flush-async-insert-queue 2023-07-25 15:48:01 +02:00
Yakov Olkhovskiy
e133db7937
Merge pull request #51472 from bigo-sg/substring_index
Add function substring_index, as in spark or mysql
2023-07-25 08:43:13 -04:00
Kruglov Pavel
da02f3189d
Merge pull request #50452 from DanRoscigno/update-acid-docs
update for min_chunk_bytes_for_parallel_parsing
2023-07-25 14:15:55 +02:00
Robert Schulze
1a965b20a3
Merge pull request #52309 from rschu1ze/qc-event-descr
Minor: Update description of events "QueryCacheHits/Misses"
2023-07-25 13:54:06 +02:00
Kruglov Pavel
f8c90d5964
Make better 2023-07-25 13:36:57 +02:00
robot-ch-test-poll
8964de808e
Merge pull request #52147 from ucasfl/any_value
Add any_value as a compatibility alias for any
2023-07-25 13:05:49 +02:00
Nikolai Kochetov
c960b3b533
Merge pull request #52533 from ClickHouse/Avogar-patch-2
Cancel execution in PipelineExecutor in case of exception in graph->updateNode
2023-07-25 12:39:22 +02:00
Yarik Briukhovetskyi
5f767b0dfa
Merge pull request #52004 from JackyWoo/rewrite_uniq_to_count
Rewrite uniq to count
2023-07-25 11:41:00 +02:00
Azat Khuzhin
2efbeab5af tests: fix 00719_parallel_ddl_table flakiness in debug builds
In debug bulds each client invocation takes ~1 second, and on CI it can
take more if the node is under some load, so let's decrease number of
iterations.

Anyway CI runs each test ~1K times daily, and if there will be something
even this number of iterations should be enough.

Signed-off-by: Azat Khuzhin <a.khuzhin@semrush.com>
2023-07-25 10:43:40 +02:00
Azat Khuzhin
b02e290d55 tests: fix 01035_avg_weighted_long flakiness
Use one clickhouse-client invocation instead of 300, in debug builds it
is significant - each spawn is ~1 second

Signed-off-by: Azat Khuzhin <a.khuzhin@semrush.com>
2023-07-25 10:38:16 +02:00
robot-ch-test-poll
bd5d93e439
Merge pull request #52536 from ClickHouse/Fix_disallow_concurrent_backup_restore_test
Fix disallow_concurrency test for backup and restore
2023-07-25 09:10:27 +02:00
robot-ch-test-poll1
4e5ed9b475
Merge pull request #52534 from ClickHouse/analyzer_fix_01951_distributed_push_down_limit
Make 01951_distributed_push_down_limit analyzer agnostic
2023-07-25 07:45:21 +02:00
robot-ch-test-poll4
fe6cd14a48
Merge pull request #52527 from Algunenano/mergetree_cleanup
Remove unused code
2023-07-25 07:41:42 +02:00
Alexey Milovidov
21382afa2b Check for punctuation 2023-07-25 06:10:04 +02:00
Alexey Milovidov
90a6a018b0
Merge branch 'master' into 50727_currentDatabase_alias 2023-07-25 06:51:28 +03:00
Alexey Milovidov
ecdafeaf83
Merge pull request #52175 from bigo-sg/comment_improve_ch_to_arrow
Add comments for https://github.com/ClickHouse/ClickHouse/pull/52112
2023-07-25 06:47:48 +03:00
Alexey Milovidov
0d0ec4cdf3
Merge branch 'master' into iaadeflate_upgrade_qpl_v1.2.0 2023-07-25 06:47:15 +03:00
flynn
8388ee067a
Merge branch 'master' into any_value 2023-07-25 11:21:19 +08:00
robot-ch-test-poll1
05d4932842
Merge pull request #52137 from ucasfl/avro-fix
Avro input format support Union with single type
2023-07-25 04:48:39 +02:00
Alexey Milovidov
b53baa43ac
Merge pull request #51293 from ClickHouse/sql-fetch-allow-without-offset
Allow SQL standard `FETCH` without `OFFSET`
2023-07-25 05:44:39 +03:00
Alexey Milovidov
fbcc06685b
Merge pull request #51367 from ClickHouse/remove-wrong-code
Attempt to remove wrong code (catch/throw in Functions)
2023-07-25 05:44:22 +03:00
Alexey Milovidov
168b84a592
Merge pull request #52337 from Avogar/no-decode-url
Allow to disable decoding/encoding path in uri in URL engine
2023-07-25 05:43:06 +03:00
Alexey Milovidov
787757fd25
Merge pull request #52497 from ClickHouse/Fix_test_insert_same_partition_and_merge_increase_timeout
Fix test_insert_same_partition_and_merge by increasing wait time
2023-07-25 05:39:20 +03:00
Alexey Milovidov
813efa31ad
Merge pull request #52513 from ClickHouse/fix-transform-2
Fix abort in function `transform`
2023-07-25 05:37:17 +03:00
flynn
93c628dea1
Merge branch 'master' into any_value 2023-07-25 10:37:08 +08:00
Alexey Milovidov
7cab99d2a3
Merge pull request #52537 from ClickHouse/tavplubix-patch-8
Update 02136_scalar_subquery_metrics.sql
2023-07-25 05:33:29 +03:00
Dmitry Kardymon
d4d381de7e Merge remote-tracking branch 'origin/master' into ADQM-940 2023-07-24 20:04:10 +00:00
Alexey Milovidov
3c034d563b
Merge pull request #52068 from azat/replicated-cluster-prep1
Preparations for Trivial Support For Resharding (part1)
2023-07-24 22:57:44 +03:00
Kseniia Sumarokova
e05e0ec557
Merge pull request #52318 from valbok/utf8-names
MaterializedMySQL: Support unquoted utf-8 strings in DDL
2023-07-24 21:49:33 +02:00
Alexey Milovidov
34ff0e0ea9
Merge pull request #52184 from azat/tests/randomize-timezone
Randomize timezone in tests across non-deterministic around 1970 and default
2023-07-24 22:47:52 +03:00
Alexander Tokmakov
8b09fb4cba
Merge pull request #52355 from valbok/comment-db
MaterializedMySQL: Add support of double quoted comments
2023-07-24 20:55:50 +03:00
Alexander Tokmakov
c3e2077449
Merge branch 'master' into comment-db 2023-07-24 20:53:46 +03:00
Alexander Tokmakov
2f99363db0
Update 02136_scalar_subquery_metrics.sql 2023-07-24 20:51:53 +03:00
Alexey Milovidov
33e4273d38 Merge branch 'sql-fetch-allow-without-offset' of github.com:ClickHouse/ClickHouse into sql-fetch-allow-without-offset 2023-07-24 19:50:56 +02:00
Kruglov Pavel
c35da36ff2
Fix default value 2023-07-24 19:50:53 +02:00
Alexey Milovidov
9660bc0d99 Merge branch 'master' into sql-fetch-allow-without-offset 2023-07-24 19:50:40 +02:00