ClickHouse/tests/integration
Alexey Milovidov 851e4ae59f Fix typos
2023-01-08 07:08:20 +01:00
..
helpers Fix typos 2023-01-08 07:08:20 +01:00
test_access_control_on_cluster
test_access_for_functions
test_aggregation_memory_efficient
test_allowed_client_hosts
test_allowed_url_from_config
test_alter_codec
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
test_always_fetch_merged
test_async_drain_connection
test_asynchronous_metric_log_table
test_atomic_drop_table
test_attach_backup_from_s3_plain Add ability to disable deduplication for BACKUP 2022-12-27 15:56:06 +01:00
test_attach_partition_with_large_destination
test_attach_without_checksums
test_attach_without_fetching
test_authentication
test_azure_blob_storage_zero_copy_replication
test_backup_restore
test_backup_restore_new Fix referential dependencies when host & post in a clickHouse dictionary source are set by default. 2022-12-12 18:22:14 +01:00
test_backup_restore_on_cluster Increase the create table timeout in test "test_backup_restore_on_cluster". 2022-12-28 00:17:19 +01:00
test_backup_restore_s3 changed type name for S3_Plain storage 2022-11-04 17:35:51 +01:00
test_backup_with_other_granularity
test_backward_compatibility binary backward compatibility test is added 2022-12-22 07:38:49 +00:00
test_block_structure_mismatch
test_broken_detached_part_clean_up fix flaky test 2022-11-28 18:31:22 +01:00
test_broken_part_during_merge Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_buffer_profile
test_catboost_evaluate
test_cgroup_limit
test_check_table
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
test_cluster_all_replicas
test_cluster_copier
test_cluster_discovery
test_codec_encrypted
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
test_concurrent_backups_s3
test_concurrent_queries_for_all_users_restriction
test_concurrent_queries_for_user_restriction
test_concurrent_queries_restriction_by_query_kind Make test_concurrent_queries_restriction_by_query_kind less flaky 2023-01-04 14:18:35 +00:00
test_concurrent_threads_soft_limit
test_concurrent_ttl_merges
test_config_corresponding_root
test_config_substitutions
test_config_xml_full
test_config_xml_main
test_config_xml_yaml_mix
test_config_yaml_full
test_config_yaml_main
test_consistant_parts_after_move_partition
test_consistent_parts_after_clone_replica
test_create_query_constraints Fix style 2022-12-13 09:41:31 +00:00
test_create_user_and_login
test_cross_replication
test_custom_settings
test_ddl_alter_query
test_ddl_worker_non_leader
test_default_compression_codec
test_default_database_on_cluster
test_default_role
test_delayed_replica_failover
test_detached_parts_metrics fix several critical races, fix tests 2022-11-23 15:16:08 +00:00
test_dictionaries_access
test_dictionaries_all_layouts_separate_sources
test_dictionaries_complex_key_cache_string
test_dictionaries_config_reload
test_dictionaries_ddl
test_dictionaries_dependency
test_dictionaries_dependency_xml
test_dictionaries_mysql
test_dictionaries_null_value
test_dictionaries_postgresql
test_dictionaries_redis
test_dictionaries_select_all
test_dictionaries_update_and_reload
test_dictionaries_update_field
test_dictionary_allow_read_expired_keys
test_dictionary_custom_settings
test_dictionary_ddl_on_cluster
test_disabled_access_control_improvements
test_disabled_mysql_server
test_disk_access_storage
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
test_distributed_ddl Fix typos 2023-01-08 07:08:20 +01:00
test_distributed_ddl_on_cross_replication
test_distributed_ddl_parallel
test_distributed_ddl_password
test_distributed_default_database
test_distributed_directory_monitor_split_batch_on_failure
test_distributed_format
test_distributed_insert_backward_compatibility Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_distributed_inter_server_secret
test_distributed_load_balancing
test_distributed_over_distributed
test_distributed_respect_user_timeouts
test_distributed_storage_configuration
test_distributed_system_query
test_distributed_type_object
test_dns_cache
test_dotnet_client
test_drop_is_lock_free address the review comments 2022-11-23 15:16:08 +00:00
test_drop_replica
test_enabling_access_management
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
test_executable_table_function
test_executable_user_defined_function
test_executable_user_defined_functions_config_reload
test_explain_estimates
test_extreme_deduplication
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
test_fetch_partition_from_auxiliary_zookeeper
test_fetch_partition_should_reset_mutation
test_fetch_partition_with_outdated_parts
test_file_schema_inference_cache
test_filesystem_layout
test_force_deduplication
test_force_drop_table
test_format_avro_confluent
test_format_schema_on_server
test_freeze_table
test_global_overcommit_tracker Do not reuse jemalloc memory in test 2022-11-21 16:10:47 +00:00
test_globs_in_filepath
test_grant_and_revoke
test_graphite_merge_tree
test_graphite_merge_tree_typed
test_groupBitmapAnd_on_distributed
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
test_hedged_requests_parallel
test_hive_query Update test.py 2022-11-23 14:10:49 +03:00
test_host_regexp_hosts_file_resolution
test_host_regexp_multiple_ptr_records
test_host_regexp_multiple_ptr_records_concurrent lower thread and iterations number 2022-10-20 13:30:20 -03:00
test_http_and_readonly
test_http_handlers_config
test_https_replication
test_inherit_multiple_profiles
test_input_format_parallel_parsing_memory_tracking
test_insert_distributed_async_extra_dirs
test_insert_distributed_async_send
test_insert_distributed_load_balancing
test_insert_into_distributed
test_insert_into_distributed_sync_async
test_insert_into_distributed_through_materialized_view
test_inserts_with_keeper_retries Revert "Revert " Keeper retries during insert (clean)"" 2022-11-10 13:14:04 +01:00
test_jbod_balancer
test_jbod_ha Remove disk restart proxy and disk decorator (#44647) 2022-12-30 14:47:30 +01:00
test_jbod_load_balancing
test_jdbc_bridge
test_jemalloc_percpu_arena
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 Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_mntr_pressure Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_keeper_multinode_blocade_leader Unify __init__.py files 2022-12-08 23:04:56 +01: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 tests/integration: add missing kazoo client termination 2022-12-27 17:01:06 +01: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_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
test_log_lz4_streaming
test_log_query_probability
test_logs_level
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 tests. 2022-11-16 01:35:11 +01:00
test_match_process_uid_against_data_owner
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
test_max_http_connections_for_replication
test_max_suspicious_broken_parts
test_MemoryTracking
test_merge_table_over_distributed
test_merge_tree_azure_blob_storage Remove disk restart proxy and disk decorator (#44647) 2022-12-30 14:47:30 +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_s3 Move common code to helpers/mock_servers.py 2023-01-06 15:55:21 +01:00
test_merge_tree_s3_failover
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
test_merge_tree_settings_constraints check one more case in test 2022-12-07 20:36:04 +00:00
test_multiple_disks Merge pull request #44938 from ClickHouse/try-fix-test_multiple_disks-test_freeze 2023-01-06 12:45:10 +01:00
test_mutation_fetch_fallback Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_mutations_hardlinks
test_mutations_in_partitions_of_merge_tree better config in test 2022-12-21 11:35:11 +00:00
test_mutations_with_merge_tree
test_mutations_with_projection
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 Mask collection values in logs 2022-11-17 16:01:42 +01:00
test_non_default_compression
test_odbc_interaction Merge pull request #44839 from ClickHouse/move-odbc-test 2023-01-04 05:17:19 +03:00
test_old_parts_finally_removed Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_old_versions
test_on_cluster_timeouts
test_optimize_on_insert Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_overcommit_tracker Automatic style fix 2022-11-10 16:08:05 +00:00
test_part_log_table
test_part_moves_between_shards
test_part_uuid
test_partition make calls to be sure that parts are deleted 2022-12-12 12:37:52 +01:00
test_parts_delete_zookeeper
test_passing_max_partitions_to_read_remotely
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
test_postgresql_replica_database_engine_2
test_profile_events_s3 Merge branch 'master' into revert_prefixes_s3 2022-09-20 06:14:07 +03:00
test_profile_settings_and_constraints_order Lint 2022-12-20 04:00:45 +01:00
test_prometheus_endpoint
test_quorum_inserts
test_quorum_inserts_parallel Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_quota
test_random_inserts Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_range_hashed_dictionary_types
test_read_only_table Automatic style fix 2022-11-17 13:46:21 +00:00
test_read_temporary_tables_on_failure
test_recompression_ttl
test_recovery_replica Update tests/integration/test_recovery_replica/test.py 2022-09-28 12:33:38 -04:00
test_redirect_url_storage
test_relative_filepath
test_reload_auxiliary_zookeepers
test_reload_certificate
test_reload_clusters_config
test_reload_max_table_size_to_drop
test_reload_zookeeper
test_reloading_settings_from_users_xml
test_reloading_storage_configuration
test_remote_prewhere
test_rename_column
test_replace_partition
test_replica_can_become_leader
test_replica_is_active
test_replicated_database Use TablesDependencyGraph in DatabaseReplicated recovery process (#44697) 2023-01-04 14:49:39 +01:00
test_replicated_fetches_bandwidth Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_replicated_fetches_timeouts
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
test_replicated_merge_tree_encrypted_disk
test_replicated_merge_tree_encryption_codec
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 Remove disk restart proxy and disk decorator (#44647) 2022-12-30 14:47:30 +01: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
test_replicated_parse_zk_metadata
test_replicated_users tests: fix test_replicated_users flakiness 2023-01-06 12:45:03 +01:00
test_replicating_constants
test_replication_credentials
test_replication_without_zookeeper
test_restart_server
test_restore_replica Revert "Revert " Keeper retries during insert (clean)"" 2022-11-10 13:14:04 +01:00
test_rocksdb_options
test_rocksdb_read_only
test_role
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 fix skip_unavailable_shards does not work using s3Cluster table function 2022-11-12 00:03:36 +08: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_table_functions Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_s3_with_https
test_s3_with_proxy
test_s3_zero_copy_replication Correct test version 2022-09-28 14:38:11 +02:00
test_s3_zero_copy_ttl Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_secure_socket
test_select_access_rights
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
test_server_initialization
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
test_settings_constraints_distributed
test_settings_profile Updated tests to match improved behaviour of currentProfiles() 2022-11-30 02:32:27 +04:00
test_shard_level_const_function
test_sharding_key_from_default_column
test_sql_user_defined_functions_on_cluster
test_ssl_cert_authentication
test_storage_delta Fix DESCRIBE for deltaLake and hudi table functions 2022-11-17 11:46:17 +00:00
test_storage_dict
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_kafka Set retention policy for Kafka topic 2023-01-04 12:04:00 +00:00
test_storage_kerberized_hdfs
test_storage_kerberized_kafka
test_storage_meilisearch Fix tests 2022-12-22 00:27:22 +01:00
test_storage_mongodb
test_storage_mysql
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
test_storage_rabbitmq Improve and refactor Kafka/StorageMQ/NATS and data formats 2022-10-28 16:41:10 +00:00
test_storage_s3 Move common code to helpers/mock_servers.py 2023-01-06 15:55:21 +01:00
test_storage_url
test_structured_logging_json
test_system_clusters_actual_information
test_system_ddl_worker_queue
test_system_flush_logs
test_system_logs_comment
test_system_logs_recreate
test_system_merges
test_system_metrics
test_system_queries
test_system_replicated_fetches Unify __init__.py files 2022-12-08 23:04:56 +01:00
test_table_function_mongodb
test_table_functions_access_rights
test_tcp_handler_http_responses
test_tcp_handler_interserver_listen_host
test_temporary_data_in_cache Fixes 2022-12-22 10:22:57 +00:00
test_text_log_level
test_timezone_config
test_tlsv1_3
test_tmp_policy Temporary files evict fs cache 2022-12-22 10:22:49 +00:00
test_transactions fix isolation breach, droping outdated part should't be ignored 2022-11-23 15:16:09 +00:00
test_ttl_move
test_ttl_replicated make calls to be sure that parts are deleted 2022-12-12 12:37:52 +01:00
test_union_header
test_user_defined_object_persistence
test_user_directories
test_user_ip_restrictions
test_user_zero_database_access
test_version_update
test_version_update_after_mutation
test_zookeeper_config
test_zookeeper_config_load_balancing
.dockerignore
.gitignore
ci-runner.py Do not report status if we failed to pull images. 2023-01-05 13:53:45 +00: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
parallel.readme
pytest.ini
README.md
runner Merge remote-tracking branch 'origin/master' into green-ci-2 2023-01-04 15:49:22 +00: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