Updated ttl test according to new TTL syntax.

This commit is contained in:
Vladimir Chebotarev 2019-10-16 13:42:10 +03:00
parent 3e984609fb
commit 5a12986159

View File

@ -1,6 +1,7 @@
import time import time
import pytest import pytest
import helpers.client as client
from helpers.cluster import ClickHouseCluster from helpers.cluster import ClickHouseCluster
from helpers.test_tools import TSV from helpers.test_tools import TSV
@ -9,7 +10,7 @@ node1 = cluster.add_instance('node1', with_zookeeper=True)
node2 = cluster.add_instance('node2', with_zookeeper=True) node2 = cluster.add_instance('node2', with_zookeeper=True)
@pytest.fixture(scope="module") @pytest.fixture(scope="module")
def start_cluster(): def started_cluster():
try: try:
cluster.start() cluster.start()
@ -25,7 +26,7 @@ def drop_table(nodes, table_name):
for node in nodes: for node in nodes:
node.query("DROP TABLE IF EXISTS {}".format(table_name)) node.query("DROP TABLE IF EXISTS {}".format(table_name))
def test_ttl_columns(start_cluster): def test_ttl_columns(started_cluster):
drop_table([node1, node2], "test_ttl") drop_table([node1, node2], "test_ttl")
for node in [node1, node2]: for node in [node1, node2]:
node.query( node.query(
@ -43,8 +44,12 @@ def test_ttl_columns(start_cluster):
expected = "1\t0\t0\n2\t0\t0\n" expected = "1\t0\t0\n2\t0\t0\n"
assert TSV(node1.query("SELECT id, a, b FROM test_ttl ORDER BY id")) == TSV(expected) assert TSV(node1.query("SELECT id, a, b FROM test_ttl ORDER BY id")) == TSV(expected)
assert TSV(node2.query("SELECT id, a, b FROM test_ttl ORDER BY id")) == TSV(expected) assert TSV(node2.query("SELECT id, a, b FROM test_ttl ORDER BY id")) == TSV(expected)
def test_ttl_table(start_cluster): @pytest.mark.parametrize("delete_suffix", [
"",
"DELETE",
])
def test_ttl_table(started_cluster, delete_suffix):
drop_table([node1, node2], "test_ttl") drop_table([node1, node2], "test_ttl")
for node in [node1, node2]: for node in [node1, node2]:
node.query( node.query(
@ -52,8 +57,8 @@ def test_ttl_table(start_cluster):
CREATE TABLE test_ttl(date DateTime, id UInt32) CREATE TABLE test_ttl(date DateTime, id UInt32)
ENGINE = ReplicatedMergeTree('/clickhouse/tables/test/test_ttl', '{replica}') ENGINE = ReplicatedMergeTree('/clickhouse/tables/test/test_ttl', '{replica}')
ORDER BY id PARTITION BY toDayOfMonth(date) ORDER BY id PARTITION BY toDayOfMonth(date)
TTL date + INTERVAL 1 DAY SETTINGS merge_with_ttl_timeout=0; TTL date + INTERVAL 1 DAY {delete_suffix} SETTINGS merge_with_ttl_timeout=0;
'''.format(replica=node.name)) '''.format(replica=node.name, delete_suffix=delete_suffix))
node1.query("INSERT INTO test_ttl VALUES (toDateTime('2000-10-10 00:00:00'), 1)") node1.query("INSERT INTO test_ttl VALUES (toDateTime('2000-10-10 00:00:00'), 1)")
node1.query("INSERT INTO test_ttl VALUES (toDateTime('2000-10-11 10:00:00'), 2)") node1.query("INSERT INTO test_ttl VALUES (toDateTime('2000-10-11 10:00:00'), 2)")
@ -62,4 +67,18 @@ def test_ttl_table(start_cluster):
assert TSV(node1.query("SELECT * FROM test_ttl")) == TSV("") assert TSV(node1.query("SELECT * FROM test_ttl")) == TSV("")
assert TSV(node2.query("SELECT * FROM test_ttl")) == TSV("") assert TSV(node2.query("SELECT * FROM test_ttl")) == TSV("")
def test_ttl_double_delete_rule_returns_error(started_cluster):
drop_table([node1, node2], "test_ttl")
try:
node1.query('''
CREATE TABLE test_ttl(date DateTime, id UInt32)
ENGINE = ReplicatedMergeTree('/clickhouse/tables/test/test_ttl', '{replica}')
ORDER BY id PARTITION BY toDayOfMonth(date)
TTL date + INTERVAL 1 DAY, date + INTERVAL 2 DAY SETTINGS merge_with_ttl_timeout=0;
'''.format(replica=node1.name))
assert False
except client.QueryRuntimeException:
pass
except:
assert False