..
helpers
Merge pull request #55876 from ClickHouse/keeper-http-readiness-endpoint
2023-12-13 17:07:57 +01:00
test_access_control_on_cluster
test_access_for_functions
Fix wording
2023-08-06 14:48:20 +02:00
test_aggregation_memory_efficient
test_allowed_client_hosts
test_allowed_url_from_config
test_alter_codec
test_alter_comment_on_cluster
Fix ALTER COMMENT queries ON CLUSTER
2023-11-09 06:19:00 +00:00
test_alter_moving_garbage
Delete unnecessary file
2023-11-10 11:31:05 +01:00
test_alter_on_mixed_type_cluster
test_alter_settings_on_cluster
test_alter_update_cast_keep_nullable
test_alternative_keeper_config
test_always_fetch_merged
test_async_connect_to_multiple_ips
test_async_insert_memory
test_async_load_databases
Merge branch 'async-loader-integration' of github.com:ClickHouse/ClickHouse into async-loader-integration
2023-08-07 09:23:36 +00:00
test_asynchronous_metric_log_table
test_asynchronous_metrics_pk_bytes_fields
fix test query
2023-12-22 08:48:14 -08:00
test_atomic_drop_table
test_attach_backup_from_s3_plain
test_attach_partition_with_large_destination
test_attach_table_from_s3_plain_readonly
format.
2023-12-27 18:27:36 +00:00
test_attach_table_normalizer
test_attach_without_checksums
test_attach_without_fetching
Update test.py
2023-11-07 19:44:16 +01:00
test_authentication
test_azure_blob_storage_zero_copy_replication
Automatic style fix
2023-10-26 09:57:22 +00:00
test_backup_log
Update test.py
2023-09-20 17:16:50 +02:00
test_backup_restore
test_backup_restore_keeper_map
Address comments
2023-11-14 14:33:34 +00:00
test_backup_restore_new
Add the test for clickhouse_backupview to CI.
2023-11-15 17:40:53 +01:00
test_backup_restore_on_cluster
Add some comments.
2023-12-11 00:56:40 +01:00
test_backup_restore_s3
Explicit finalize() function in ZipArchiveWriter.
2023-12-24 00:33:59 +01:00
test_backup_restore_storage_policy
test_backup_s3_storage_class
test_backward_compatibility
Add exclude for tryBase64Decode to backward compat test (follow-up to #56913 )
2023-11-19 15:33:58 +00:00
test_block_structure_mismatch
test_broken_part_during_merge
Deterministic result for CHECK TABLE in tests
2023-10-23 09:36:39 +00:00
test_broken_projections
Automatic style fix
2024-01-19 11:11:13 +00:00
test_buffer_profile
test_build_sets_from_multiple_threads
Add a test for data-race in CreatingSetsTransform
2023-10-08 21:45:44 +02:00
test_catboost_evaluate
Automatic style fix
2024-01-05 23:02:58 +00:00
test_cgroup_limit
test_check_table
Minor changes in test_check_table
2023-11-23 16:24:11 +00:00
test_checking_s3_blobs_paranoid
Merge pull request #56938 from CheSema/lz4-buffering
2023-11-20 20:33:30 +01:00
test_cleanup_after_start
test_cleanup_dir_after_bad_zk_conn
test_cluster_all_replicas
Analyzer: Remove constants from header in StorageDistributed
2023-09-14 16:44:18 +00:00
test_cluster_copier
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_cluster_discovery
Fix test_cluster_discovery/test_password.py
2024-01-15 11:31:22 +00:00
test_codec_encrypted
test_composable_protocols
backward compatibility changes + fixes
2023-08-29 23:50:41 +00:00
test_compressed_marks_restart
test_compression_codec_read
test_compression_nested_columns
fix tests
2023-08-07 15:00:25 +00:00
test_concurrent_backups_s3
Disable broken tests to have the bug fixed
2023-09-09 23:21:14 +02:00
test_concurrent_queries_for_all_users_restriction
test_concurrent_queries_for_user_restriction
test_concurrent_queries_restriction_by_query_kind
test_concurrent_threads_soft_limit
Merge branch 'master' into concurrency
2023-11-13 02:56:56 +01:00
test_concurrent_ttl_merges
test_config_corresponding_root
test_config_decryption
test_config_hide_in_preprocessed
Fix flakiness in test_config_hide_in_preprocessed
2023-08-29 11:22:23 +00:00
test_config_substitutions
Allow nodes in config with from_env/from_zk and non empty element with replace=1
2023-12-07 18:01:40 +01:00
test_config_xml_full
Remove CurrentStatusInfo
2023-08-30 20:56:14 +02:00
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_crash_log
test_create_query_constraints
test_create_user_and_login
test_cross_replication
test_custom_settings
test_ddl_alter_query
ignore finished ddl tasks if hostname changed
2023-11-29 02:06:52 +01:00
test_ddl_config_hostname
Fix style & review
2023-12-08 19:40:09 +00:00
test_ddl_worker_non_leader
test_default_compression_codec
Adapt version changes
2023-10-31 18:24:33 +01:00
test_default_database_on_cluster
test_default_role
test_delayed_replica_failover
test_detached_parts_metrics
test_dictionaries_access
test_dictionaries_all_layouts_separate_sources
Remove garbage
2023-08-09 23:12:39 +02:00
test_dictionaries_complex_key_cache_string
Remove garbage
2023-08-09 23:12:39 +02:00
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
Attemp to fix test_dictionaries_redis flakiness
2023-10-19 11:59:13 +02:00
test_dictionaries_select_all
test_dictionaries_update_and_reload
Fix test_dictionaries_update_and_reload/test.py::test_reload_while_loading flakiness
2023-12-10 08:36:10 +01:00
test_dictionaries_wait_for_load
Change the default for "wait_dictionaries_load_at_startup" to true,
2023-11-23 14:45:42 +01:00
test_dictionaries_with_invalid_structure
test_dictionary_allow_read_expired_keys
Remove garbage
2023-08-09 23:12:39 +02:00
test_dictionary_custom_settings
test_dictionary_ddl_on_cluster
test_disabled_access_control_improvements
Merge branch 'master' of github.com:ClickHouse/ClickHouse into fix-grammarly
2023-08-11 01:04:33 +02:00
test_disabled_mysql_server
test_disk_access_storage
test_disk_configuration
test_disk_over_web_server
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_disk_types
test_disks_app_func
change case for copy operation in clickhouse-disks
2023-08-31 13:39:32 +00:00
test_distributed_async_insert_for_node_changes
Make DirectoryMonitor handle cluster node list change ( #42826 )
2023-12-08 14:41:51 +01:00
test_distributed_backward_compatability
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_distributed_ddl
test_distributed_ddl_on_cross_replication
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_distributed_ddl_parallel
test_distributed_ddl_password
test_distributed_default_database
test_distributed_directory_monitor_split_batch_on_failure
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_distributed_format
fix tests
2023-09-14 11:12:44 +08:00
test_distributed_insert_backward_compatibility
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_distributed_inter_server_secret
Merge pull request #56082 from Algunenano/less_diff_images
2023-11-18 17:24:28 +01:00
test_distributed_load_balancing
Fix code style
2023-09-27 12:56:06 +08:00
test_distributed_over_distributed
test_distributed_respect_user_timeouts
test_distributed_storage_configuration
Fix test_distributed_storage_configuration flakiness
2023-11-24 20:28:18 +01:00
test_distributed_system_query
test_distributed_type_object
test_dns_cache
test_dotnet_client
test_drop_if_empty
Add drop table IF EMPTY ( #48915 )
2023-09-21 09:20:18 -04:00
test_drop_is_lock_free
Enable test_query_is_lock_free[detach table] for the analyzer
2023-10-16 12:49:17 +00:00
test_drop_no_local_path
test_drop_replica
Added suggestions for mistyped names for db and tables with different… ( #49801 )
2023-08-11 13:24:16 +03:00
test_drop_replica_with_auxiliary_zookeepers
test_enabling_access_management
test_encrypted_disk
Enable temporary_data_in_cache in test_encrypted_disk
2023-12-04 10:34:17 +00:00
test_encrypted_disk_replication
test_endpoint_macro_substitution
test_executable_dictionary
test_executable_table_function
test_executable_user_defined_function
Fix black style again
2023-08-18 15:38:47 +08:00
test_executable_user_defined_functions_config_reload
test_explain_estimates
test_external_cluster
Fix ON CLUSTER queries without local database
2023-11-08 23:30:35 +00:00
test_external_http_authenticator
Add external HTTP Basic authenticator ( #55199 )
2023-10-20 19:24:19 +02:00
test_extreme_deduplication
Remove garbage
2023-08-09 23:12:39 +02:00
test_failed_async_inserts
test_fetch_memory_usage
test_fetch_partition_from_auxiliary_zookeeper
test_fetch_partition_should_reset_mutation
test_fetch_partition_with_outdated_parts
test_file_cluster
Introduced fileCluster table function
2023-11-22 15:06:04 +01:00
test_file_schema_inference_cache
Cache number of rows in files for count in file/s3/url/hdfs/azure functions
2023-08-22 11:59:59 +00:00
test_filesystem_cache
Make caches with the same path use the same cache objects
2023-12-27 18:37:43 +01:00
test_filesystem_layout
fix tests
2023-08-07 15:00:25 +00:00
test_force_deduplication
test_force_drop_table
test_format_avro_confluent
test_format_schema_on_server
Added test to check CapnProto cache
2023-10-19 09:00:39 +02:00
test_freeze_table
test_global_overcommit_tracker
test_globs_in_filepath
test_grant_and_revoke
Fix some of the CI
2023-12-28 17:56:05 +00:00
test_graphite_merge_tree
fix
2023-08-16 12:06:36 +02:00
test_graphite_merge_tree_typed
test_group_array_element_size
Automatic style fix
2023-08-18 13:34:20 +00:00
test_groupBitmapAnd_on_distributed
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_grpc_protocol
Add index to table system.numbers ( #50909 )
2023-12-01 19:59:25 +01:00
test_grpc_protocol_ssl
Use pregenerated gRPC protocol pb2 files to fix test flakyness.
2023-09-26 17:28:19 +02:00
test_hedged_requests
Use less attempts
2023-09-25 21:04:12 +02:00
test_hedged_requests_parallel
test_host_regexp_hosts_file_resolution
test_host_regexp_multiple_ptr_records
bring back dns tests, fix them by pining coredns version and modifying test_reverse_dns_query
2023-08-10 16:45:29 -03:00
test_host_regexp_multiple_ptr_records_concurrent
Lower the number of iterations in test_host_regexp_multiple_ptr_records_concurrent ( #54307 )
2023-09-05 20:05:12 +02:00
test_hot_reload_storage_policy
tables auto initialize new disks without restart
2023-11-06 10:26:48 +00:00
test_http_and_readonly
test_http_failover
test_http_handlers_config
Automatic style fix
2023-10-20 12:40:28 +00:00
test_http_native
test_https_replication
test_https_s3_table_function_with_http_proxy_no_tunneling
Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy ( #55033 )
2023-11-04 13:47:52 -04:00
test_inherit_multiple_profiles
test_input_format_parallel_parsing_memory_tracking
test_insert_distributed_async_extra_dirs
test_insert_distributed_async_send
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_insert_distributed_load_balancing
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_insert_into_distributed
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_insert_into_distributed_sync_async
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_insert_into_distributed_through_materialized_view
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_inserts_with_keeper_retries
test_interserver_dns_retires
test_jbod_balancer
Add wait_until_fully_merged.
2023-11-02 01:50:09 +08:00
test_jbod_ha
test_jbod_load_balancing
Fix incorrect free space accounting for least_used JBOD policy
2023-10-29 17:36:31 +01:00
test_jdbc_bridge
test_jemalloc_percpu_arena
test_join_set_family_s3
test_kafka_bad_messages
Fix style
2024-01-02 15:43:44 +00:00
test_keeper_and_access_storage
test_keeper_auth
Fix test_keeper_auth
2023-11-18 19:38:33 +00:00
test_keeper_availability_zone
reduce timeout and setTimeout earlier.
2023-11-14 17:58:16 +00:00
test_keeper_back_to_back
test_keeper_broken_logs
better test_keeper_broken_logs
2023-11-16 13:08:48 +00:00
test_keeper_client
Add get_direct_children_number command to keeper-client ( #55898 )
2023-10-24 17:02:54 +02:00
test_keeper_compression
Updated name to use_compression
2023-10-27 14:53:54 +02:00
test_keeper_disks
Use different config for snapshot test
2023-09-05 06:45:06 +00:00
test_keeper_dynamic_log_level
Fix a style check issue
2023-08-23 20:13:54 +08:00
test_keeper_feature_flags_config
Automatic style fix
2023-09-18 11:28:36 +00:00
test_keeper_force_recovery
test_keeper_force_recovery_single_node
test_keeper_four_word_command
Fix test
2023-11-15 07:42:19 +00:00
test_keeper_http_control
Remove time.sleep
from test
2023-12-12 12:29:00 +01:00
test_keeper_incorrect_config
test_keeper_internal_secure
test_keeper_map
test_keeper_memory_soft_limit
support soft limit ratio
2023-12-08 21:48:27 +01:00
test_keeper_mntr_data_size
test_keeper_mntr_pressure
test_keeper_multinode_simple
test_keeper_nodes_add
test_keeper_nodes_move
test_keeper_nodes_remove
test_keeper_persistent_log
test_keeper_persistent_log_multinode
test_keeper_reconfig_add
Automatic style fix
2023-09-07 00:44:54 +00:00
test_keeper_reconfig_remove
Automatic style fix
2023-09-07 00:44:54 +00:00
test_keeper_reconfig_remove_many
Automatic style fix
2023-09-07 00:44:54 +00:00
test_keeper_reconfig_replace_leader
More stable test_keeper_reconfig_replace_leader
2023-11-16 13:31:39 +00:00
test_keeper_reconfig_replace_leader_in_one_command
Keeper reconfig -- sleep before removing leader to avoid losing accepted
2023-11-09 16:22:44 +00:00
test_keeper_restore_from_snapshot
test_keeper_s3_snapshot
test_keeper_secure_client
test_keeper_session
test_keeper_snapshot_on_exit
test_keeper_snapshot_small_distance
test_keeper_snapshots
test_keeper_snapshots_multinode
test_keeper_three_nodes_start
test_keeper_three_nodes_two_alive
test_keeper_two_nodes_cluster
test_keeper_znode_time
test_keeper_zookeeper_converter
test_kerberos_auth
test_ldap_external_user_directory
style: Apply black formatter
2023-09-30 07:04:05 +02:00
test_library_bridge
test_limited_replicated_fetches
test_log_family_hdfs
test_log_family_s3
test_log_levels_update
test_log_lz4_streaming
test_log_query_probability
test_logs_level
test_lost_part
test_lost_part_during_startup
test_manipulate_statistic
support rename
2023-10-04 00:58:26 +02:00
test_mask_sensitive_info
Fix black formatting
2024-01-08 12:47:58 +01:00
test_match_process_uid_against_data_owner
test_materialized_mysql_database
MaterializedMySQL: Introduce MySQL Binlog Client
2024-01-03 15:26:09 +01:00
test_materialized_view_restart_server
test_max_rows_to_read_leaf_with_view
Fix test_max_rows_to_read_leaf_with_view flakiness (due to prefer_localhost_replica)
2023-10-09 06:56:53 +02:00
test_max_suspicious_broken_parts
test_max_suspicious_broken_parts_replicated
Fix unexpected parts handling ( #56693 )
2023-11-15 16:54:47 +01:00
test_memory_profiler_min_max_borders
test_MemoryTracking
test_merge_table_over_distributed
test_merge_tree_azure_blob_storage
Update test.py
2024-01-18 11:02:13 +01:00
test_merge_tree_check_part_with_cache
test_merge_tree_empty_parts
test_merge_tree_hdfs
test_merge_tree_load_parts
test_merge_tree_s3
ClickHouse Cloud promotion ( #57638 )
2023-12-15 15:23:23 +01:00
test_merge_tree_s3_failover
Revert "Revert "s3 adaptive timeouts""
2023-11-20 14:53:22 +01:00
test_merge_tree_s3_with_cache
test_merge_tree_settings_constraints
test_merges_memory_limit
test_move_partition_to_disk_on_cluster
test_move_partition_to_volume_async
Automatic style fix
2023-11-15 17:48:54 +00:00
test_multi_access_storage_role_management
test_multiple_disks
Automatic style fix
2023-12-08 02:33:04 +00:00
test_mutation_fetch_fallback
test_mutations_hardlinks
test_mutations_in_partitions_of_merge_tree
test_mutations_with_merge_tree
Remove garbage
2023-08-09 23:12:39 +02:00
test_mutations_with_projection
test_mysql_database_engine
test_mysql_protocol
Fix incorrect nullable columns reporting in MySQL binary protocol
2023-11-15 16:53:38 +01:00
test_named_collections
Delete a file (2)
2023-11-13 07:08:21 +01:00
test_named_collections_if_exists_on_cluster
test_non_default_compression
refine setting with enable_zstd_qat_codec
2023-12-22 14:24:15 -05:00
test_odbc_interaction
test_old_parts_finally_removed
test_old_versions
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_on_cluster_timeouts
test_optimize_on_insert
test_overcommit_tracker
Merge branch 'master' into concurrency
2023-11-13 02:56:56 +01:00
test_parallel_replicas_all_marks_read
New parallel replicas coordinator implementation ( #57968 )
2024-01-04 00:27:04 +01:00
test_parallel_replicas_custom_key
Fix existing intergation test
2023-11-30 18:42:03 +00:00
test_parallel_replicas_custom_key_failover
Using current database in cluster
2024-01-17 19:35:35 +00:00
test_parallel_replicas_custom_key_load_balancing
Using current database in cluster
2024-01-17 19:35:35 +00:00
test_parallel_replicas_distributed_skip_shards
Parallel replicas: friendly settings ( #57542 )
2023-12-13 14:42:06 +01:00
test_parallel_replicas_invisible_parts
fix
2024-01-17 19:42:23 +01:00
test_parallel_replicas_over_distributed
Merge pull request #57809 from ClickHouse/fix-flaky-test_parallel_replicas_over_distributed
2023-12-13 17:11:41 +01:00
test_parallel_replicas_skip_shards
Parallel replicas: friendly settings ( #57542 )
2023-12-13 14:42:06 +01:00
test_part_log_table
fix the missing column
2023-08-16 17:49:28 +00:00
test_part_uuid
test_partition
Merge remote-tracking branch 'upstream/master' into HEAD
2023-09-18 23:13:20 +00:00
test_parts_delete_zookeeper
fix
2023-11-04 22:50:19 +01:00
test_passing_max_partitions_to_read_remotely
test_password_constraints
test_peak_memory_usage
Improved test
2023-08-11 23:48:17 +00:00
test_polymorphic_parts
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_postgresql_database_engine
Cleanup
2023-11-29 11:11:58 +00:00
test_postgresql_protocol
Added waiting to other PostgreSQL tests
2023-08-17 08:24:17 +00:00
test_postgresql_replica_database_engine_1
Automatic style fix
2023-12-14 13:19:46 +00:00
test_postgresql_replica_database_engine_2
Fix
2024-01-18 16:56:17 +01:00
test_profile_events_s3
test_profile_max_sessions_for_user
Use pregenerated gRPC protocol pb2 files to fix test flakyness.
2023-09-26 17:28:19 +02:00
test_profile_settings_and_constraints_order
test_prometheus_endpoint
Automatic style fix
2023-12-07 19:42:33 +00:00
test_quorum_inserts
sync second replica in test_insert_quorum
2023-08-08 11:06:49 +00:00
test_quorum_inserts_parallel
Fix integration test
2023-12-19 14:36:03 +01:00
test_quota
test_random_inserts
test_range_hashed_dictionary_types
test_read_only_table
test_read_temporary_tables_on_failure
test_recompression_ttl
test_recovery_replica
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_query_masking_rules
Reintroduce commit 3067ca6
2024-01-17 08:10:49 +02:00
test_reload_zookeeper
test_reloading_settings_from_users_xml
test_reloading_storage_configuration
test_remote_blobs_naming
fix style
2024-01-05 13:42:30 +00:00
test_remote_prewhere
test_rename_column
test_render_log_file_name_templates
test_replace_partition
test_replica_can_become_leader
test_replica_is_active
test_replicated_database
Merge pull request #58649 from azat/tests/test_replicated_database
2024-01-16 21:08:33 +01:00
test_replicated_database_cluster_groups
an option to avoid waiting for inactive Replicated db replicas
2023-12-29 15:19:16 +01:00
test_replicated_fetches_bandwidth
test_replicated_fetches_timeouts
Automatic style fix
2023-12-18 22:07:00 +00:00
test_replicated_merge_tree_compatibility
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_replicated_merge_tree_config
test_replicated_merge_tree_encrypted_disk
test_replicated_merge_tree_encryption_codec
Add comment.
2023-11-24 14:01:52 +01:00
test_replicated_merge_tree_s3
test_replicated_merge_tree_s3_zero_copy
test_replicated_merge_tree_wait_on_shutdown
test_replicated_merge_tree_with_auxiliary_zookeepers
test_replicated_mutations
test_replicated_parse_zk_metadata
test_replicated_s3_zero_copy_drop_partition
Black
2023-10-07 21:18:54 +02:00
test_replicated_table_attach
test_replicated_user_defined_functions
Refactoring for UserDefinedSQLObjectsLoader
2023-12-12 17:03:49 +03:00
test_replicated_users
ignore_on_cluster_for_grants
2023-12-05 15:11:32 +00:00
test_replicated_zero_copy_projection_mutation
fix tests
2023-11-04 15:44:55 +01:00
test_replicating_constants
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_replication_credentials
test_replication_without_zookeeper
test_restart_server
These queries need to be run in the same session
2023-08-23 15:00:00 +02:00
test_restore_replica
Update test.py
2023-08-07 16:58:59 +03:00
test_rocksdb_options
Add ability to specify BlockBasedTableOptions for rocksdb
2023-11-02 15:36:00 +01:00
test_rocksdb_read_only
test_role
test_row_policy
Merge branch 'master' of github.com:ClickHouse/ClickHouse into fix-grammarly
2023-08-11 01:04:33 +02:00
test_runtime_configurable_cache_size
Disable test
2023-08-21 21:26:28 +00:00
test_s3_aws_sdk_has_slightly_unreliable_behaviour
test_s3_cluster
test_s3_imds
test_s3_low_cardinality_right_border
test_s3_storage_class
test_s3_storage_conf_new_proxy
tmp
2023-10-04 17:21:41 -03:00
test_s3_storage_conf_proxy
Add global proxy setting ( #51749 )
2023-08-24 16:07:26 +03:00
test_s3_style_link
style fix
2023-11-28 19:13:37 +01:00
test_s3_table_function_with_http_proxy
fix tests
2023-10-11 10:10:19 -03:00
test_s3_table_function_with_https_proxy
Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy ( #55033 )
2023-11-04 13:47:52 -04:00
test_s3_table_functions
fix tests, to avoid timeouts do less retries
2023-10-18 16:36:45 +02:00
test_s3_with_https
test_s3_zero_copy_replication
ClickHouse Cloud promotion ( #57638 )
2023-12-15 15:23:23 +01:00
test_s3_zero_copy_ttl
MergeTask uses temporary data storage
2023-11-29 16:18:32 +00:00
test_scheduler
review fixes
2023-09-07 14:02:58 +00:00
test_secure_socket
test_select_access_rights
Follow-up to #52695 : Move tests to a more appropriate place
2023-08-14 09:27:12 +00:00
test_send_crash_reports
test_send_request_to_leader_replica
test_server_initialization
test_server_reload
Use pregenerated gRPC protocol pb2 files to fix test flakyness.
2023-09-26 17:28:19 +02:00
test_server_start_and_ip_conversions
test_session_log
Use pregenerated gRPC protocol pb2 files to fix test flakyness.
2023-09-26 17:28:19 +02:00
test_settings_constraints
test_settings_constraints_distributed
test_settings_profile
Merge branch 'master' of github.com:ClickHouse/ClickHouse into fix-grammarly
2023-08-11 01:04:33 +02:00
test_shard_level_const_function
test_sharding_key_from_default_column
Rename directory monitor concept into background INSERT ( #55978 )
2023-11-01 15:09:39 +01:00
test_shutdown_wait_unfinished_queries
Automatic style fix
2023-08-23 06:27:28 +00:00
test_sql_user_defined_functions_on_cluster
test_ssh_keys_authentication
SSH keys authentication ( #41109 )
2023-09-26 17:50:19 +02:00
test_ssl_cert_authentication
Remove tests
2023-09-26 09:02:12 +00:00
test_storage_azure_blob_storage
Fix test_unset_skip_unavailable_shards
2023-12-15 12:18:40 +01:00
test_storage_delta
Adjust the test_storage_delta::test_multiple_log_files after MinIO upgrade
2023-10-08 07:30:13 +02:00
test_storage_dict
test_storage_hdfs
Add union mode for schema inference to infer union schema of files with different schemas
2023-10-20 20:46:41 +00:00
test_storage_hudi
test_storage_iceberg
Automatic style fix
2024-01-06 15:55:20 +00:00
test_storage_kafka
Merge pull request #58614 from Blargian/58363_disable_ansi_pretty_automatically
2024-01-17 13:45:41 +01:00
test_storage_kerberized_hdfs
test_storage_kerberized_kafka
test_storage_mongodb
test_storage_mysql
Add one more test case to the test
2024-01-12 10:41:04 +01:00
test_storage_numbers
Add index to table system.numbers ( #50909 )
2023-12-01 19:59:25 +01:00
test_storage_policies
test_storage_postgresql
Merge pull request #57874 from joelynch/joelynch/host-psql
2023-12-19 15:24:23 -05:00
test_storage_rabbitmq
fix failing 02421 stateless and (hopefully) fix failing integration tests
2024-01-16 19:48:23 +02:00
test_storage_redis
test_storage_s3
S3 Session Tokens: Added tests
2023-12-19 10:50:19 +02:00
test_storage_s3_queue
Automatic style fix
2024-01-08 02:39:19 +00:00
test_storage_url
Fix wording
2023-08-06 14:48:20 +02:00
test_storage_url_http_headers
test_storage_url_with_proxy
Add global proxy setting ( #51749 )
2023-08-24 16:07:26 +03:00
test_store_cleanup
Fix test_store_cleanup/test.py after rebase
2023-10-23 12:33:35 +00:00
test_structured_logging_json
test_system_clusters_actual_information
test_system_ddl_worker_queue
test_system_flush_logs
Added suggestions for mistyped names for db and tables with different… ( #49801 )
2023-08-11 13:24:16 +03:00
test_system_logs
test_system_logs_comment
test_system_logs_hostname
add a test
2023-10-27 11:02:51 -07:00
test_system_logs_recreate
test_system_merges
Fix test_system_merges after optimization for "x OR 1" conditions
2023-10-16 15:57:34 +02:00
test_system_metrics
Add test
2023-11-27 15:05:56 +00:00
test_system_queries
test_system_replicated_fetches
test_system_start_stop_listen
bugfix: parse system stop listen tcp secure
2023-12-04 19:56:35 +01:00
test_table_function_mongodb
test_table_function_redis
test_table_functions_access_rights
Fix wording
2023-08-06 14:48:20 +02:00
test_tcp_handler_http_responses
test_tcp_handler_interserver_listen_host
test_temporary_data
test_temporary_data_in_cache
Merge branch 'master' into fs-cache-improvement
2023-11-01 10:47:36 +01:00
test_text_log_level
test_throttling
Add ability to throttle merges/mutations
2023-12-24 22:31:49 +01:00
test_timezone_config
test_tlsv1_3
Remove tests
2023-09-26 09:02:12 +00:00
test_tmp_policy
test_transactions
test_truncate_database
add integration tests
2023-08-10 21:14:47 -07:00
test_ttl_move
Automatic style fix
2023-12-08 02:33:04 +00:00
test_ttl_replicated
Adapt to work with releases without DROP SYNC
2023-10-31 18:06:28 +01:00
test_undrop_query
Mark a setting obsolete ( #57336 )
2023-11-29 19:24:11 +01:00
test_union_header
test_user_defined_object_persistence
test_user_directories
test_user_grants_from_config
test_user_ip_restrictions
test_user_valid_until
Fix test_user_valid_until
2024-01-02 14:50:28 +01:00
test_user_zero_database_access
test_version_update
Try reducing number of different images
2023-10-31 17:20:07 +01:00
test_version_update_after_mutation
Adapt version changes
2023-10-31 18:24:33 +01:00
test_wrong_db_or_table_name
add a test
2024-01-02 13:52:52 -08:00
test_zero_copy_fetch
test_zero_copy_replication_drop_detached_part
test_zookeeper_config
Maybe better, but not sure
2023-08-05 16:52:44 +02:00
test_zookeeper_config_load_balancing
Add load balancing test_hostname_levenshtein_distance
2023-09-27 10:46:39 +08:00
test_zookeeper_fallback_session
integration test working and std::exception_ptr.
2023-11-03 02:24:42 +00:00
.dockerignore
.gitignore
ci-runner.py
Create a single point of true for integration tests images
2023-12-21 16:09:56 +01:00
conftest.py
Update conftest.py ( #53166 )
2023-08-08 22:23:18 +03:00
integration_test_images.py
Create a single point of true for integration tests images
2023-12-21 16:09:56 +01:00
parallel_skip.json
Fix clang-tidy issues and disable parallel execution of tests
2023-11-17 11:02:07 +03:00
parallel.readme
pytest.ini
README.md
Remove Meilisearch
2023-09-30 06:02:38 +02:00
runner
Create a single point of true for integration tests images
2023-12-21 16:09:56 +01:00