ClickHouse/tests/integration/test_groupBitmapAnd_on_distributed/test.py

83 lines
3.3 KiB
Python
Raw Normal View History

2021-12-17 14:50:41 +00:00
import pytest
from helpers.cluster import ClickHouseCluster
cluster = ClickHouseCluster(__file__)
2021-12-17 23:55:12 +00:00
node1 = cluster.add_instance('node1', main_configs=["configs/clusters.xml"], with_zookeeper=True)
node2 = cluster.add_instance('node2', main_configs=["configs/clusters.xml"], with_zookeeper=True)
node3 = cluster.add_instance('node3', main_configs=["configs/clusters.xml"], with_zookeeper=True)
node4 = cluster.add_instance('node4', main_configs=["configs/clusters.xml"], image='yandex/clickhouse-server', tag='21.5', with_zookeeper=True)
2021-12-17 14:50:41 +00:00
def insert_data(node, table_name):
node.query("""INSERT INTO {}
VALUES (bitmapBuild(cast([1,2,3,4,5,6,7,8,9,10] as Array(UInt32))));""".format(table_name))
@pytest.fixture(scope="module")
def start_cluster():
try:
cluster.start()
yield cluster
finally:
cluster.shutdown()
def test_groupBitmapAnd_on_distributed_table(start_cluster):
local_table_name = "bitmap_column_expr_test"
distributed_table_name = "bitmap_column_expr_test_dst"
cluster_name = "awsome_cluster"
2021-12-17 23:55:12 +00:00
for node in (node1, node2):
node.query("""CREATE TABLE {}
(
z AggregateFunction(groupBitmap, UInt32)
)
ENGINE = MergeTree()
ORDER BY tuple()""".format(local_table_name))
2021-12-18 04:27:31 +00:00
node.query("""CREATE TABLE {}
2021-12-17 23:55:12 +00:00
(
z AggregateFunction(groupBitmap, UInt32)
)
2021-12-18 04:27:31 +00:00
ENGINE = Distributed('{}', 'default', '{}')""".format(distributed_table_name, cluster_name, local_table_name))
2021-12-17 14:50:41 +00:00
insert_data(node1, local_table_name)
expected = "10"
2021-12-17 23:55:12 +00:00
for node in (node1, node2):
result = node.query("select groupBitmapAnd(z) FROM {};".format(distributed_table_name)).strip()
assert(result == expected)
2021-12-17 14:50:41 +00:00
def test_aggregate_function_versioning(start_cluster):
local_table_name = "bitmap_column_expr_versioning_test"
distributed_table_name = "bitmap_column_expr_versioning_test_dst"
cluster_name = "test_version_cluster"
2021-12-17 23:55:12 +00:00
for node in (node3, node4):
node.query("""CREATE TABLE {}
(
z AggregateFunction(groupBitmap, UInt32)
)
ENGINE = MergeTree()
ORDER BY tuple()""".format(local_table_name))
2021-12-17 14:50:41 +00:00
2021-12-18 04:27:31 +00:00
node.query("""CREATE TABLE {}
2021-12-17 23:55:12 +00:00
(
z AggregateFunction(groupBitmap, UInt32)
)
2021-12-18 04:27:31 +00:00
ENGINE = Distributed('{}', 'default', '{}')""".format(distributed_table_name, cluster_name, local_table_name))
2021-12-17 14:50:41 +00:00
2021-12-17 23:55:12 +00:00
node.query("""INSERT INTO {} VALUES
(bitmapBuild(cast([1,2,3,4,5,6,7,8,9,10] as Array(UInt32))));""".format(local_table_name))
2021-12-17 14:50:41 +00:00
expected = "10"
new_version_distributed_result = node3.query("select groupBitmapAnd(z) FROM {};".format(distributed_table_name)).strip()
old_version_distributed_result = node4.query("select groupBitmapAnd(z) FROM {};".format(distributed_table_name)).strip()
assert(new_version_distributed_result == expected)
assert(old_version_distributed_result == expected)
2021-12-17 23:55:12 +00:00
result_from_old_to_new_version = node3.query("select groupBitmapAnd(z) FROM remote('node4', default.{})".format(local_table_name)).strip()
2021-12-17 14:50:41 +00:00
assert(result_from_old_to_new_version != expected)
2021-12-17 23:55:12 +00:00
result_from_new_to_old_version = node4.query("select groupBitmapAnd(z) FROM remote('node3', default.{})".format(local_table_name)).strip()
2021-12-17 14:50:41 +00:00
assert(result_from_new_to_old_version != expected)