Disable some tests

This commit is contained in:
alesapin 2022-02-04 14:31:58 +03:00
parent 875e5413ad
commit 25c0b07e68
24 changed files with 30 additions and 4 deletions

View File

@ -100,7 +100,7 @@ public:
void removeSharedFileIfExists(const String & path, bool delete_metadata_only) override;
void removeSharedRecursive(const String & path, bool keep_in_remote_fs) override;
void removeSharedRecursive(const String & path, bool delete_metadata_only) override;
void listFiles(const String & path, std::vector<String> & file_names) override;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
set allow_experimental_projection_optimization = 1, force_optimize_projection = 1;
drop table if exists tp;

View File

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

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists tp;
create table tp (d1 Int32, d2 Int32, eventcnt Int64, projection p (select sum(eventcnt) group by d1)) engine = MergeTree order by (d1, d2);

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists d;
create table d (i int, j int) engine MergeTree partition by i % 2 order by tuple() settings index_granularity = 1;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists t;
create table t (i int, j int) engine MergeTree order by i;

View File

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

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
set allow_experimental_projection_optimization = 1;
drop table if exists x;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
set allow_experimental_projection_optimization = 1;
drop table if exists t;

View File

@ -1,3 +1,5 @@
-- Tags: no-s3-storage
drop table if exists tp;
create table tp (x Int32, y Int32, projection p (select x, y order by x)) engine = MergeTree order by y;

View File

@ -1,4 +1,4 @@
-- Tags: long
-- Tags: long, no-s3-storage
drop table if exists tp_1;
drop table if exists tp_2;

View File

@ -1,3 +1,6 @@
-- Tags: no-s3-storage
DROP TABLE IF EXISTS t;
drop table if exists tp;
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; -- { serverError 583 }

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists t;
create table t (i int, j int, k int, projection p (select * order by j)) engine MergeTree order by i settings index_granularity = 1;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists x;
create table x (i UInt64, j UInt64, k UInt64, projection agg (select sum(j), avg(k) group by i), projection norm (select j, k order by i)) engine MergeTree order by tuple();

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists x;
create table x (i int) engine MergeTree order by tuple();

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
DROP TABLE IF EXISTS t;
CREATE TABLE t (`key` UInt32, `created_at` Date, `value` UInt32, PROJECTION xxx (SELECT key, created_at, sum(value) GROUP BY key, created_at)) ENGINE = MergeTree PARTITION BY toYYYYMM(created_at) ORDER BY key;
@ -5,3 +6,5 @@ CREATE TABLE t (`key` UInt32, `created_at` Date, `value` UInt32, PROJECTION xxx
INSERT INTO t SELECT 1 AS key, today() + (number % 30), number FROM numbers(1000);
ALTER TABLE t UPDATE value = 0 WHERE (value > 0) AND (created_at >= '2021-12-21') SETTINGS allow_experimental_projection_optimization = 1;
DROP TABLE IF EXISTS t;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists z;
create table z (pk Int64, d Date, id UInt64, c UInt64) Engine MergeTree partition by d order by pk ;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists tp;
create table tp (x Int32, y Int32, projection p (select x, y order by x)) engine = MergeTree order by y settings min_rows_for_compact_part = 2, min_rows_for_wide_part = 4, min_bytes_for_compact_part = 16, min_bytes_for_wide_part = 32;

View File

@ -1,4 +1,4 @@
-- Tags: long, no-parallel
-- Tags: long, no-parallel, no-s3-storage
drop table if exists t;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists t;
create table t (s UInt16, l UInt16, projection p (select s, l order by l)) engine MergeTree order by s;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists t;
create table t (x UInt32) engine = MergeTree order by tuple() settings index_granularity = 8;

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists projection_test;
create table projection_test (`sum(block_count)` UInt64, domain_alias UInt64 alias length(domain), datetime DateTime, domain LowCardinality(String), x_id String, y_id String, block_count Int64, retry_count Int64, duration Int64, kbytes Int64, buffer_time Int64, first_time Int64, total_bytes Nullable(UInt64), valid_bytes Nullable(UInt64), completed_bytes Nullable(UInt64), fixed_bytes Nullable(UInt64), force_bytes Nullable(UInt64), projection p (select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) / count(), avg((kbytes * 8) / duration), count(), sum(block_count) / sum(duration), avg(block_count / duration), sum(buffer_time) / sum(duration), avg(buffer_time / duration), sum(valid_bytes) / sum(total_bytes), sum(completed_bytes) / sum(total_bytes), sum(fixed_bytes) / sum(total_bytes), sum(force_bytes) / sum(total_bytes), sum(valid_bytes) / sum(total_bytes), sum(retry_count) / sum(duration), avg(retry_count / duration), countIf(block_count > 0) / count(), countIf(first_time = 0) / count(), uniqHLL12(x_id), uniqHLL12(y_id) group by dt_m, domain)) engine MergeTree partition by toDate(datetime) order by (toStartOfTenMinutes(datetime), domain);

View File

@ -1,3 +1,4 @@
-- Tags: no-s3-storage
drop table if exists projection_without_key;
create table projection_without_key (key UInt32, PROJECTION x (SELECT sum(key) group by key % 3)) engine MergeTree order by key;

View File

@ -1,4 +1,4 @@
-- Tags: distributed
-- Tags: distributed, no-s3-storage
drop table if exists projection_test;