remove tmpfs for now

This commit is contained in:
Yatsishin Ilya 2021-05-19 13:23:51 +03:00
parent 76e481189b
commit 7a5895815b
5 changed files with 213 additions and 9 deletions

View File

@ -372,7 +372,7 @@ class ClickhouseIntegrationTestsRunner:
test_cmd = ' '.join([test for test in sorted(test_names)])
parallel_cmd = " --parallel {} ".format(num_workers) if num_workers > 0 else ""
cmd = "cd {}/tests/integration && ./runner {} --tmpfs -t {} {} '-ss -rfEp --color=no --durations=0 {}' | tee {}".format(
cmd = "cd {}/tests/integration && ./runner {} -t {} {} '-ss -rfEp --color=no --durations=0 {}' | tee {}".format(
repo_path, image_cmd, test_cmd, parallel_cmd, _get_deselect_option(self.should_skip_tests()), output_path)
with open(log_path, 'w') as log:

View File

@ -51,7 +51,7 @@ def _create_env_file(path, variables):
f.write("=".join([var, value]) + "\n")
return path
def run_and_check(args, env=None, shell=False, stdout=subprocess.PIPE, stderr=subprocess.PIPE, timeout=120):
def run_and_check(args, env=None, shell=False, stdout=subprocess.PIPE, stderr=subprocess.PIPE, timeout=180):
res = subprocess.run(args, stdout=stdout, stderr=stderr, env=env, shell=shell, timeout=timeout)
if res.returncode != 0:
# check_call(...) from subprocess does not print stderr, so we do it manually
@ -760,7 +760,7 @@ class ClickHouseCluster:
run_and_check(self.base_cmd + ["up", "--force-recreate", "--no-deps", "-d", node.name])
node.ip_address = self.get_instance_ip(node.name)
node.client = Client(node.ip_address, command=self.client_bin_path)
start_deadline = time.time() + 120.0 # seconds
start_deadline = time.time() + 180.0 # seconds
node.wait_for_start(start_deadline)
return node
@ -1521,7 +1521,6 @@ class ClickHouseInstance:
self.docker_client = None
self.ip_address = None
self.client = None
self.default_timeout = 20.0 # 20 sec
self.image = image
self.tag = tag
self.stay_alive = stay_alive
@ -1718,7 +1717,7 @@ class ClickHouseInstance:
return None
return None
def restart_with_latest_version(self, stop_start_wait_sec=60, callback_onstop=None, signal=60):
def restart_with_latest_version(self, stop_start_wait_sec=120, callback_onstop=None, signal=60):
if not self.stay_alive:
raise Exception("Cannot restart not stay alive container")
self.exec_in_container(["bash", "-c", "pkill -{} clickhouse".format(signal)], user='root')

View File

@ -1,4 +1,162 @@
[
"test_dictionaries_access/test.py::test_create",
"test_dictionaries_access/test.py::test_dictget",
"test_dictionaries_access/test.py::test_drop",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_cassandra.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_local.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_clickhouse_remote.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_executable_cache.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_executable_cache.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_executable_hashed.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_executable_hashed.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_executable_hashed.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_file.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_file.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_file.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_file.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_http.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_https.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_mongo.py::test_simple[hashed]",
"test_dictionaries_all_layouts_separate_sources/test_mongo_uri.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_complex[complex_key_cache]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_complex[complex_key_direct]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_complex[complex_key_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_ranged[range_hashed]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_simple[cache]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_simple[direct]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_simple[flat]",
"test_dictionaries_all_layouts_separate_sources/test_mysql.py::test_simple[hashed]",
"test_dictionaries_complex_key_cache_string/test.py::test_memory_consumption[memory]",
"test_dictionaries_complex_key_cache_string/test.py::test_memory_consumption[ssd]",
"test_dictionaries_ddl/test.py::test_clickhouse_remote",
"test_dictionaries_ddl/test.py::test_conflicting_name",
"test_dictionaries_ddl/test.py::test_create_and_select_mysql[complex_node1_cache]",
"test_dictionaries_ddl/test.py::test_create_and_select_mysql[complex_node1_hashed]",
"test_dictionaries_ddl/test.py::test_create_and_select_mysql[complex_node2_cache]",
"test_dictionaries_ddl/test.py::test_create_and_select_mysql[complex_node2_hashed]",
"test_dictionaries_ddl/test.py::test_dictionary_with_where",
"test_dictionaries_ddl/test.py::test_file_dictionary_restrictions",
"test_dictionaries_ddl/test.py::test_http_dictionary_restrictions",
"test_dictionaries_ddl/test.py::test_restricted_database",
"test_dictionaries_dependency/test.py::test_dependency_via_dictionary_database[node0]",
"test_dictionaries_dependency/test.py::test_dependency_via_dictionary_database[node1]",
"test_dictionaries_dependency/test.py::test_dependency_via_explicit_table[node0]",
"test_dictionaries_dependency/test.py::test_dependency_via_explicit_table[node1]",
"test_dictionaries_dependency/test.py::test_dependency_via_implicit_table[node0]",
"test_dictionaries_dependency/test.py::test_dependency_via_implicit_table[node1]",
"test_dictionaries_dependency_xml/test.py::test_get_data",
"test_dictionaries_mysql/test.py::test_load_mysql_dictionaries",
"test_dictionaries_null_value/test.py::test_null_value",
"test_dictionaries_postgresql/test.py::test_dictionary_with_replicas",
"test_dictionaries_postgresql/test.py::test_invalidate_query",
"test_dictionaries_postgresql/test.py::test_load_dictionaries",
"test_dictionaries_postgresql/test.py::test_postgres_scema",
"test_dictionaries_redis/test.py::test_redis_dictionaries[0]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[1]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[10]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[11]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[12]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[13]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[2]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[3]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[4]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[5]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[6]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[7]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[8]",
"test_dictionaries_redis/test.py::test_redis_dictionaries[9]",
"test_dictionaries_select_all/test.py::test_select_all[clickhouse_complex_integers_key_hashed]",
"test_dictionaries_select_all/test.py::test_select_all[clickhouse_complex_mixed_key_hashed]",
"test_dictionaries_select_all/test.py::test_select_all[clickhouse_flat]",
"test_dictionaries_select_all/test.py::test_select_all[clickhouse_hashed]",
"test_dictionaries_select_all/test.py::test_select_all[clickhouse_range_hashed]",
"test_dictionaries_select_all/test.py::test_select_all_from_cached[clickhouse_cache]",
"test_dictionaries_select_all/test.py::test_select_all_from_cached[clickhouse_complex_integers_key_cache]",
"test_dictionaries_select_all/test.py::test_select_all_from_cached[clickhouse_complex_mixed_key_cache]",
"test_dictionaries_update_and_reload/test.py::test_reload_after_fail_by_system_reload",
"test_dictionaries_update_and_reload/test.py::test_reload_after_fail_by_timer",
"test_dictionaries_update_and_reload/test.py::test_reload_after_fail_in_cache_dictionary",
"test_dictionaries_update_and_reload/test.py::test_reload_after_loading",
"test_dictionaries_update_and_reload/test.py::test_reload_while_loading",
"test_dictionaries_update_field/test.py::test_update_field[complex_key_hashed_update_field_dictionary-HASHED]",
"test_dictionaries_update_field/test.py::test_update_field[flat_update_field_dictionary-FLAT]",
"test_dictionaries_update_field/test.py::test_update_field[simple_key_hashed_update_field_dictionary-HASHED]",
"test_dictionary_allow_read_expired_keys/test_default_reading.py::test_default_reading",
"test_dictionary_allow_read_expired_keys/test_default_string.py::test_return_real_values",
"test_dictionary_allow_read_expired_keys/test_dict_get_or_default.py::test_simple_dict_get_or_default",
"test_dictionary_allow_read_expired_keys/test_dict_get.py::test_simple_dict_get",
"test_dictionary_custom_settings/test.py::test_work",
"test_dictionary_ddl_on_cluster/test.py::test_dictionary_ddl_on_cluster",
"test_disk_access_storage/test.py::test_alter",
"test_disk_access_storage/test.py::test_create",
"test_disk_access_storage/test.py::test_drop",
"test_distributed_ddl_parallel/test.py::test_slow_dict_load_7",
"test_distributed_ddl_parallel/test.py::test_smoke_parallel_dict_reload",
"test_distributed_storage_configuration/test.py::test_insert",
"test_odbc_interaction/test.py::test_postgres_odbc_hashed_dictionary_no_tty_pipe_overflow",
"test_odbc_interaction/test.py::test_postgres_odbc_hashed_dictionary_with_schema",
"test_odbc_interaction/test.py::test_sqlite_odbc_cached_dictionary",
"test_odbc_interaction/test.py::test_sqlite_odbc_hashed_dictionary",
"test_odbc_interaction/test.py::test_sqlite_simple_select_storage_works",
"test_range_hashed_dictionary_types/test.py::test_range_hashed_dict",
"test_redirect_url_storage/test.py::test_url_with_globs",
"test_redirect_url_storage/test.py::test_url_with_globs_and_failover",
"test_redirect_url_storage/test.py::test_url_without_redirect",
"test_redirect_url_storage/test.py::test_url_with_redirect_allowed",
"test_redirect_url_storage/test.py::test_url_with_redirect_not_allowed",
"test_reloading_storage_configuration/test.py::test_add_disk",
"test_reloading_storage_configuration/test.py::test_add_disk_to_policy",
"test_reloading_storage_configuration/test.py::test_add_disk_to_separate_config",
"test_reloading_storage_configuration/test.py::test_add_policy",
"test_reloading_storage_configuration/test.py::test_add_volume_to_policy",
"test_reloading_storage_configuration/test.py::test_new_policy_works",
"test_reloading_storage_configuration/test.py::test_remove_disk",
"test_reloading_storage_configuration/test.py::test_remove_disk_from_policy",
"test_reloading_storage_configuration/test.py::test_remove_policy",
"test_reloading_storage_configuration/test.py::test_remove_volume_from_policy",
"test_s3_zero_copy_replication/test.py::test_s3_zero_copy_on_hybrid_storage",
"test_storage_hdfs/test.py::test_bad_hdfs_uri",
"test_storage_hdfs/test.py::test_globs_in_read_table",
"test_storage_hdfs/test.py::test_read_files_with_spaces",
@ -13,6 +171,49 @@
"test_storage_hdfs/test.py::test_write_gzip_storage",
"test_storage_hdfs/test.py::test_write_gz_storage",
"test_storage_hdfs/test.py::test_write_table",
"test_storage_kafka/test.py::test_bad_reschedule",
"test_storage_kafka/test.py::test_commits_of_unprocessed_messages_on_drop",
"test_storage_kafka/test.py::test_exception_from_destructor",
"test_storage_kafka/test.py::test_kafka_commit_on_block_write",
"test_storage_kafka/test.py::test_kafka_consumer_hang",
"test_storage_kafka/test.py::test_kafka_consumer_hang2",
"test_storage_kafka/test.py::test_kafka_csv_with_delimiter",
"test_storage_kafka/test.py::test_kafka_csv_with_thread_per_consumer",
"test_storage_kafka/test.py::test_kafka_duplicates_when_commit_failed",
"test_storage_kafka/test.py::test_kafka_engine_put_errors_to_stream",
"test_storage_kafka/test.py::test_kafka_engine_put_errors_to_stream_with_random_malformed_json",
"test_storage_kafka/test.py::test_kafka_flush_by_block_size",
"test_storage_kafka/test.py::test_kafka_flush_by_time",
"test_storage_kafka/test.py::test_kafka_flush_on_big_message",
"test_storage_kafka/test.py::test_kafka_formats",
"test_storage_kafka/test.py::test_kafka_formats_with_broken_message",
"test_storage_kafka/test.py::test_kafka_insert",
"test_storage_kafka/test.py::test_kafka_issue11308",
"test_storage_kafka/test.py::test_kafka_issue14202",
"test_storage_kafka/test.py::test_kafka_issue4116",
"test_storage_kafka/test.py::test_kafka_json_as_string",
"test_storage_kafka/test.py::test_kafka_json_without_delimiter",
"test_storage_kafka/test.py::test_kafka_lot_of_partitions_partial_commit_of_bulk",
"test_storage_kafka/test.py::test_kafka_many_materialized_views",
"test_storage_kafka/test.py::test_kafka_materialized_view",
"test_storage_kafka/test.py::test_kafka_materialized_view_with_subquery",
"test_storage_kafka/test.py::test_kafka_no_holes_when_write_suffix_failed",
"test_storage_kafka/test.py::test_kafka_produce_consume",
"test_storage_kafka/test.py::test_kafka_produce_key_timestamp",
"test_storage_kafka/test.py::test_kafka_protobuf",
"test_storage_kafka/test.py::test_kafka_protobuf_no_delimiter",
"test_storage_kafka/test.py::test_kafka_rebalance",
"test_storage_kafka/test.py::test_kafka_select_empty",
"test_storage_kafka/test.py::test_kafka_settings_new_syntax",
"test_storage_kafka/test.py::test_kafka_settings_old_syntax",
"test_storage_kafka/test.py::test_kafka_string_field_on_first_position_in_protobuf",
"test_storage_kafka/test.py::test_kafka_tsv_with_delimiter",
"test_storage_kafka/test.py::test_kafka_unavailable",
"test_storage_kafka/test.py::test_kafka_virtual_columns",
"test_storage_kafka/test.py::test_kafka_virtual_columns2",
"test_storage_kafka/test.py::test_kafka_virtual_columns_with_materialized_view",
"test_storage_kafka/test.py::test_librdkafka_compression",
"test_storage_kafka/test.py::test_premature_flush_on_eof",
"test_storage_kerberized_hdfs/test.py::test_cache_path",
"test_storage_kerberized_hdfs/test.py::test_prohibited",
"test_storage_kerberized_hdfs/test.py::test_read_table",
@ -20,6 +221,8 @@
"test_storage_kerberized_hdfs/test.py::test_read_write_storage",
"test_storage_kerberized_hdfs/test.py::test_two_users",
"test_storage_kerberized_hdfs/test.py::test_write_storage_not_expired",
"test_storage_kerberized_kafka/test.py::test_kafka_json_as_string",
"test_storage_kerberized_kafka/test.py::test_kafka_json_as_string_no_kdc",
"test_storage_mongodb/test.py::test_complex_data_type",
"test_storage_mongodb/test.py::test_incorrect_data_type",
"test_storage_mongodb/test.py::test_simple_select",
@ -102,5 +305,7 @@
"test_storage_s3/test.py::test_storage_s3_put_gzip[gz]",
"test_storage_s3/test.py::test_storage_s3_put_uncompressed",
"test_storage_s3/test.py::test_wrong_s3_syntax[1_argument]",
"test_storage_s3/test.py::test_wrong_s3_syntax[6_arguments]"
]
"test_storage_s3/test.py::test_wrong_s3_syntax[6_arguments]",
"test_ttl_move/test.py::test_moves_work_after_storage_policy_change[mt_test_moves_work_after_storage_policy_change]",
"test_ttl_move/test.py::test_moves_work_after_storage_policy_change[replicated_mt_test_moves_work_after_storage_policy_change]"
]

View File

@ -0,0 +1,2 @@
dictionaries/*
!.gitignore

View File

@ -1,2 +0,0 @@
*
!.gitignore