ClickHouse/tests/queries/skip_list.json
Azat Khuzhin 808d1a0215 Reimplement preallocate for hashed/sparse_hashed dictionaries
It was initially implemented in #15454, but was reverted in #21948 (due
to higher memory usage).

This implementation differs from the initial, since now there is
separate attribute to enable preallocation, before it was done
automatically, but this has problems with duplicates in the source.

Plus this implementation does not uses dynamic_cast, instead it extends
IDictionarySource interface.
2021-05-10 07:41:48 +03:00

720 lines
31 KiB
JSON

/** List of tests which should be skipped depending on clickhouse build options.
* This file in json format, but javascript-style comments are allowed.
*/
{
"thread-sanitizer": [
"00877",
"query_profiler",
"memory_profiler",
"01103_check_cpu_instructions_at_startup",
"00152_insert_different_granularity",
"00151_replace_partition_with_different_granularity",
"00157_cache_dictionary",
"01193_metadata_loading",
"01473_event_time_microseconds",
"01526_max_untracked_memory", /// requires TraceCollector, does not available under sanitizers
"01474_executable_dictionary", /// informational stderr from sanitizer at start
"functions_bad_arguments", /// Too long for TSan
"01603_read_with_backoff_bug", /// Too long for TSan
"01646_system_restart_replicas_smoke", /// RESTART REPLICAS can acquire too much locks, while only 64 is possible from one thread under TSan
"01641_memory_tracking_insert_optimize", /// INSERT lots of rows is too heavy for TSan
"01017_uniqCombined_memory_usage" /// Fine thresholds on memory usage
],
"address-sanitizer": [
"00877",
"query_profiler",
"memory_profiler",
"odbc_roundtrip",
"01103_check_cpu_instructions_at_startup",
"01473_event_time_microseconds",
"01526_max_untracked_memory", /// requires TraceCollector, does not available under sanitizers
"01193_metadata_loading",
"01017_uniqCombined_memory_usage" /// Fine thresholds on memory usage
],
"ub-sanitizer": [
"capnproto",
"query_profiler",
"memory_profiler",
"01103_check_cpu_instructions_at_startup",
"00900_orc_load",
"01473_event_time_microseconds",
"01526_max_untracked_memory", /// requires TraceCollector, does not available under sanitizers
"01193_metadata_loading"
],
"memory-sanitizer": [
"capnproto",
"query_profiler",
"memory_profiler",
"01175_distributed_ddl_output_mode_long", /// issue 21600
"01103_check_cpu_instructions_at_startup",
"01086_odbc_roundtrip", /// can't pass because odbc libraries are not instrumented
"00877_memory_limit_for_new_delete", /// memory limits don't work correctly under msan because it replaces malloc/free
"01473_event_time_microseconds",
"01526_max_untracked_memory", /// requires TraceCollector, does not available under sanitizers
"01193_metadata_loading",
"01017_uniqCombined_memory_usage" /// Fine thresholds on memory usage
],
"debug-build": [
"query_profiler",
"memory_profiler",
"00899_long_attach",
"00980_alter_settings_race",
"00834_kill_mutation_replicated_zookeeper",
"00834_kill_mutation",
"01200_mutations_memory_consumption",
"01103_check_cpu_instructions_at_startup",
"01037_polygon_dicts_",
"hyperscan",
"01193_metadata_loading",
"01473_event_time_microseconds",
"01396_inactive_replica_cleanup_nodes",
"01641_memory_tracking_insert_optimize" /// INSERT lots of rows is too heavy in debug build
],
"unbundled-build": [
"00429",
"00877",
"pocopatch",
"parquet",
"xxhash",
"_h3",
"query_profiler",
"memory_profiler",
"orc_load",
"01033_storage_odbc_parsing_exception_check",
"avro",
"01072_optimize_skip_unused_shards_const_expr_eval",
"00505_secure",
"00505_shard_secure",
"odbc_roundtrip",
"01103_check_cpu_instructions_at_startup",
"01114_mysql_database_engine_segfault",
"00834_cancel_http_readonly_queries_on_client_close",
"_arrow",
"01099_parallel_distributed_insert_select",
"01300_client_save_history_when_terminated",
"orc_output",
"01370_client_autocomplete_word_break_characters",
"01676_clickhouse_client_autocomplete",
"01193_metadata_loading",
"01455_time_zones",
"01755_client_highlight_multi_line_comment_regression"
],
"release-build": [
],
"database-ordinary": [
"00604_show_create_database",
"00609_mv_index_in_in",
"00510_materizlized_view_and_deduplication_zookeeper",
"00738_lock_for_inner_table",
"01153_attach_mv_uuid"
],
"database-replicated": [
"memory_tracking",
"memory_usage",
"live_view",
"01181_db_atomic_drop_on_cluster",
"01175_distributed_ddl_output_mode",
"01415_sticking_mutations",
"00980_zookeeper_merge_tree_alter_settings",
"01148_zookeeper_path_macros_unfolding",
"01294_system_distributed_on_cluster",
"01269_create_with_null",
"01451_replicated_detach_drop_and_quorum",
"01188_attach_table_from_path",
"01149_zookeeper_mutation_stuck_after_replace_partition",
/// user_files
"01721_engine_file_truncate_on_insert",
/// Fails due to additional replicas or shards
"quorum",
"01650_drop_part_and_deduplication_zookeeper",
"01532_execute_merges_on_single_replica",
"00652_replicated_mutations_default_database_zookeeper",
"00620_optimize_on_nonleader_replica_zookeeper",
/// grep -c
"01018_ddl_dictionaries_bad_queries",
"00908_bloom_filter_index",
/// Unsupported type of ALTER query
"01650_fetch_patition_with_macro_in_zk_path",
"01451_detach_drop_part",
"01451_replicated_detach_drop_part",
"01417_freeze_partition_verbose",
"01417_freeze_partition_verbose_zookeeper",
"01130_in_memory_parts_partitons",
"01060_shutdown_table_after_detach",
"01021_only_tuple_columns",
"01015_attach_part",
"00955_test_final_mark",
"00753_alter_attach",
"00626_replace_partition_from_table_zookeeper",
"00626_replace_partition_from_table",
"00152_insert_different_granularity",
"00054_merge_tree_partitions",
"01781_merge_tree_deduplication",
/// Old syntax is not allowed
"01062_alter_on_mutataion_zookeeper",
"00925_zookeeper_empty_replicated_merge_tree_optimize_final",
"00754_alter_modify_order_by_replicated_zookeeper",
"00652_replicated_mutations_zookeeper",
"00623_replicated_truncate_table_zookeeper",
"00516_deduplication_after_drop_partition_zookeeper",
"00446_clear_column_in_partition_concurrent_zookeeper",
"00236_replicated_drop_on_non_leader_zookeeper",
"00226_zookeeper_deduplication_and_unexpected_parts",
"00215_primary_key_order_zookeeper",
"00121_drop_column_zookeeper",
"00083_create_merge_tree_zookeeper",
"00062_replicated_merge_tree_alter_zookeeper",
/// Does not support renaming of multiple tables in single query
"00634_rename_view",
"00140_rename",
"01783_http_chunk_size"
],
"polymorphic-parts": [
"01508_partition_pruning_long", /// bug, shoud be fixed
"01482_move_to_prewhere_and_cast" /// bug, shoud be fixed
],
"antlr": [
"00186_very_long_arrays",
"00233_position_function_sql_comparibilty",
"00417_kill_query",
"00534_functions_bad_arguments12",
"00534_functions_bad_arguments2",
"00534_functions_bad_arguments4",
"00534_functions_bad_arguments9",
"00564_temporary_table_management",
"00600_replace_running_query",
"00626_replace_partition_from_table_zookeeper",
"00652_replicated_mutations_zookeeper",
"00687_top_and_offset",
"00746_sql_fuzzy",
"00763_create_query_as_table_engine_bug",
"00765_sql_compatibility_aliases",
"00825_protobuf_format_array_3dim",
"00825_protobuf_format_array_of_arrays",
"00825_protobuf_format_enum_mapping",
"00825_protobuf_format_map",
"00825_protobuf_format_nested_in_nested",
"00825_protobuf_format_nested_optional",
"00825_protobuf_format_no_length_delimiter",
"00825_protobuf_format_persons",
"00825_protobuf_format_squares",
"00825_protobuf_format_table_default",
"00826_cross_to_inner_join",
"00834_not_between",
"00909_kill_not_initialized_query",
"00938_template_input_format",
"00939_limit_by_offset",
"00943_materialize_index",
"00944_clear_index_in_partition",
"00952_input_function",
"00953_constraints_operations",
"00954_client_prepared_statements",
"00956_sensitive_data_masking",
"00969_columns_clause",
"00975_indices_mutation_replicated_zookeeper_long",
"00975_values_list",
"00976_system_stop_ttl_merges",
"00977_int_div",
"00978_table_function_values_alias",
"00980_merge_alter_settings",
"00980_zookeeper_merge_tree_alter_settings",
"00982_array_enumerate_uniq_ranked",
"00984_materialized_view_to_columns",
"00988_constraints_replication_zookeeper",
"00995_order_by_with_fill",
"01001_enums_in_in_section",
"01011_group_uniq_array_memsan",
"01011_test_create_as_skip_indices",
"01014_format_custom_separated",
"01015_attach_part",
"01015_database_bad_tables",
"01017_uniqCombined_memory_usage",
"01018_ddl_dictionaries_concurrent_requrests", /// Cannot parse ATTACH DICTIONARY IF NOT EXISTS
"01019_alter_materialized_view_atomic",
"01019_alter_materialized_view_consistent",
"01019_alter_materialized_view_query",
"01021_tuple_parser",
"01025_array_compact_generic",
"01030_limit_by_with_ties_error",
"01033_quota_dcl",
"01034_with_fill_and_push_down_predicate",
"01035_avg_weighted_long",
"01039_row_policy_dcl",
"01039_test_setting_parse",
"01042_system_reload_dictionary_reloads_completely",
"01045_dictionaries_restrictions",
"01055_compact_parts_1",
"01056_create_table_as",
"01066_bit_count",
"01070_materialize_ttl",
"01070_mutations_with_dependencies",
"01073_grant_and_revoke",
"01073_show_tables_not_like",
"01074_partial_revokes",
"01075_allowed_client_hosts",
"01085_regexp_input_format",
"01086_regexp_input_format_skip_unmatched",
"01089_alter_settings_old_format",
"01095_tpch_like_smoke",
"01107_atomic_db_detach_attach",
"01109_exchange_tables",
"01109_sc0rp10_string_hash_map_zero_bytes",
"01110_dictionary_layout_without_arguments",
"01114_database_atomic",
"01114_materialize_clear_index_compact_parts",
"01115_join_with_dictionary",
"01117_comma_and_others_join_mix",
"01125_dict_ddl_cannot_add_column",
"01130_in_memory_parts",
"01144_multiple_joins_rewriter_v2_and_lambdas",
"01144_multiword_data_types",
"01145_with_fill_const",
"01149_zookeeper_mutation_stuck_after_replace_partition",
"01150_ddl_guard_rwr",
"01185_create_or_replace_table",
"01187_set_profile_as_setting",
"01188_attach_table_from_path",
"01190_full_attach_syntax",
"01191_rename_dictionary",
"01192_rename_database_zookeeper",
"01213_alter_rename_column",
"01232_untuple",
"01244_optimize_distributed_group_by_sharding_key",
"01254_dict_load_after_detach_attach",
"01256_misspell_layout_name_podshumok",
"01257_dictionary_mismatch_types",
"01267_alter_default_key_columns_zookeeper",
"01268_mv_scalars",
"01269_create_with_null",
"01271_show_privileges",
"01272_offset_without_limit",
"01277_alter_rename_column_constraint_zookeeper",
"01278_min_insert_block_size_rows_for_materialized_views",
"01280_min_map_max_map",
"01280_null_in",
"01280_ttl_where_group_by_negative",
"01280_ttl_where_group_by",
"01280_unicode_whitespaces_lexer",
"01292_create_user",
"01293_create_role",
"01293_pretty_max_value_width",
"01293_show_settings",
"01294_create_settings_profile",
"01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long",
"01295_create_row_policy",
"01296_create_row_policy_in_current_database",
"01297_create_quota",
"01308_row_policy_and_trivial_count_query",
"01317_no_password_in_command_line",
"01318_map_add_map_subtract",
"01322_any_input_optimize",
"01324_if_transform_strings_to_enum",
"01337_mysql_global_variables",
"01355_alter_column_with_order",
"01355_ilike",
"01373_is_zero_or_null",
"01374_if_nullable_filimonov",
"01378_alter_rename_with_ttl_zookeeper",
"01379_with_fill_several_columns",
"01397_in_bad_arguments",
"01412_mod_float",
"01415_table_function_view",
"01417_freeze_partition_verbose_zookeeper",
"01417_freeze_partition_verbose",
"01419_merge_tree_settings_sanity_check",
"01430_modify_sample_by_zookeeper",
"01447_json_strings",
"01449_json_compact_strings",
"01451_detach_drop_part",
"01451_replicated_detach_drop_and_quorum",
"01451_replicated_detach_drop_part",
"01457_create_as_table_function_structure",
"01460_allow_dollar_and_number_in_identifier",
"01463_test_alter_live_view_refresh",
"01465_ttl_recompression",
"01470_columns_transformers",
"01470_columns_transformers2",
"01470_explain",
"01470_show_databases_like",
"01470_test_insert_select_asterisk",
"01491_nested_multiline_comments",
"01493_table_function_null",
"01495_subqueries_in_with_statement_2",
"01495_subqueries_in_with_statement_3",
"01495_subqueries_in_with_statement",
"01501_clickhouse_client_INSERT_exception",
"01504_compression_multiple_streams",
"01508_explain_header",
"01508_partition_pruning_long",
"01509_check_parallel_quorum_inserts_long",
"01509_parallel_quorum_and_merge_long",
"01509_dictionary_preallocate",
"01515_mv_and_array_join_optimisation_bag",
"01516_create_table_primary_key",
"01517_drop_mv_with_inner_table",
"01523_client_local_queries_file_parameter",
"01523_interval_operator_support_string_literal",
"01525_select_with_offset_fetch_clause",
"01526_client_start_and_exit",
"01529_union_distinct_and_setting_union_default_mode",
"01530_drop_database_atomic_sync",
"01532_execute_merges_on_single_replica",
"01532_primary_key_without_order_by_zookeeper",
"01541_max_memory_usage_for_user_long",
"01551_mergetree_read_in_order_spread",
"01552_dict_fixedstring",
"01554_bloom_filter_index_big_integer_uuid",
"01556_explain_select_with_union_query",
"01561_aggregate_functions_of_key_with_join",
"01562_optimize_monotonous_functions_in_order_by",
"01581_deduplicate_by_columns_local",
"01581_deduplicate_by_columns_replicated",
"01582_distinct_optimization",
"01590_countSubstrings",
"01593_insert_settings",
"01594_too_low_memory_limits",
"01596_setting_limit_offset",
"01600_log_queries_with_extensive_info",
"01600_quota_by_forwarded_ip",
"01601_detach_permanently",
"01602_show_create_view",
"01603_read_with_backoff_bug",
"01604_explain_ast_of_nonselect_query",
"01605_drop_settings_profile_while_assigned",
"01605_skip_idx_compact_parts",
"01606_git_import",
"01606_merge_from_wide_to_compact",
"01614_with_fill_with_limit",
"01632_max_partitions_to_read",
"01638_div_mod_ambiguities",
"01642_if_nullable_regression",
"01643_system_suspend",
"01655_plan_optimizations",
"01475_read_subcolumns_storages",
"01674_clickhouse_client_query_param_cte",
"01666_merge_tree_max_query_limit",
"01786_explain_merge_tree",
"01666_merge_tree_max_query_limit",
"01802_test_postgresql_protocol_with_row_policy", /// It cannot parse DROP ROW POLICY
"01823_explain_json",
"01852_cast_operator",
"01852_cast_operator_bad_cases"
],
"parallel":
[
/// Pessimistic list of tests which work badly in parallel.
/// Probably they need better investigation.
"00062_replicated_merge_tree_alter_zookeeper",
"00080_show_tables_and_system_tables",
"00101_materialized_views_and_insert_without_explicit_database",
"00109_shard_totals_after_having",
"00110_external_sort",
"00116_storage_set",
"00121_drop_column_zookeeper",
"00133_long_shard_memory_tracker_and_exception_safety",
"00158_buffer_and_nonexistent_table",
"00180_attach_materialized_view",
"00226_zookeeper_deduplication_and_unexpected_parts",
"00236_replicated_drop_on_non_leader_zookeeper",
"00305_http_and_readonly",
"00311_array_primary_key",
"00417_kill_query",
"00423_storage_log_single_thread",
"00429_long_http_bufferization",
"00446_clear_column_in_partition_concurrent_zookeeper",
"00446_clear_column_in_partition_zookeeper",
"00463_long_sessions_in_http_interface",
"00505_shard_secure",
"00508_materialized_view_to",
"00516_deduplication_after_drop_partition_zookeeper",
"00534_functions_bad_arguments10",
"00552_or_nullable",
"00564_versioned_collapsing_merge_tree",
"00571_non_exist_database_when_create_materializ_view",
"00575_illegal_column_exception_when_drop_depen_column",
"00599_create_view_with_subquery",
"00600_replace_running_query",
"00604_show_create_database",
"00612_http_max_query_size",
"00619_union_highlite",
"00620_optimize_on_nonleader_replica_zookeeper",
"00623_truncate_table",
"00623_truncate_table_throw_exception",
"00625_arrays_in_nested",
"00626_replace_partition_from_table",
"00626_replace_partition_from_table_zookeeper",
"00633_materialized_view_and_too_many_parts_zookeeper",
"00643_cast_zookeeper",
"00652_mergetree_mutations",
"00652_replicated_mutations_zookeeper",
"00682_empty_parts_merge",
"00688_low_cardinality_serialization",
"00693_max_block_size_system_tables_columns",
"00699_materialized_view_mutations",
"00701_rollup",
"00715_fetch_merged_or_mutated_part_zookeeper",
"00716_allow_ddl",
"00719_parallel_ddl_db",
"00740_database_in_nested_view",
"00741_client_comment_multiline",
"00751_default_databasename_for_view",
"00753_alter_attach",
"00754_alter_modify_column_partitions",
"00754_alter_modify_order_by_replicated_zookeeper",
"00763_long_lock_buffer_alter_destination_table",
"00800_versatile_storage_join",
"00804_test_alter_compression_codecs",
"00804_test_custom_compression_codecs",
"00804_test_custom_compression_codes_log_storages",
"00804_test_delta_codec_compression",
"00815_left_join_on_stepanel",
"00834_cancel_http_readonly_queries_on_client_close",
"00834_kill_mutation",
"00834_kill_mutation_replicated_zookeeper",
"00840_long_concurrent_select_and_drop_deadlock",
"00857_global_joinsavel_table_alias",
"00899_long_attach_memory_limit",
"00910_buffer_prewhere",
"00910_zookeeper_custom_compression_codecs_replicated",
"00926_adaptive_index_granularity_merge_tree",
"00926_adaptive_index_granularity_pk",
"00926_adaptive_index_granularity_replacing_merge_tree",
"00926_zookeeper_adaptive_index_granularity_replicated_merge_tree",
"00933_alter_ttl",
"00933_reserved_word",
"00933_test_fix_extra_seek_on_compressed_cache",
"00933_ttl_replicated_zookeeper",
"00933_ttl_with_default",
"00950_dict_get",
"00955_test_final_mark",
"00976_ttl_with_old_parts",
"00980_merge_alter_settings",
"00980_zookeeper_merge_tree_alter_settings",
"00988_constraints_replication_zookeeper",
"00989_parallel_parts_loading",
"00992_system_parts_race_condition_zookeeper_long",
"00993_system_parts_race_condition_drop_zookeeper",
"01012_show_tables_limit",
"01013_sync_replica_timeout_zookeeper",
"01014_lazy_database_basic",
"01014_lazy_database_concurrent_recreate_reattach_and_show_tables",
"01015_attach_part",
"01015_database_bad_tables",
"01018_ddl_dictionaries_concurrent_requrests",
"01018_ddl_dictionaries_create",
"01018_ddl_dictionaries_select",
"01018_ddl_dictionaries_special",
"01018_dictionaries_from_dictionaries",
"01018_ip_dictionary_long",
"01021_only_tuple_columns",
"01023_materialized_view_query_context",
"01031_mutations_interpreter_and_context",
"01033_dictionaries_lifetime",
"01035_concurrent_move_partition_from_table_zookeeper",
"01036_no_superfluous_dict_reload_on_create_database",
"01036_no_superfluous_dict_reload_on_create_database_2",
"01037_polygon_dicts_correctness_all",
"01037_polygon_dicts_correctness_fast",
"01037_polygon_dicts_simple_functions",
"01038_dictionary_lifetime_min_zero_sec",
"01040_dictionary_invalidate_query_switchover_long",
"01041_create_dictionary_if_not_exists",
"01042_system_reload_dictionary_reloads_completely",
"01043_dictionary_attribute_properties_values",
"01045_dictionaries_restrictions",
"01045_zookeeper_system_mutations_with_parts_names",
"01048_exists_query",
"01053_drop_database_mat_view",
"01053_ssd_dictionary",
"01054_cache_dictionary_bunch_update",
"01054_cache_dictionary_overflow_cell",
"01055_compact_parts_1",
"01056_create_table_as",
"01060_avro",
"01060_shutdown_table_after_detach",
"01069_database_memory",
"01070_materialize_ttl",
"01070_modify_ttl",
"01070_mutations_with_dependencies",
"01071_live_view_detach_dependency",
"01071_prohibition_secondary_index_with_old_format_merge_tree",
"01073_attach_if_not_exists",
"01073_show_tables_not_like",
"01076_cache_dictionary_datarace_exception_ptr",
"01076_parallel_alter_replicated_zookeeper",
"01079_parallel_alter_add_drop_column_zookeeper",
"01079_parallel_alter_detach_table_zookeeper",
"01080_check_for_error_incorrect_size_of_nested_column",
"01083_expressions_in_engine_arguments",
"01084_regexp_empty",
"01085_max_distributed_connections_http",
"01092_memory_profiler",
"01098_temporary_and_external_tables",
"01103_distributed_product_mode_local_column_renames",
"01107_atomic_db_detach_attach",
"01108_restart_replicas_rename_deadlock_zookeeper",
"01109_exchange_tables",
"01110_dictionary_layout_without_arguments",
"01113_local_dictionary_type_conversion",
"01114_database_atomic",
"01114_mysql_database_engine_segfault",
"01115_join_with_dictionary",
"01125_dict_ddl_cannot_add_column",
"01127_month_partitioning_consistency_select",
"01130_in_memory_parts_partitons",
"01135_default_and_alter_zookeeper",
"01148_zookeeper_path_macros_unfolding",
"01150_ddl_guard_rwr",
"01153_attach_mv_uuid",
"01152_cross_replication",
"01185_create_or_replace_table",
"01190_full_attach_syntax",
"01191_rename_dictionary",
"01192_rename_database_zookeeper",
"01193_metadata_loading",
"01200_mutations_memory_consumption",
"01224_no_superfluous_dict_reload",
"01225_drop_dictionary_as_table",
"01225_show_create_table_from_dictionary",
"01231_distributed_aggregation_memory_efficient_mix_levels",
"01232_extremes",
"01238_http_memory_tracking",
"01249_bad_arguments_for_bloom_filter",
"01251_dict_is_in_infinite_loop",
"01254_dict_create_without_db",
"01254_dict_load_after_detach_attach",
"01257_dictionary_mismatch_types",
"01259_dictionary_custom_settings_ddl",
"01267_alter_default_key_columns_zookeeper",
"01268_dictionary_direct_layout",
"01269_alias_type_differs",
"01272_suspicious_codecs",
"01277_alter_rename_column_constraint_zookeeper",
"01280_ssd_complex_key_dictionary",
"01280_ttl_where_group_by",
"01281_group_by_limit_memory_tracking",
"01281_unsucceeded_insert_select_queries_counter",
"01293_system_distribution_queue",
"01294_lazy_database_concurrent",
"01294_lazy_database_concurrent_recreate_reattach_and_show_tables_long",
"01294_system_distributed_on_cluster",
"01296_create_row_policy_in_current_database",
"01297_create_quota",
"01305_replica_create_drop_zookeeper",
"01307_multiple_leaders_zookeeper",
"01318_long_unsuccessful_mutation_zookeeper",
"01319_manual_write_to_replicas",
"01320_create_sync_race_condition_zookeeper",
"01338_long_select_and_alter",
"01338_long_select_and_alter_zookeeper",
"01355_alter_column_with_order",
"01355_ilike",
"01357_version_collapsing_attach_detach_zookeeper",
"01375_compact_parts_codecs",
"01376_GROUP_BY_injective_elimination_dictGet",
"01378_alter_rename_with_ttl_zookeeper",
"01383_remote_ambiguous_column_shard",
"01388_clear_all_columns",
"01391_join_on_dict_crash",
"01392_column_resolve",
"01396_inactive_replica_cleanup_nodes_zookeeper",
"01412_cache_dictionary_race",
"01414_mutations_and_errors_zookeeper",
"01415_inconsistent_merge_tree_settings",
"01415_sticking_mutations",
"01417_freeze_partition_verbose",
"01417_freeze_partition_verbose_zookeeper",
"01430_modify_sample_by_zookeeper",
"01444_create_table_drop_database_race",
"01454_storagememory_data_race_challenge",
"01455_rank_correlation_spearman",
"01456_modify_column_type_via_add_drop_update",
"01457_create_as_table_function_structure",
"01459_manual_write_to_replicas",
"01460_DistributedFilesToInsert",
"01465_ttl_recompression",
"01470_show_databases_like",
"01471_calculate_ttl_during_merge",
"01487_distributed_in_not_default_db",
"01493_alter_remove_properties_zookeeper",
"01493_storage_set_persistency",
"01494_storage_join_persistency",
"01501_cache_dictionary_all_fields",
"01507_clickhouse_server_start_with_embedded_config",
"01509_dictionary_preallocate",
"01516_create_table_primary_key",
"01516_drop_table_stress",
"01517_drop_mv_with_inner_table",
"01526_complex_key_dict_direct_layout",
"01527_clickhouse_local_optimize",
"01527_dist_sharding_key_dictGet_reload",
"01530_drop_database_atomic_sync",
"01541_max_memory_usage_for_user_long",
"01542_dictionary_load_exception_race",
"01545_system_errors", // looks at the difference of values in system.errors
"01560_optimize_on_insert_zookeeper",
"01563_distributed_query_finish", // looks at system.errors which is global
"01575_disable_detach_table_of_dictionary",
"01593_concurrent_alter_mutations_kill",
"01593_concurrent_alter_mutations_kill_many_replicas",
"01600_count_of_parts_metrics", // tests global system metrics
"01600_detach_permanently",
"01600_log_queries_with_extensive_info",
"01600_multiple_left_join_with_aliases",
"01601_detach_permanently",
"01602_show_create_view",
"01603_rename_overwrite_bug",
"01666_blns",
"01646_system_restart_replicas_smoke", // system restart replicas is a global query
"01656_test_query_log_factories_info",
"01658_read_file_to_stringcolumn",
"01669_columns_declaration_serde",
"01676_dictget_in_default_expression",
"01681_cache_dictionary_simple_key",
"01682_cache_dictionary_complex_key",
"01683_flat_dictionary",
"01684_ssd_cache_dictionary_simple_key",
"01685_ssd_cache_dictionary_complex_key",
"01700_system_zookeeper_path_in",
"01702_system_query_log", // It's ok to execute in parallel with oter tests but not several instances of the same test.
"01702_system_query_log", // Runs many global system queries
"01715_background_checker_blather_zookeeper",
"01721_engine_file_truncate_on_insert", // It's ok to execute in parallel but not several instances of the same test.
"01722_long_brotli_http_compression_json_format", // It is broken in some unimaginable way with the genius error 'cannot write to ofstream'. Not sure how to debug this
"01747_alter_partition_key_enum_zookeeper",
"01748_dictionary_table_dot", // creates database
"01760_polygon_dictionaries",
"01760_system_dictionaries",
"01761_alter_decimal_zookeeper",
"01360_materialized_view_with_join_on_query_log", // creates and drops MVs on query_log, which may interrupt flushes.
"01509_parallel_quorum_insert_no_replicas", // It's ok to execute in parallel with oter tests but not several instances of the same test.
"attach",
"ddl_dictionaries",
"dictionary",
"limit_memory",
"live_view",
"memory_leak",
"memory_limit",
"polygon_dicts", // they use an explicitly specified database
"01658_read_file_to_stringcolumn",
"01721_engine_file_truncate_on_insert", // It's ok to execute in parallel but not several instances of the same test.
"01702_system_query_log", // It's ok to execute in parallel with oter tests but not several instances of the same test.
"01748_dictionary_table_dot", // creates database
"00950_dict_get",
"01683_flat_dictionary",
"01681_cache_dictionary_simple_key",
"01682_cache_dictionary_complex_key",
"01684_ssd_cache_dictionary_simple_key",
"01685_ssd_cache_dictionary_complex_key",
"01737_clickhouse_server_wait_server_pool_long", // This test is fully compatible to run in parallel, however under ASAN processes are pretty heavy and may fail under flaky adress check.
"01760_system_dictionaries",
"01760_polygon_dictionaries",
"01778_hierarchical_dictionaries",
"01780_clickhouse_dictionary_source_loop",
"01785_dictionary_element_count",
"01802_test_postgresql_protocol_with_row_policy", /// Creates database and users
"01804_dictionary_decimal256_type",
"01850_dist_INSERT_preserve_error" // uses cluster with different static databases shard_0/shard_1
]
}