ClickHouse/tests/integration
Robert Schulze 81bf43157f
Allow configuration of Kafka topics with periods
The Kafka table engine allows global configuration and per-Kafka-topic
configuration. The latter uses syntax <kafka_TOPIC>, e.g. for topic
"football":

  <kafka_football>
      <retry_backoff_ms>250</retry_backoff_ms>
      <fetch_min_bytes>100000</fetch_min_bytes>
  </kafka_football>

Some users had to find out the hard way that such configuration doesn't
take effect if the topic name contains a period, e.g. "sports.football".
The reason is that ClickHouse configuration framework already uses
periods as level separators to descend the configuration hierarchy.
(Besides that, per-topic configuration at the same level as global
configuration could be considered ugly.)

Note that Kafka topics may contain characters "a-zA-Z0-9._-" (*) and
a tree-like topic organization using periods is quite common in
practice.

This PR deprecates the existing per-topic configuration syntax (but
continues to support it for backward compat) and introduces a new
per-topic configuration syntax below the global Kafka configuration of
the form:

<kafka>
   <topic name="football">
       <retry_backoff_ms>250</retry_backoff_ms>
       <fetch_min_bytes>100000</fetch_min_bytes>
   </topic>
</kafka>

The period restriction doesn't apply to XML attributes, so <topic
name="sports.football"> will work. Also, everything Kafka-related is
below <kafka>.

Considered but rejected alternatives:
- Extending Poco ConfigurationView with custom separators (e.g."/"
  instead of "."). Won't work easily because ConfigurationView only
  builds a path but defers descending the configuration tree to the
  normal configuration classes.
- Reloading the configuration file in StorageKafka (instead of reading
  the loaded file) but with a custom separator. This mode is supported
  by XML configuration. Too ugly and error-prone since the true
  configuration is composed from multiple configuration files.

(*) https://stackoverflow.com/a/37067544
2023-02-22 20:35:09 +00:00
..
helpers Update postgres_utility.py 2023-02-21 16:25:11 +01:00
test_access_control_on_cluster Add forgitten config file 2023-02-06 11:35:30 +01:00
test_access_for_functions Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_aggregation_memory_efficient Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_allowed_client_hosts Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_allowed_url_from_config improvements 2022-07-07 20:21:10 +00:00
test_alter_codec Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_alter_on_mixed_type_cluster Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_alter_settings_on_cluster Update test.py 2022-12-01 19:41:29 +03:00
test_alter_update_cast_keep_nullable Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_always_fetch_merged Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_async_drain_connection Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_async_insert_memory Automatic style fix 2023-02-21 02:06:16 +00:00
test_asynchronous_metric_log_table Fix "black" 2022-04-28 05:30:14 +02:00
test_atomic_drop_table apply trash-formatter 2022-06-23 21:40:05 +02:00
test_attach_backup_from_s3_plain Simplify ATTACH MergeTree table FROM S3 in tests 2023-02-11 08:46:05 +01:00
test_attach_partition_with_large_destination apply trash-formatter 2022-06-23 21:40:05 +02:00
test_attach_without_checksums Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_attach_without_fetching Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_authentication Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_azure_blob_storage_zero_copy_replication Fix tests 2022-08-14 04:11:17 +02:00
test_backup_restore apply trash-formatter 2022-06-23 21:40:05 +02:00
test_backup_restore_new Fix test test_backup_restore_new/test.py::test_async_backups_to_same_destination[http]. 2023-02-15 17:27:05 +01:00
test_backup_restore_on_cluster Merge pull request #45800 from vitlibar/rename-new-columns-in-system-backups 2023-02-03 14:00:16 +01:00
test_backup_restore_s3 Use new copy s3 functions in S3ObjectStorage. 2023-01-21 15:47:58 +01:00
test_backup_with_other_granularity Automatic style fix 2023-02-21 16:08:13 +00:00
test_backward_compatibility add setting to disable vertical merges from compact parts 2023-02-10 16:33:46 +00:00
test_block_structure_mismatch Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_broken_detached_part_clean_up Automatic style fix 2023-02-16 13:37:40 +00:00
test_broken_part_during_merge Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_buffer_profile Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_catboost_evaluate chore: restore SYSTEM RELOAD MODEL(S) and moniting view SYSTEM.MODELS 2022-09-12 19:33:02 +00:00
test_cgroup_limit Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_check_table Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_checking_s3_blobs_paranoid Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_cleanup_after_start Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_cleanup_dir_after_bad_zk_conn Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_cluster_all_replicas Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_cluster_copier Increase table retries in cluster copier tests (#46590) 2023-02-22 15:09:48 +01:00
test_cluster_discovery Fix ClusterDiscovery 2022-08-12 13:26:17 +00:00
test_codec_encrypted Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_composable_protocols Automatic style fix 2022-12-20 17:46:17 +00:00
test_compressed_marks_restart Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_compression_codec_read Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_compression_nested_columns Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_concurrent_backups_s3 Increase timeout for test_concurrent_backups 2022-08-29 13:13:43 +02:00
test_concurrent_queries_for_all_users_restriction Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_concurrent_queries_for_user_restriction Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_concurrent_queries_restriction_by_query_kind Add a test 2023-02-02 04:40:45 +01:00
test_concurrent_threads_soft_limit Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_concurrent_ttl_merges Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_config_corresponding_root Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_config_substitutions Fix tests. 2022-07-15 15:44:29 +02:00
test_config_xml_full Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_config_xml_main Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_config_xml_yaml_mix Automatic style fix 2023-02-07 23:57:14 +00:00
test_config_yaml_full Merge branch 'master' into remove-useless-line 2022-09-10 05:07:10 +02:00
test_config_yaml_main Merge branch 'master' into remove-useless-line 2022-09-10 05:07:10 +02:00
test_consistant_parts_after_move_partition Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_consistent_parts_after_clone_replica fix test 2022-06-10 17:48:14 +02:00
test_create_query_constraints Merge remote-tracking branch 'origin/named-collections-fix-access' into named-collections-fix-access 2023-02-04 23:32:56 +01:00
test_create_user_and_login Automatic style fix 2023-01-11 10:09:43 +01:00
test_cross_replication deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_custom_settings Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_ddl_alter_query Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_ddl_worker_non_leader fix flaky test 2022-04-28 21:39:45 +02:00
test_default_compression_codec automatically convert system database to Atomic 2022-06-23 21:38:43 +02:00
test_default_database_on_cluster Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_default_role Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_delayed_replica_failover deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_detached_parts_metrics fix several critical races, fix tests 2022-11-23 15:16:08 +00:00
test_dictionaries_access Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_dictionaries_all_layouts_separate_sources disable flaky test with cassandra dictionaries 2023-02-16 15:11:34 +01:00
test_dictionaries_complex_key_cache_string Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_config_reload Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_dictionaries_ddl Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_dependency apply trash-formatter 2022-06-23 21:40:05 +02:00
test_dictionaries_dependency_xml Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_mysql Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_null_value Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_postgresql Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_redis Merge remote-tracking branch 'origin/master' into integration-tests-7 2022-07-25 09:17:55 +00:00
test_dictionaries_select_all Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_update_and_reload Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionaries_with_invalid_structure [rev 2] Fix review notes 2023-01-20 09:37:49 +03:00
test_dictionary_allow_read_expired_keys Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionary_custom_settings Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_dictionary_ddl_on_cluster Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_disabled_access_control_improvements Merge branch 'master' into readonly-settings-allow 2022-09-12 16:20:40 +02:00
test_disabled_mysql_server Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_disk_access_storage fix tests 2022-09-13 00:12:40 +02:00
test_disk_configuration Fix black check 2023-02-17 21:02:16 +01:00
test_disk_over_web_server Add a test for unavalable web server and web disk 2022-11-12 13:25:10 +01:00
test_disk_types Slightly better clickhouse disks and remove DiskMemory 2022-12-08 18:20:54 +01:00
test_disks_app_func Automatic style fix 2022-12-08 17:27:23 +00:00
test_distributed_backward_compatability Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_distributed_ddl Fix typos 2023-01-08 07:08:20 +01:00
test_distributed_ddl_on_cross_replication fix 2022-07-21 20:32:33 +02:00
test_distributed_ddl_parallel Update test.py 2023-02-09 20:37:47 +03:00
test_distributed_ddl_password Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_distributed_default_database Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_distributed_directory_monitor_split_batch_on_failure Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_distributed_format Black 2022-06-13 19:44:12 +00:00
test_distributed_insert_backward_compatibility Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_distributed_inter_server_secret Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_distributed_load_balancing Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_distributed_over_distributed Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_distributed_respect_user_timeouts fixes 2022-07-21 13:57:24 +02:00
test_distributed_storage_configuration apply trash-formatter 2022-06-23 21:40:05 +02:00
test_distributed_system_query Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_distributed_type_object Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_dns_cache Fix style 2023-02-11 01:45:28 +01:00
test_dotnet_client Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_drop_is_lock_free address the review comments 2022-11-23 15:16:08 +00:00
test_drop_no_local_path Add timeout 2023-01-30 17:02:58 +01:00
test_drop_replica tests/integration: remove superfluous import of PartitionManager 2022-05-13 10:57:24 +03:00
test_enabling_access_management Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_encrypted_disk Slightly better clickhouse disks and remove DiskMemory 2022-12-08 18:20:54 +01:00
test_endpoint_macro_substitution Updated to skip access check for hdfs , as done for other tests - Allow macro substitution in endpoint 2023-01-02 14:03:51 +01:00
test_executable_dictionary Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_executable_table_function add settings for executable table func 2022-07-30 20:02:56 +02:00
test_executable_user_defined_function Fixed style check 2022-06-03 18:06:59 +02:00
test_executable_user_defined_functions_config_reload Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_explain_estimates Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_extreme_deduplication deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_failed_async_inserts Update tests/integration/test_failed_async_inserts/test.py 2022-11-03 22:26:24 +01:00
test_fetch_memory_usage Disable test for sanitizers. 2022-08-09 12:25:58 +00:00
test_fetch_partition_from_auxiliary_zookeeper Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_fetch_partition_should_reset_mutation Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_fetch_partition_with_outdated_parts Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_file_schema_inference_cache Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_filesystem_layout apply trash-formatter 2022-06-23 21:40:05 +02:00
test_force_deduplication Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_force_drop_table apply trash-formatter 2022-06-23 21:40:05 +02:00
test_format_avro_confluent Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_format_schema_on_server Do not allow SETTINGS after FORMAT for INSERT queries 2022-04-07 16:29:36 +03:00
test_freeze_table Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_global_overcommit_tracker Add forgitten config file 2023-02-06 11:35:30 +01:00
test_globs_in_filepath Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_grant_and_revoke Merge pull request #46010 from kssenii/named-collections-fix-access 2023-02-07 23:20:22 +01:00
test_graphite_merge_tree Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_graphite_merge_tree_typed Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_groupBitmapAnd_on_distributed reformat py 2022-04-29 11:00:54 +08:00
test_grpc_protocol Fix test test_grpc_protocol/test.py::test_progress 2023-01-06 19:58:20 +01:00
test_grpc_protocol_ssl black 2023-01-02 12:43:16 +01:00
test_hedged_requests Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_hedged_requests_parallel Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_hive_query Update test.py 2022-11-23 14:10:49 +03:00
test_host_regexp_hosts_file_resolution Fix host_regexp hosts file tst 2022-08-29 15:58:18 -03:00
test_host_regexp_multiple_ptr_records Minor style fix in dns integ test 2022-07-21 08:29:40 -03:00
test_host_regexp_multiple_ptr_records_concurrent lower thread and iterations number 2022-10-20 13:30:20 -03:00
test_http_and_readonly Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_http_handlers_config Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_http_native Add raw content option to http helper methods 2023-02-15 07:17:28 -07:00
test_https_replication Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_inherit_multiple_profiles Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_input_format_parallel_parsing_memory_tracking Revert "Use separate counter for RSS in global memory tracker." 2022-08-14 09:50:12 +03:00
test_insert_distributed_async_extra_dirs Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_insert_distributed_async_send Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_insert_distributed_load_balancing Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_insert_into_distributed fix tests 2022-06-24 19:10:33 +02:00
test_insert_into_distributed_sync_async deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_insert_into_distributed_through_materialized_view fix tests 2022-06-24 19:10:33 +02:00
test_inserts_with_keeper_retries Revert "Revert " Keeper retries during insert (clean)"" 2022-11-10 13:14:04 +01:00
test_interserver_dns_retires CLICKHOUSE-2375 Add interserver DNS retries 2022-11-11 14:47:26 +00:00
test_jbod_balancer Less parallelism instead 2022-06-01 23:02:31 +08:00
test_jbod_ha tests: fix broken disk emulation in test_jbod_ha 2023-01-27 21:11:10 +01:00
test_jbod_load_balancing Implement lead_used load balancing algorithm for disks inside volume 2022-05-19 14:10:11 +03:00
test_jdbc_bridge Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_jemalloc_percpu_arena Debug integration tests 2022-04-18 00:16:53 +02:00
test_join_set_family_s3 Remove 'send_metadata' setting 2022-10-05 14:54:08 +02:00
test_keeper_and_access_storage Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_auth tests: more fixes for test_keeper_auth 2022-12-29 09:29:24 +01:00
test_keeper_back_to_back Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_force_recovery Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_force_recovery_single_node Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_four_word_command Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_incorrect_config Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_internal_secure Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_map Add EXISTS clauses 2023-01-12 15:39:04 +00:00
test_keeper_mntr_pressure Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_multinode_blocade_leader Automatic style fix 2023-02-20 23:49:25 +00:00
test_keeper_multinode_simple Done 2022-12-27 17:03:57 +00:00
test_keeper_nodes_add tests/integration: add missing kazoo client termination 2022-12-27 17:01:06 +01:00
test_keeper_nodes_move tests/integration: add missing kazoo client termination 2022-12-27 17:01:06 +01:00
test_keeper_nodes_remove tests/integration: add missing kazoo client termination 2022-12-27 17:01:06 +01:00
test_keeper_persistent_log Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_persistent_log_multinode Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_restore_from_snapshot Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_s3_snapshot Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_secure_client Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_session Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_snapshot_on_exit tests/integration: add missing kazoo client termination 2022-12-27 17:01:06 +01:00
test_keeper_snapshot_small_distance Retry on invalid snapshot 2023-01-07 17:08:25 +00:00
test_keeper_snapshots Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_snapshots_multinode Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_three_nodes_start tests/integration: add missing kazoo client termination 2022-12-27 17:01:06 +01:00
test_keeper_three_nodes_two_alive Don't allow third node to become leader 2023-01-12 08:44:55 +00:00
test_keeper_two_nodes_cluster Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_znode_time Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_zookeeper_converter Retry on invalid snapshot 2023-01-07 17:08:25 +00:00
test_kerberos_auth Update Exception messages in test.py 2022-12-26 13:17:22 +00:00
test_library_bridge Automatic style fix 2023-01-02 13:38:18 +00:00
test_limited_replicated_fetches Fixed the restriction on maximum size of replicated fetches (#42090) 2022-10-06 13:18:46 +02:00
test_log_family_hdfs tests: fix hdfs disks (chicken and an egg problem with current cluster.py) 2022-11-20 16:28:35 +01:00
test_log_family_s3 Remove 'send_metadata' setting 2022-10-05 14:54:08 +02:00
test_log_levels_update Automatic style fix 2022-08-25 11:00:01 +02:00
test_log_lz4_streaming docs for logger stream_compression 2023-02-10 09:02:54 -05:00
test_log_query_probability Auto set test's name in integration tests. 2022-07-18 15:03:57 +02:00
test_logs_level Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_lost_part Blakc 2023-01-04 20:30:52 +00:00
test_lost_part_during_startup Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_mask_sensitive_info Add missed test config. 2023-01-30 21:47:30 +01:00
test_match_process_uid_against_data_owner Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_materialized_mysql_database to 15357_MaterializeMySQL_support_drop_mulit_table-fix style-black 2022-11-21 11:48:57 +08:00
test_materialized_view_restart_server Fix test 2022-03-29 14:07:19 +02:00
test_max_http_connections_for_replication Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_max_suspicious_broken_parts Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_MemoryTracking Merge branch 'master' into mvcc_prototype 2022-03-23 11:28:43 +01:00
test_merge_table_over_distributed Fix integration test 2023-01-17 13:12:52 +00:00
test_merge_tree_azure_blob_storage Fix test_merge_tree_azure_blob_storage::test_zero_copy_replication test 2023-02-07 12:52:36 +01:00
test_merge_tree_empty_parts fix several critical races, fix tests 2022-11-23 15:16:08 +00:00
test_merge_tree_hdfs Automatic style fix 2022-12-25 08:38:02 +00:00
test_merge_tree_load_parts fix tests 2022-12-14 01:36:03 +00:00
test_merge_tree_s3 Move common code to helpers/mock_servers.py 2023-01-06 15:55:21 +01:00
test_merge_tree_s3_failover increase a time gap between insert and ttl move 2023-02-09 15:12:21 +01:00
test_merge_tree_s3_restore Remove disk restart proxy and disk decorator (#44647) 2022-12-30 14:47:30 +01:00
test_merge_tree_s3_with_cache Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_merge_tree_settings_constraints check one more case in test 2022-12-07 20:36:04 +00:00
test_multiple_disks Better fix 2023-01-13 12:12:27 +01:00
test_mutation_fetch_fallback Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_mutations_hardlinks Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_mutations_in_partitions_of_merge_tree better config in test 2022-12-21 11:35:11 +00:00
test_mutations_with_merge_tree Merge branch 'master' into remove-useless-line 2022-09-04 03:24:40 +02:00
test_mutations_with_projection Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_mysql_database_engine Fix flaky tests (#44690) 2022-12-29 14:32:10 +01:00
test_mysql_protocol Automatic style fix 2022-11-29 14:48:05 +00:00
test_named_collections Address review comments 2023-02-07 13:01:55 +01:00
test_non_default_compression Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_odbc_interaction fix test 2023-01-25 06:47:04 -08:00
test_old_parts_finally_removed Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_old_versions Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_on_cluster_timeouts Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_optimize_on_insert Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_overcommit_tracker Merge pull request #46010 from kssenii/named-collections-fix-access 2023-02-07 23:20:22 +01:00
test_part_log_table Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_part_moves_between_shards Automatic style fix 2022-07-30 21:49:36 +00:00
test_part_uuid Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_partition fix/adjust tests in integration/test_partition 2023-01-17 12:02:18 +01:00
test_parts_delete_zookeeper Update test.py 2022-06-09 17:53:52 +03:00
test_passing_max_partitions_to_read_remotely Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_password_constraints Better implementation of password rules 2022-12-11 23:59:04 +00:00
test_polymorphic_parts Disable compressed marks for some tests 2022-11-17 18:06:59 +01:00
test_postgresql_database_engine Fix tests 2022-12-22 12:27:42 +01:00
test_postgresql_protocol black 2023-01-03 21:28:54 +00:00
test_postgresql_replica_database_engine_1 Uodate test 2023-02-20 14:36:53 +01:00
test_postgresql_replica_database_engine_2 Fix remaining tests 2023-02-16 18:56:19 +01:00
test_profile_events_s3 Resubmit prefetches 2023-02-08 21:26:24 +01:00
test_profile_settings_and_constraints_order Lint 2022-12-20 04:00:45 +01:00
test_prometheus_endpoint Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_quorum_inserts Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_quorum_inserts_parallel Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_quota Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_random_inserts Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_range_hashed_dictionary_types Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_read_only_table Automatic style fix 2022-11-17 13:46:21 +00:00
test_read_temporary_tables_on_failure Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_recompression_ttl Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_recovery_replica Update tests/integration/test_recovery_replica/test.py 2022-09-28 12:33:38 -04:00
test_redirect_url_storage Merge branch 'master' into parallel-downloading-url-engine 2022-03-23 07:41:14 +00:00
test_relative_filepath Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_reload_auxiliary_zookeepers Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_reload_certificate Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_reload_clusters_config tests/integration: remove superfluous import of PartitionManager 2022-05-13 10:57:24 +03:00
test_reload_max_table_size_to_drop Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_reload_zookeeper Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_reloading_settings_from_users_xml Extend support for aliases to constraints and profiles 2023-01-27 09:39:10 +00:00
test_reloading_storage_configuration Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_remote_prewhere Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_rename_column Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replace_partition deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_replica_can_become_leader Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replica_is_active Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replicated_database Automatic style fix 2023-01-31 14:35:08 +00:00
test_replicated_fetches_bandwidth Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_replicated_fetches_timeouts Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replicated_merge_tree_compatibility assert unused value in test_replicated_merge_tree_compatibility 2022-10-12 18:12:25 +01:00
test_replicated_merge_tree_config Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_replicated_merge_tree_encrypted_disk Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replicated_merge_tree_encryption_codec Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replicated_merge_tree_hdfs_zero_copy tests: fix hdfs disks (chicken and an egg problem with current cluster.py) 2022-11-20 16:28:35 +01:00
test_replicated_merge_tree_s3 Revert "Merge pull request #41249 from ClickHouse/revert-40968-s3-sharding-2" 2022-09-16 14:06:26 +02:00
test_replicated_merge_tree_s3_restore Update test.py 2023-02-09 20:27:24 +03:00
test_replicated_merge_tree_s3_zero_copy Revert "Merge pull request #41249 from ClickHouse/revert-40968-s3-sharding-2" 2022-09-16 14:06:26 +02:00
test_replicated_merge_tree_with_auxiliary_zookeepers Use ZooKeeper in a single test 2022-10-17 07:36:49 +00:00
test_replicated_mutations Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replicated_parse_zk_metadata Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replicated_users Fix integration test test_replicated_users::test_rename_replicated (#45192) 2023-01-12 12:36:36 +01:00
test_replicating_constants Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_replication_credentials deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_replication_without_zookeeper Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_restart_server Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_restore_replica Revert "Revert " Keeper retries during insert (clean)"" 2022-11-10 13:14:04 +01:00
test_reverse_dns_query fix style 2023-02-02 13:42:17 -03:00
test_rocksdb_options move functional test to integration test 2022-09-02 18:45:37 +08:00
test_rocksdb_read_only fix test 2022-09-03 10:44:07 +08:00
test_role Allow a user to inspect grants from granted roles 2022-05-18 10:44:18 +00:00
test_row_policy Support subqueries in row policy filters. 2022-10-21 15:42:29 +02:00
test_s3_aws_sdk_has_slightly_unreliable_behaviour Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_s3_cluster Try fix flaky test test_parallel_distributed_insert_select_with_schema_inference 2023-02-16 16:28:47 +01:00
test_s3_imds Add test for IMDS session token. 2023-01-06 15:55:26 +01:00
test_s3_low_cardinality_right_border Automatic style fix 2023-01-03 18:29:09 +00:00
test_s3_storage_class fix 2023-01-05 09:09:42 +08:00
test_s3_table_functions Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_s3_with_https Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_s3_with_proxy Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_s3_zero_copy_replication Correct test version 2022-09-28 14:38:11 +02:00
test_s3_zero_copy_ttl Merge pull request #46275 from ClickHouse/less-mem-usage-for-vertical-merge 2023-02-13 21:10:43 +01:00
test_secure_socket Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_select_access_rights Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_send_crash_reports Merge pull request #41046 from azat/build/llvm-15 2022-09-16 07:31:06 +03:00
test_send_request_to_leader_replica deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_server_initialization fix tests 2022-06-24 19:10:33 +02:00
test_server_reload Better 2022-12-20 17:37:03 +01:00
test_server_start_and_ip_conversions Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_settings_constraints Extend support for aliases to constraints and profiles 2023-01-27 09:39:10 +00:00
test_settings_constraints_distributed Merge remote-tracking branch 'origin/named-collections-fix-access' into named-collections-fix-access 2023-02-04 23:32:56 +01:00
test_settings_profile Automatic style fix 2023-01-27 09:46:51 +00:00
test_shard_level_const_function Change <yandex> to <clickhouse> in configs 2021-09-20 01:38:53 +03:00
test_sharding_key_from_default_column Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_sql_user_defined_functions_on_cluster Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_ssl_cert_authentication Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_storage_delta Fix DESCRIBE for deltaLake and hudi table functions 2022-11-17 11:46:17 +00:00
test_storage_dict Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_storage_hdfs Update test.py 2022-11-17 06:41:43 +08:00
test_storage_hudi Automatic style fix 2022-11-17 11:54:13 +00:00
test_storage_iceberg fix test 2023-01-18 11:34:52 +00:00
test_storage_kafka Allow configuration of Kafka topics with periods 2023-02-22 20:35:09 +00:00
test_storage_kerberized_hdfs Fix HDFSCommon and test_storage_kerberized_hdfs to make running integration tests 2022-06-07 12:06:22 +03:00
test_storage_kerberized_kafka Allow configuration of Kafka topics with periods 2023-02-22 20:35:09 +00:00
test_storage_meilisearch Update test.py 2023-02-20 14:29:04 +01:00
test_storage_mongodb Update test.py 2022-07-13 22:59:14 +02:00
test_storage_mysql Merge branch 'master' into remove-useless-line 2022-09-04 03:24:40 +02:00
test_storage_nats Merge branch 'master' into improve-streaming-engines 2022-11-03 13:22:06 +01:00
test_storage_policies Automatic style fix 2022-11-17 14:46:25 +00:00
test_storage_postgresql Fix tests 2022-12-22 12:27:42 +01:00
test_storage_postgresql_replica temporarily disable all tests with materialized postgres 2022-07-25 17:32:51 +02:00
test_storage_rabbitmq Merge branch 'master' into update-rabbit-producer 2023-02-21 11:50:30 +01:00
test_storage_s3 Automatic style fix 2023-02-09 08:26:36 +00:00
test_storage_url Merge branch 'master' into remove-useless-line 2022-09-10 05:07:10 +02:00
test_structured_logging_json Merge branch 'master' into remove-useless-line 2022-09-04 03:24:40 +02:00
test_system_clusters_actual_information tests/integration: remove superfluous import of PartitionManager 2022-05-13 10:57:24 +03:00
test_system_ddl_worker_queue Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_system_flush_logs Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_system_logs_comment Fixed style check 2022-03-23 20:41:28 +01:00
test_system_logs_recreate Add <storage_policy> config parameter for system logs 2023-01-19 10:25:28 +01:00
test_system_merges Update test.py 2023-01-23 19:01:06 +03:00
test_system_metrics Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_system_queries Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_system_replicated_fetches Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_table_function_mongodb Fix style check and black check 2022-07-12 16:29:11 +02:00
test_table_functions_access_rights Add new table function viewIfPermitted(). 2022-07-15 15:44:29 +02:00
test_tcp_handler_http_responses Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_tcp_handler_interserver_listen_host Merge pull request #42991 from ClickHouse/tests-connection-error 2023-01-12 08:32:03 -05:00
test_temporary_data_in_cache Fixes 2022-12-22 10:22:57 +00:00
test_text_log_level Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_timezone_config Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_tlsv1_3 Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_tmp_policy Temporary files evict fs cache 2022-12-22 10:22:49 +00:00
test_transactions add query for waiting of loading parts and fix test_transactions 2022-12-12 14:33:42 +00:00
test_ttl_move Remove trash 2022-09-04 04:28:08 +02:00
test_ttl_replicated Fix flaky ttl test 2023-01-17 17:08:32 +01:00
test_union_header deprecate old MergeTree syntax 2022-06-23 11:24:54 +02:00
test_user_defined_object_persistence Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_user_directories Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_user_ip_restrictions Automatic style fix 2022-08-01 11:24:03 +00:00
test_user_zero_database_access Remove one line from XML, because we do not care 2022-08-28 02:44:02 +02:00
test_version_update Apply black formatter to all *.py files in the repo 2022-03-22 17:39:58 +01:00
test_version_update_after_mutation fix tests 2022-08-26 15:33:04 +02:00
test_zookeeper_config Auto set test's name in integration tests. 2022-07-18 15:03:57 +02:00
test_zookeeper_config_load_balancing apply formatter 2022-03-24 12:23:14 +01:00
.dockerignore Move all folders inside /dbms one level up (#9974) 2020-04-02 02:51:21 +03:00
.gitignore Move all folders inside /dbms one level up (#9974) 2020-04-02 02:51:21 +03:00
ci-runner.py Compress tar archives with zstd in intergration tests 2023-02-18 21:54:38 +01:00
CMakeLists.txt What happens if I remove 156 lines of code? 2023-01-03 18:51:16 +00:00
conftest.py tests/integration: disable logging.raiseExceptions 2022-12-26 22:57:54 +01:00
parallel_skip.json Make test_global_overcommit_tracker non-parallel 2022-11-15 20:52:18 +00:00
parallel.json rename MaterializeMySQL to MaterializedMySQL 2021-07-26 21:17:28 +03:00
parallel.readme rename MaterializeMySQL to MaterializedMySQL 2021-07-26 21:17:28 +03:00
pytest.ini improvements 2022-07-07 20:21:10 +00:00
README.md Typos 2022-08-04 19:27:38 +00:00
runner Parallel distributed insert select with s3Cluster [3] (#44955) 2023-01-09 13:30:32 +01:00

ClickHouse integration tests

This directory contains tests that involve several ClickHouse instances, custom configs, ZooKeeper, etc.

Running natively

Prerequisites:

  • Ubuntu 20.04 (Focal) or higher.
  • docker. Minimum required API version: 1.25, check with docker version.

You must install latest Docker from https://docs.docker.com/engine/installation/linux/docker-ce/ubuntu/#set-up-the-repository Don't use Docker from your system repository.

  • pip and libpq-dev. To install: sudo apt-get install python3-pip libpq-dev zlib1g-dev libcrypto++-dev libssl-dev libkrb5-dev python3-dev
  • py.test testing framework. To install: sudo -H pip install pytest
  • docker-compose and additional python libraries. To install:
sudo -H pip install \
    PyMySQL \
    aerospike \
    avro \
    cassandra-driver \
    confluent-kafka \
    dicttoxml \
    docker \
    docker-compose \
    grpcio \
    grpcio-tools \
    kafka-python \
    kazoo \
    minio \
    lz4 \
    protobuf \
    psycopg2-binary \
    pymongo \
    pytz \
    pytest \
    pytest-timeout \
    redis \
    tzlocal==2.1 \
    urllib3 \
    requests-kerberos \
    dict2xml \
    hypothesis \
    pyhdfs \
    pika \
    meilisearch \
    nats-py

(highly not recommended) If you really want to use OS packages on modern debian/ubuntu instead of "pip": sudo apt install -y docker docker-compose python3-pytest python3-dicttoxml python3-docker python3-pymysql python3-protobuf python3-pymongo python3-tzlocal python3-kazoo python3-psycopg2 kafka-python python3-pytest-timeout python3-minio

If you want to run the tests under a non-privileged user, you must add this user to docker group: sudo usermod -aG docker $USER and re-login. (You must close all your sessions (for example, restart your computer)) To check, that you have access to Docker, run docker ps.

Run the tests with the pytest command. To select which tests to run, use: pytest -k <test_name_pattern>

By default tests are run with system-wide client binary, server binary and base configs. To change that, set the following environment variables:

  • CLICKHOUSE_TESTS_SERVER_BIN_PATH to choose the server binary.
  • CLICKHOUSE_TESTS_CLIENT_BIN_PATH to choose the client binary.
  • CLICKHOUSE_TESTS_BASE_CONFIG_DIR to choose the directory from which base configs (config.xml andusers.xml) are taken.

Please note that if you use separate build (ENABLE_CLICKHOUSE_ALL=OFF), you need to build different components, including but not limited to ENABLE_CLICKHOUSE_LIBRARY_BRIDGE=ON ENABLE_CLICKHOUSE_ODBC_BRIDGE=ON ENABLE_CLICKHOUSE_KEEPER=ON. So it is easier to use ENABLE_CLICKHOUSE_ALL=ON

For tests that use common docker compose files you may need to set up their path with environment variable: DOCKER_COMPOSE_DIR=$HOME/ClickHouse/docker/test/integration/runner/compose

Running with runner script

The only requirement is fresh configured docker and docker pull clickhouse/integration-tests-runner

Notes:

  • If you want to run integration tests without sudo you have to add your user to docker group sudo usermod -aG docker $USER. More information about docker configuration.
  • If you already had run these tests without ./runner script you may have problems with pytest cache. It can be removed with rm -r __pycache__ .pytest_cache/.
  • Some tests maybe require a lot of resources (CPU, RAM, etc.). Better not try large tests like test_cluster_copier or test_distributed_ddl* on your laptop.

You can run tests via ./runner script and pass pytest arguments as last arg:

$ ./runner --binary $HOME/ClickHouse/programs/clickhouse  --odbc-bridge-binary $HOME/ClickHouse/programs/clickhouse-odbc-bridge --base-configs-dir $HOME/ClickHouse/programs/server/ 'test_ssl_cert_authentication -ss'
Start tests
====================================================================================================== test session starts ======================================================================================================
platform linux -- Python 3.8.10, pytest-7.1.2, pluggy-1.0.0 -- /usr/bin/python3
cachedir: .pytest_cache
rootdir: /ClickHouse/tests/integration, configfile: pytest.ini
plugins: repeat-0.9.1, xdist-2.5.0, forked-1.4.0, order-1.0.0, timeout-2.1.0
timeout: 900.0s
timeout method: signal
timeout func_only: False
collected 4 items                                                                                                                                                                                                               

test_ssl_cert_authentication/test.py::test_https Copy common default production configuration from /clickhouse-config. Files: config.xml, users.xml
PASSED
test_ssl_cert_authentication/test.py::test_https_wrong_cert PASSED
test_ssl_cert_authentication/test.py::test_https_non_ssl_auth PASSED
test_ssl_cert_authentication/test.py::test_create_user PASSED

================================================================================================= 4 passed in 118.58s (0:01:58) =================================================================================================

Path to binary and configs maybe specified via env variables:

$ export CLICKHOUSE_TESTS_BASE_CONFIG_DIR=$HOME/ClickHouse/programs/server/
$ export CLICKHOUSE_TESTS_SERVER_BIN_PATH=$HOME/ClickHouse/programs/clickhouse
$ export CLICKHOUSE_TESTS_ODBC_BRIDGE_BIN_PATH=$HOME/ClickHouse/programs/clickhouse-odbc-bridge
$ ./runner 'test_odbc_interaction'
$ # or ./runner '-v -ss'
Start tests
============================= test session starts ==============================
platform linux2 -- Python 2.7.15rc1, pytest-4.0.0, py-1.7.0, pluggy-0.8.0
rootdir: /ClickHouse/tests/integration, inifile: pytest.ini
collected 6 items

test_odbc_interaction/test.py ......                                     [100%]
==================== 6 passed, 1 warnings in 96.33 seconds =====================

You can just open shell inside a container by overwritting the command: ./runner --command=bash

Rebuilding the docker containers

The main container used for integration tests lives in docker/test/integration/base/Dockerfile. Rebuild it with

cd docker/test/integration/base
docker build -t clickhouse/integration-test .

The helper container used by the runner script is in docker/test/integration/runner/Dockerfile.

Adding new tests

To add new test named foo, create a directory test_foo with an empty __init__.py and a file named test.py containing tests in it. All functions with names starting with test will become test cases.

helpers directory contains utilities for:

  • Launching a ClickHouse cluster with or without ZooKeeper in docker containers.
  • Sending queries to launched instances.
  • Introducing network failures such as severing network link between two instances.

To assert that two TSV files must be equal, wrap them in the TSV class and use the regular assert statement. Example: assert TSV(result) == TSV(reference). In case the assertion fails, pytest will automagically detect the types of variables and only the small diff of two files is printed.

Troubleshooting

If tests failing for mysterious reasons, this may help:

sudo service docker stop
sudo bash -c 'rm -rf /var/lib/docker/*'
sudo service docker start

iptables-nft

On Ubuntu 20.10 and later in host network mode (default) one may encounter problem with nested containers not seeing each other. It happens because legacy and nftables rules are out of sync. Problem can be solved by:

sudo iptables -P FORWARD ACCEPT