Add tags to tests.

This commit is contained in:
Vitaly Baranov 2021-09-12 15:35:27 +03:00
parent bbb192ee85
commit 39d73c01b2
1026 changed files with 1909 additions and 0 deletions

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT (dummy AS x) - 1 FROM remote('127.0.0.{2,3}', system, one) SELECT (dummy AS x) - 1 FROM remote('127.0.0.{2,3}', system, one)

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT count() FROM remote('127.0.0.{2,3}', system, one) WHERE arrayExists((x) -> x = 1, [1, 2, 3]) SELECT count() FROM remote('127.0.0.{2,3}', system, one) WHERE arrayExists((x) -> x = 1, [1, 2, 3])

View File

@ -1 +1,3 @@
-- Tags: distributed
SELECT quantilesTiming(0.1, 0.5, 0.9)(dummy) FROM remote('127.0.0.{2,3}', system, one) GROUP BY 1 WITH TOTALS SELECT quantilesTiming(0.1, 0.5, 0.9)(dummy) FROM remote('127.0.0.{2,3}', system, one) GROUP BY 1 WITH TOTALS

View File

@ -1 +1,3 @@
-- Tags: distributed
SELECT NOT dummy FROM remote('127.0.0.{2,3}', system, one) WHERE NOT dummy SELECT NOT dummy FROM remote('127.0.0.{2,3}', system, one) WHERE NOT dummy

View File

@ -1,3 +1,5 @@
-- Tags: distributed
DROP TABLE IF EXISTS big_array; DROP TABLE IF EXISTS big_array;
CREATE TABLE big_array (x Array(UInt8)) ENGINE=TinyLog; CREATE TABLE big_array (x Array(UInt8)) ENGINE=TinyLog;
SET min_insert_block_size_rows = 0, min_insert_block_size_bytes = 0; SET min_insert_block_size_rows = 0, min_insert_block_size_bytes = 0;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: zookeeper
CUR_DIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CUR_DIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT number FROM remote('127.0.0.{2,3}', system, numbers) WHERE number GLOBAL IN (SELECT number FROM remote('127.0.0.{2,3}', system, numbers) WHERE number % 2 = 1 LIMIT 10) LIMIT 10; SELECT number FROM remote('127.0.0.{2,3}', system, numbers) WHERE number GLOBAL IN (SELECT number FROM remote('127.0.0.{2,3}', system, numbers) WHERE number % 2 = 1 LIMIT 10) LIMIT 10;

View File

@ -1,3 +1,6 @@
-- Tags: long, replica, no-replicated-database
-- Tag no-replicated-database: Old syntax is not allowed
DROP TABLE IF EXISTS replicated_alter1; DROP TABLE IF EXISTS replicated_alter1;
DROP TABLE IF EXISTS replicated_alter2; DROP TABLE IF EXISTS replicated_alter2;

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT toTypeName(1.0) FROM remote('127.0.0.{2,3}', system, one) SELECT toTypeName(1.0) FROM remote('127.0.0.{2,3}', system, one)

View File

@ -1,2 +1,4 @@
-- Tags: replica
SELECT arrayFilter(x -> materialize(0), materialize([0])) AS p, arrayAll(y -> arrayExists(x -> y != x, p), p) AS test; SELECT arrayFilter(x -> materialize(0), materialize([0])) AS p, arrayAll(y -> arrayExists(x -> y != x, p), p) AS test;
SELECT arrayFilter(x -> materialize(0), materialize([''])) AS p, arrayAll(y -> arrayExists(x -> y != x, p), p) AS test; SELECT arrayFilter(x -> materialize(0), materialize([''])) AS p, arrayAll(y -> arrayExists(x -> y != x, p), p) AS test;

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT -(-1) FROM remote('127.0.0.{2,3}', system, one) SELECT -(-1) FROM remote('127.0.0.{2,3}', system, one)

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel
DROP DATABASE IF EXISTS test_show_tables; DROP DATABASE IF EXISTS test_show_tables;
CREATE DATABASE test_show_tables; CREATE DATABASE test_show_tables;

View File

@ -1,3 +1,7 @@
-- Tags: long, zookeeper, no-replicated-database, no-parallel
-- Tag no-replicated-database: Old syntax is not allowed
-- Tag no-parallel: leftovers
SET optimize_on_insert = 0; SET optimize_on_insert = 0;
DROP TABLE IF EXISTS merge_tree; DROP TABLE IF EXISTS merge_tree;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS report1; DROP TABLE IF EXISTS report1;
DROP TABLE IF EXISTS report2; DROP TABLE IF EXISTS report2;

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel
CREATE DATABASE IF NOT EXISTS test_00101_0; CREATE DATABASE IF NOT EXISTS test_00101_0;
USE test_00101_0; USE test_00101_0;

View File

@ -1,3 +1,5 @@
-- Tags: shard, no-fasttest
SELECT 'Русский (default)'; SELECT 'Русский (default)';
SELECT arrayJoin(['а', 'я', 'ё', 'А', 'Я', 'Ё']) AS x ORDER BY x; SELECT arrayJoin(['а', 'я', 'ё', 'А', 'Я', 'Ё']) AS x ORDER BY x;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET max_rows_to_group_by = 100000; SET max_rows_to_group_by = 100000;
SET group_by_overflow_mode = 'any'; SET group_by_overflow_mode = 'any';

View File

@ -1,3 +1,5 @@
-- Tags: shard, no-parallel, no-fasttest
SET max_rows_to_group_by = 100000; SET max_rows_to_group_by = 100000;
SET max_block_size = 100001; SET max_block_size = 100001;
SET group_by_overflow_mode = 'any'; SET group_by_overflow_mode = 'any';

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel, no-fasttest
SET max_memory_usage = 300000000; SET max_memory_usage = 300000000;
SET max_bytes_before_external_sort = 20000000; SET max_bytes_before_external_sort = 20000000;
SELECT number FROM (SELECT number FROM system.numbers LIMIT 10000000) ORDER BY number * 1234567890123456789 LIMIT 9999990, 10; SELECT number FROM (SELECT number FROM system.numbers LIMIT 10000000) ORDER BY number * 1234567890123456789 LIMIT 9999990, 10;

View File

@ -1,3 +1,5 @@
-- Tags: distributed
SET max_memory_usage = 300000000; SET max_memory_usage = 300000000;
SET max_bytes_before_external_sort = 20000000; SET max_bytes_before_external_sort = 20000000;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET totals_mode = 'after_having_auto'; SET totals_mode = 'after_having_auto';
SET max_rows_to_group_by = 100000; SET max_rows_to_group_by = 100000;
SET group_by_overflow_mode = 'any'; SET group_by_overflow_mode = 'any';

View File

@ -1,3 +1,5 @@
-- Tags: shard
SELECT intDiv(number, 100) AS k, length(groupArray(number)) FROM (SELECT * FROM system.numbers LIMIT 1000000) GROUP BY k WITH TOTALS ORDER BY k LIMIT 10; SELECT intDiv(number, 100) AS k, length(groupArray(number)) FROM (SELECT * FROM system.numbers LIMIT 1000000) GROUP BY k WITH TOTALS ORDER BY k LIMIT 10;
SELECT ''; SELECT '';

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: shard
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel
DROP TABLE IF EXISTS set; DROP TABLE IF EXISTS set;
DROP TABLE IF EXISTS set2; DROP TABLE IF EXISTS set2;

View File

@ -1,3 +1,6 @@
-- Tags: zookeeper, no-replicated-database
-- Tag no-replicated-database: Old syntax is not allowed
DROP TABLE IF EXISTS alter_00121; DROP TABLE IF EXISTS alter_00121;
CREATE TABLE alter_00121 (d Date, x UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/alter_00121/t1', 'r1', d, (d), 8192); CREATE TABLE alter_00121 (d Date, x UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/alter_00121/t1', 'r1', d, (d), 8192);

View File

@ -1,2 +1,4 @@
-- Tags: distributed
SET max_distributed_connections = 1; SET max_distributed_connections = 1;
SELECT count() + 1 FROM remote('127.0.0.{2,3}', system, one); SELECT count() + 1 FROM remote('127.0.0.{2,3}', system, one);

View File

@ -1,3 +1,5 @@
-- Tags: replica, distributed
SET max_parallel_replicas = 2; SET max_parallel_replicas = 2;
DROP TABLE IF EXISTS report; DROP TABLE IF EXISTS report;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long, shard, no-parallel
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1 +1,3 @@
-- Tags: distributed
SELECT DISTINCT number FROM remote('127.0.0.{2,3}', system.numbers) LIMIT 10 SELECT DISTINCT number FROM remote('127.0.0.{2,3}', system.numbers) LIMIT 10

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel
CREATE DATABASE IF NOT EXISTS test2_00158; CREATE DATABASE IF NOT EXISTS test2_00158;
DROP TABLE IF EXISTS test2_00158.mt_buffer_00158; DROP TABLE IF EXISTS test2_00158.mt_buffer_00158;
DROP TABLE IF EXISTS test2_00158.mt_00158; DROP TABLE IF EXISTS test2_00158.mt_00158;

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT toFloat64(dummy + 2) AS n, j1, j2 FROM remote('127.0.0.{2,3}', system.one) jr1 GLOBAL ANY LEFT JOIN (SELECT number / 3 AS n, number AS j1, 'Hello' AS j2 FROM system.numbers LIMIT 10) jr2 USING n LIMIT 10; SELECT toFloat64(dummy + 2) AS n, j1, j2 FROM remote('127.0.0.{2,3}', system.one) jr1 GLOBAL ANY LEFT JOIN (SELECT number / 3 AS n, number AS j1, 'Hello' AS j2 FROM system.numbers LIMIT 10) jr2 USING n LIMIT 10;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET any_join_distinct_right_table_keys = 1; SET any_join_distinct_right_table_keys = 1;
SET joined_subquery_requires_alias = 0; SET joined_subquery_requires_alias = 0;

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT arrayMap((x, y) -> (x, y), [1, 2, 3], [4, 5, 6]) FROM remote('127.0.0.{2,3}', system.one) ORDER BY rand(); SELECT arrayMap((x, y) -> (x, y), [1, 2, 3], [4, 5, 6]) FROM remote('127.0.0.{2,3}', system.one) ORDER BY rand();

View File

@ -1,3 +1,5 @@
-- Tags: replica
SELECT SELECT
number, number,
range(number) AS arr, range(number) AS arr,

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel
DROP TABLE IF EXISTS t_00180; DROP TABLE IF EXISTS t_00180;
DROP TABLE IF EXISTS mv_00180; DROP TABLE IF EXISTS mv_00180;
DROP TABLE IF EXISTS `.inner.mv_00180`; DROP TABLE IF EXISTS `.inner.mv_00180`;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET send_logs_level = 'fatal'; SET send_logs_level = 'fatal';
SELECT count() FROM remote('{127,1}.0.0.{2,3}', system.one) SETTINGS skip_unavailable_shards = 1; SELECT count() FROM remote('{127,1}.0.0.{2,3}', system.one) SETTINGS skip_unavailable_shards = 1;
SELECT count() FROM remote('{1,127}.0.0.{2,3}', system.one) SETTINGS skip_unavailable_shards = 1; SELECT count() FROM remote('{1,127}.0.0.{2,3}', system.one) SETTINGS skip_unavailable_shards = 1;

View File

@ -1,3 +1,5 @@
-- Tags: distributed
SELECT 'distributed_group_by_no_merge=1'; SELECT 'distributed_group_by_no_merge=1';
SELECT count(), uniq(dummy) FROM remote('127.0.0.{2,3}', system.one) SETTINGS distributed_group_by_no_merge=1; SELECT count(), uniq(dummy) FROM remote('127.0.0.{2,3}', system.one) SETTINGS distributed_group_by_no_merge=1;
SELECT count(), uniq(dummy) FROM remote('127.0.0.{2,3,4,5}', system.one) SETTINGS distributed_group_by_no_merge=1; SELECT count(), uniq(dummy) FROM remote('127.0.0.{2,3,4,5}', system.one) SETTINGS distributed_group_by_no_merge=1;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,3 +1,4 @@
-- Tags: long
/* timestamp 1419800400 == 2014-12-29 00:00:00 (Europe/Moscow) */ /* timestamp 1419800400 == 2014-12-29 00:00:00 (Europe/Moscow) */
/* timestamp 1412106600 == 2014-09-30 23:50:00 (Europe/Moscow) */ /* timestamp 1412106600 == 2014-09-30 23:50:00 (Europe/Moscow) */

View File

@ -1,3 +1,5 @@
-- Tags: replica
DROP TABLE IF EXISTS parallel_replicas; DROP TABLE IF EXISTS parallel_replicas;
DROP TABLE IF EXISTS parallel_replicas_backup; DROP TABLE IF EXISTS parallel_replicas_backup;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SELECT * FROM (SELECT * WHERE dummy GLOBAL IN (SELECT 0)); SELECT * FROM (SELECT * WHERE dummy GLOBAL IN (SELECT 0));
SELECT * FROM (SELECT * WHERE dummy GLOBAL IN (SELECT toUInt8(number) FROM system.numbers LIMIT 10)); SELECT * FROM (SELECT * WHERE dummy GLOBAL IN (SELECT toUInt8(number) FROM system.numbers LIMIT 10));
SELECT * FROM (SELECT * FROM (SELECT * FROM system.numbers LIMIT 20) WHERE number GLOBAL IN (SELECT number FROM system.numbers LIMIT 10)); SELECT * FROM (SELECT * FROM (SELECT * FROM system.numbers LIMIT 20) WHERE number GLOBAL IN (SELECT number FROM system.numbers LIMIT 10));

View File

@ -1,3 +1,5 @@
-- Tags: distributed
DROP TABLE IF EXISTS numbers_memory; DROP TABLE IF EXISTS numbers_memory;
CREATE TABLE numbers_memory AS system.numbers ENGINE = Memory; CREATE TABLE numbers_memory AS system.numbers ENGINE = Memory;
INSERT INTO numbers_memory SELECT number FROM system.numbers LIMIT 100; INSERT INTO numbers_memory SELECT number FROM system.numbers LIMIT 100;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SELECT toUInt64(1) IN (1234567890, 2345678901, 3456789012, 4567890123, 5678901234, 6789012345, 7890123456, 8901234567, 9012345678, 123456789) AS x, 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, x, x, x, x, x, x, x,

View File

@ -1,3 +1,5 @@
-- Tags: long, shard
-- uniqHLL12 -- uniqHLL12
SELECT 'uniqHLL12'; SELECT 'uniqHLL12';

View File

@ -1 +1,3 @@
-- Tags: global
SELECT 1 GLOBAL IN (SELECT 1), 2 GLOBAL IN (SELECT 2) FROM remote('localhost', system.one); SELECT 1 GLOBAL IN (SELECT 1), 2 GLOBAL IN (SELECT 2) FROM remote('localhost', system.one);

View File

@ -1,3 +1,6 @@
-- Tags: long, zookeeper, no-replicated-database
-- Tag no-replicated-database: Old syntax is not allowed
DROP TABLE IF EXISTS primary_key; DROP TABLE IF EXISTS primary_key;
CREATE TABLE primary_key (d Date DEFAULT today(), x Int8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00215/primary_key', 'r1', d, -x, 1); CREATE TABLE primary_key (d Date DEFAULT today(), x Int8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00215/primary_key', 'r1', d, -x, 1);

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET joined_subquery_requires_alias = 0; SET joined_subquery_requires_alias = 0;
SELECT k, a FROM (SELECT 42 AS k FROM remote('127.0.0.2', system.one)) GLOBAL ALL FULL OUTER JOIN (SELECT 42 AS k, 1 AS a, a) USING k; SELECT k, a FROM (SELECT 42 AS k FROM remote('127.0.0.2', system.one)) GLOBAL ALL FULL OUTER JOIN (SELECT 42 AS k, 1 AS a, a) USING k;

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT x FROM (SELECT count() AS x FROM remote('127.0.0.2', system.one) WITH TOTALS) LIMIT 1; SELECT x FROM (SELECT count() AS x FROM remote('127.0.0.2', system.one) WITH TOTALS) LIMIT 1;

View File

@ -1,3 +1,5 @@
-- Tags: distributed
SET max_block_size = 1000; SET max_block_size = 1000;
DROP TABLE IF EXISTS numbers_10_00223; DROP TABLE IF EXISTS numbers_10_00223;

View File

@ -1,3 +1,5 @@
-- Tags: distributed
DROP TABLE IF EXISTS numbers_100k_log; DROP TABLE IF EXISTS numbers_100k_log;
CREATE TABLE numbers_100k_log ENGINE = Log AS SELECT * FROM system.numbers LIMIT 100000; CREATE TABLE numbers_100k_log ENGINE = Log AS SELECT * FROM system.numbers LIMIT 100000;

View File

@ -1,3 +1,6 @@
-- Tags: long, zookeeper, no-replicated-database
-- Tag no-replicated-database: Old syntax is not allowed
DROP TABLE IF EXISTS deduplication; DROP TABLE IF EXISTS deduplication;
CREATE TABLE deduplication (d Date DEFAULT '2015-01-01', x Int8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00226/deduplication', 'r1', d, x, 1); CREATE TABLE deduplication (d Date DEFAULT '2015-01-01', x Int8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00226/deduplication', 'r1', d, x, 1);

View File

@ -1,3 +1,5 @@
-- Tags: shard
select quantilesDeterministic(0.5, 0.9)(number, number) from (select number from system.numbers limit 101); select quantilesDeterministic(0.5, 0.9)(number, number) from (select number from system.numbers limit 101);
-- test merge does not cause overflow -- test merge does not cause overflow
select ignore(quantilesDeterministic(0.5, 0.9)(number, number)) from (select number from remote('127.0.0.{2,3}', system, numbers) limit 1000000); select ignore(quantilesDeterministic(0.5, 0.9)(number, number)) from (select number from remote('127.0.0.{2,3}', system, numbers) limit 1000000);

View File

@ -1,3 +1,6 @@
-- Tags: long, replica, no-replicated-database
-- Tag no-replicated-database: Old syntax is not allowed
SET replication_alter_partitions_sync = 2; SET replication_alter_partitions_sync = 2;
DROP TABLE IF EXISTS attach_r1; DROP TABLE IF EXISTS attach_r1;

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS storage; DROP TABLE IF EXISTS storage;
CREATE TABLE storage(UserID UInt64) ENGINE=Memory; CREATE TABLE storage(UserID UInt64) ENGINE=Memory;
INSERT INTO storage(UserID) values (6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(402895971392036118)(402895971392036118)(402895971392036118); INSERT INTO storage(UserID) values (6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(6460432721393873721)(402895971392036118)(402895971392036118)(402895971392036118);

View File

@ -1,3 +1,5 @@
-- Tags: shard
select 40 as z from (select * from system.numbers limit 3) group by z; select 40 as z from (select * from system.numbers limit 3) group by z;
select 41 as z from remote('127.0.0.{2,3}', system.one) group by z; select 41 as z from remote('127.0.0.{2,3}', system.one) group by z;
select count(), 42 AS z from remote('127.0.0.{2,3}', system.one) group by z; select count(), 42 AS z from remote('127.0.0.{2,3}', system.one) group by z;

View File

@ -1,3 +1,5 @@
-- Tags: no-fasttest
SELECT cityHash64(1, 2, '') AS x1, cityHash64((1, 2), '') AS x2, cityHash64(1, (2, '')) AS x3, cityHash64((1, 2, '')) AS x4; SELECT cityHash64(1, 2, '') AS x1, cityHash64((1, 2), '') AS x2, cityHash64(1, (2, '')) AS x3, cityHash64((1, 2, '')) AS x4;
SELECT cityHash64(materialize(1), 2, '') AS x1, cityHash64((materialize(1), 2), '') AS x2, cityHash64(materialize(1), (2, '')) AS x3, cityHash64((materialize(1), 2, '')) AS x4; SELECT cityHash64(materialize(1), 2, '') AS x1, cityHash64((materialize(1), 2), '') AS x2, cityHash64(materialize(1), (2, '')) AS x3, cityHash64((materialize(1), 2, '')) AS x4;
SELECT cityHash64(1, materialize(2), '') AS x1, cityHash64((1, materialize(2)), '') AS x2, cityHash64(1, (materialize(2), '')) AS x3, cityHash64((1, materialize(2), '')) AS x4; SELECT cityHash64(1, materialize(2), '') AS x1, cityHash64((1, materialize(2)), '') AS x2, cityHash64(1, (materialize(2), '')) AS x3, cityHash64((1, materialize(2), '')) AS x4;

View File

@ -1,3 +1,5 @@
-- Tags: race
SELECT 'a}a' AS x, x LIKE (concat('%', x, '%') AS pat), materialize(x) LIKE pat; SELECT 'a}a' AS x, x LIKE (concat('%', x, '%') AS pat), materialize(x) LIKE pat;
SELECT 'a}a' AS x, x LIKE (concat('%', x) AS pat), materialize(x) LIKE pat; SELECT 'a}a' AS x, x LIKE (concat('%', x) AS pat), materialize(x) LIKE pat;
SELECT 'a}a' AS x, x LIKE (concat(x, '%') AS pat), materialize(x) LIKE pat; SELECT 'a}a' AS x, x LIKE (concat(x, '%') AS pat), materialize(x) LIKE pat;

View File

@ -1 +1,3 @@
-- Tags: shard
SELECT 1 GLOBAL IN (SELECT 1) AS s, s FROM remote('127.0.0.{2,3}', system.one); SELECT 1 GLOBAL IN (SELECT 1) AS s, s FROM remote('127.0.0.{2,3}', system.one);

View File

@ -1,3 +1,5 @@
-- Tags: shard
SELECT length(groupArray(number)), count() FROM (SELECT number FROM system.numbers_mt LIMIT 1000000); SELECT length(groupArray(number)), count() FROM (SELECT number FROM system.numbers_mt LIMIT 1000000);
SELECT groupArray(dummy), count() FROM remote('127.0.0.{2,3}', system.one); SELECT groupArray(dummy), count() FROM remote('127.0.0.{2,3}', system.one);

View File

@ -1,3 +1,5 @@
-- Tags: shard
SELECT quantileExactWeighted(0.5)(number, 1) FROM (SELECT number FROM system.numbers LIMIT 1001); SELECT quantileExactWeighted(0.5)(number, 1) FROM (SELECT number FROM system.numbers LIMIT 1001);
SELECT quantilesExactWeighted(0, 0.001, 0.01, 0.05, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 0.95, 0.99, 0.999, 1)(number, 1) FROM (SELECT number FROM system.numbers LIMIT 1001); SELECT quantilesExactWeighted(0, 0.001, 0.01, 0.05, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 0.95, 0.99, 0.999, 1)(number, 1) FROM (SELECT number FROM system.numbers LIMIT 1001);
SELECT quantilesExactWeighted(0, 0.001, 0.01, 0.05, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 0.95, 0.99, 0.999, 1)(number, number) FROM (SELECT number FROM system.numbers LIMIT 1001); SELECT quantilesExactWeighted(0, 0.001, 0.01, 0.05, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 0.95, 0.99, 0.999, 1)(number, number) FROM (SELECT number FROM system.numbers LIMIT 1001);

View File

@ -1 +1,3 @@
-- Tags: long
select reinterpretAsFloat64(unhex('875635ffffffbfbe')) select reinterpretAsFloat64(unhex('875635ffffffbfbe'))

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS numbers_10_00290; DROP TABLE IF EXISTS numbers_10_00290;
SET max_block_size = 1000; SET max_block_size = 1000;
CREATE TABLE numbers_10_00290 ENGINE = Log AS SELECT * FROM system.numbers LIMIT 10000; CREATE TABLE numbers_10_00290 ENGINE = Log AS SELECT * FROM system.numbers LIMIT 10000;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET max_subquery_depth = 3; SET max_subquery_depth = 3;
SELECT 1 FROM remote('127.0.0.{1,2}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one)))); SELECT 1 FROM remote('127.0.0.{1,2}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one))));

View File

@ -1,3 +1,5 @@
-- Tags: shard
set max_threads = 1; set max_threads = 1;
drop table if exists enums; drop table if exists enums;

View File

@ -1,3 +1,5 @@
-- Tags: shard
SET output_format_write_statistics = 0; SET output_format_write_statistics = 0;
SELECT arrayJoin(range(100)) AS x FROM remote('127.0.0.2', system.one) WHERE x GLOBAL IN (SELECT toUInt8(arrayJoin(range(100)) + 50)) GROUP BY x ORDER BY x LIMIT 10 FORMAT JSONCompact; SELECT arrayJoin(range(100)) AS x FROM remote('127.0.0.2', system.one) WHERE x GLOBAL IN (SELECT toUInt8(arrayJoin(range(100)) + 50)) GROUP BY x ORDER BY x LIMIT 10 FORMAT JSONCompact;
SELECT arrayJoin(range(100)) AS x FROM remote('127.0.0.{2,3}', system.one) WHERE x GLOBAL IN (SELECT toUInt8(arrayJoin(range(100)) + 50)) GROUP BY x ORDER BY x LIMIT 10 FORMAT JSONCompact; SELECT arrayJoin(range(100)) AS x FROM remote('127.0.0.{2,3}', system.one) WHERE x GLOBAL IN (SELECT toUInt8(arrayJoin(range(100)) + 50)) GROUP BY x ORDER BY x LIMIT 10 FORMAT JSONCompact;

View File

@ -1,3 +1,5 @@
-- Tags: disabled, zookeeper, no-parallel
DROP TABLE IF EXISTS r1; DROP TABLE IF EXISTS r1;
DROP TABLE IF EXISTS r2; DROP TABLE IF EXISTS r2;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: no-fasttest
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: no-parallel
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,3 +1,5 @@
-- Tags: no-parallel
DROP TABLE IF EXISTS array_pk; DROP TABLE IF EXISTS array_pk;
CREATE TABLE array_pk (key Array(UInt8), s String, n UInt64, d Date MATERIALIZED '2000-01-01') ENGINE = MergeTree(d, (key, s, n), 1); CREATE TABLE array_pk (key Array(UInt8), s String, n UInt64, d Date MATERIALIZED '2000-01-01') ENGINE = MergeTree(d, (key, s, n), 1);

View File

@ -1,2 +1,4 @@
-- Tags: no-fasttest
SELECT cityHash64(*) FROM (SELECT 1 AS x, CAST(x AS Enum8('Hello' = 0, 'World' = 1)) AS y); SELECT cityHash64(*) FROM (SELECT 1 AS x, CAST(x AS Enum8('Hello' = 0, 'World' = 1)) AS y);
SELECT cityHash64(*) FROM (SELECT 1 AS x, x AS y); SELECT cityHash64(*) FROM (SELECT 1 AS x, x AS y);

View File

@ -1,3 +1,5 @@
-- Tags: disabled
DROP TABLE IF EXISTS replacing; DROP TABLE IF EXISTS replacing;
CREATE TABLE replacing (d Date, k UInt64, s String, v UInt16) ENGINE = ReplacingMergeTree(d, k, 8192, v); CREATE TABLE replacing (d Date, k UInt64, s String, v UInt16) ENGINE = ReplacingMergeTree(d, k, 8192, v);

View File

@ -1,3 +1,4 @@
-- Tags: long
SELECT 'Trivial case'; SELECT 'Trivial case';

View File

@ -1,3 +1,5 @@
-- Tags: long
/* Trivial case */ /* Trivial case */
SELECT CASE WHEN 1 THEN 2 WHEN 3 THEN 4 ELSE 5 END; SELECT CASE WHEN 1 THEN 2 WHEN 3 THEN 4 ELSE 5 END;

View File

@ -1,2 +1,4 @@
-- Tags: no-parallel, no-fasttest
SELECT quantileTiming(number) FROM (SELECT * FROM system.numbers LIMIT 10000); SELECT quantileTiming(number) FROM (SELECT * FROM system.numbers LIMIT 10000);
SELECT floor(log2(1 + number) / log2(1.5)) AS k, count() AS c, quantileTiming(number % 10000) AS q FROM (SELECT * FROM system.numbers LIMIT 1000000) GROUP BY k ORDER BY k; SELECT floor(log2(1 + number) / log2(1.5)) AS k, count() AS c, quantileTiming(number % 10000) AS q FROM (SELECT * FROM system.numbers LIMIT 1000000) GROUP BY k ORDER BY k;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: race, shard
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,2 +1,4 @@
-- Tags: shard
SELECT anyHeavy(x) FROM (SELECT intHash64(number) % 100 < 60 ? 999 : number AS x FROM system.numbers LIMIT 100000); SELECT anyHeavy(x) FROM (SELECT intHash64(number) % 100 < 60 ? 999 : number AS x FROM system.numbers LIMIT 100000);
SELECT anyHeavy(1) FROM remote('127.0.0.{2,3}', system.one); SELECT anyHeavy(1) FROM remote('127.0.0.{2,3}', system.one);

View File

@ -1,3 +1,5 @@
-- Tags: replica
DROP TABLE IF EXISTS bad_arrays; DROP TABLE IF EXISTS bad_arrays;
CREATE TABLE bad_arrays (a Array(String), b Array(UInt8)) ENGINE = Memory; CREATE TABLE bad_arrays (a Array(String), b Array(UInt8)) ENGINE = Memory;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: no-fasttest
set -e set -e

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS group_uniq_str; DROP TABLE IF EXISTS group_uniq_str;
CREATE TABLE group_uniq_str ENGINE = Memory AS SELECT number % 10 as id, toString(intDiv((number%10000), 10)) as v FROM system.numbers LIMIT 10000000; CREATE TABLE group_uniq_str ENGINE = Memory AS SELECT number % 10 as id, toString(intDiv((number%10000), 10)) as v FROM system.numbers LIMIT 10000000;

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS group_uniq_arr_int; DROP TABLE IF EXISTS group_uniq_arr_int;
CREATE TABLE group_uniq_arr_int ENGINE = Memory AS CREATE TABLE group_uniq_arr_int ENGINE = Memory AS
SELECT g as id, if(c == 0, [v], if(c == 1, emptyArrayInt64(), [v, v])) as v FROM SELECT g as id, if(c == 0, [v], if(c == 1, emptyArrayInt64(), [v, v])) as v FROM

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS group_uniq_arr_str; DROP TABLE IF EXISTS group_uniq_arr_str;
CREATE TABLE group_uniq_arr_str ENGINE = Memory AS CREATE TABLE group_uniq_arr_str ENGINE = Memory AS
SELECT hex(intHash32(g)) as id, if(c == 0, [hex(v)], if(c == 1, emptyArrayString(), [hex(v), hex(v)])) as v FROM SELECT hex(intHash32(g)) as id, if(c == 0, [hex(v)], if(c == 1, emptyArrayString(), [hex(v), hex(v)])) as v FROM

View File

@ -1,3 +1,5 @@
-- Tags: no-fasttest
SET output_format_write_statistics = 0; SET output_format_write_statistics = 0;
SET extremes = 1; SET extremes = 1;

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: no-fasttest
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,6 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
set -e set -e
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: no-fasttest
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: no-fasttest
set -e set -e

View File

@ -1,3 +1,5 @@
-- Tags: shard
DROP TABLE IF EXISTS limit_by; DROP TABLE IF EXISTS limit_by;
CREATE TABLE limit_by (Num UInt32, Name String) ENGINE = Memory; CREATE TABLE limit_by (Num UInt32, Name String) ENGINE = Memory;

View File

@ -1,3 +1,5 @@
-- Tags: long
-- The results are different than in Python. That's why this file is genearated and the reference is edited instead of using the Python script. -- The results are different than in Python. That's why this file is genearated and the reference is edited instead of using the Python script.
-- Example: in ClickHouse, 9223372036854775808.0 != 9223372036854775808. -- Example: in ClickHouse, 9223372036854775808.0 != 9223372036854775808.

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

View File

@ -1,4 +1,5 @@
#!/usr/bin/env bash #!/usr/bin/env bash
# Tags: long
CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd) CURDIR=$(cd "$(dirname "${BASH_SOURCE[0]}")" && pwd)
# shellcheck source=../shell_config.sh # shellcheck source=../shell_config.sh

Some files were not shown because too many files have changed in this diff Show More