module ClickHaskell.Packets.SettingsSupport where -- Internal import ClickHaskell.Primitive -- GHC import Data.Kind import GHC.TypeLits data Setting (a :: Symbol) (settType :: Type) type SupportedSettings = '[ Setting "min_compress_block_size" UInt64, Setting "max_compress_block_size" UInt64, Setting "min_insert_block_size_rows" UInt64, Setting "min_insert_block_size_bytes" UInt64, Setting "min_insert_block_size_rows_for_materialized_views" UInt64, Setting "min_insert_block_size_bytes_for_materialized_views" UInt64, Setting "min_external_table_block_size_rows" UInt64, Setting "min_external_table_block_size_bytes" UInt64, Setting "max_joined_block_size_rows" UInt64, Setting "max_joined_block_size_bytes" UInt64, Setting "min_joined_block_size_rows" UInt64, Setting "min_joined_block_size_bytes" UInt64, Setting "max_insert_threads" UInt64, Setting "max_insert_delayed_streams_for_parallel_write" UInt64, Setting "max_threads_for_indexes" UInt64, Setting "max_download_buffer_size" UInt64, Setting "max_read_buffer_size_local_fs" UInt64, Setting "max_read_buffer_size_remote_fs" UInt64, Setting "max_distributed_connections" UInt64, Setting "max_query_size" UInt64, Setting "interactive_delay" UInt64, Setting "poll_interval" UInt64, Setting "idle_connection_timeout" UInt64, Setting "distributed_connections_pool_size" UInt64, Setting "connections_with_failover_max_tries" UInt64, Setting "s3_strict_upload_part_size" UInt64, Setting "azure_strict_upload_part_size" UInt64, Setting "azure_max_blocks_in_multipart_upload" UInt64, Setting "s3_min_upload_part_size" UInt64, Setting "s3_max_upload_part_size" UInt64, Setting "azure_min_upload_part_size" UInt64, Setting "azure_max_upload_part_size" UInt64, Setting "s3_upload_part_size_multiply_factor" UInt64, Setting "s3_upload_part_size_multiply_parts_count_threshold" UInt64, Setting "s3_max_part_number" UInt64, Setting "s3_max_single_operation_copy_size" UInt64, Setting "azure_upload_part_size_multiply_factor" UInt64, Setting "azure_upload_part_size_multiply_parts_count_threshold" UInt64, Setting "s3_max_inflight_parts_for_one_file" UInt64, Setting "azure_max_inflight_parts_for_one_file" UInt64, Setting "s3_max_single_part_upload_size" UInt64, Setting "azure_max_single_part_upload_size" UInt64, Setting "azure_max_single_part_copy_size" UInt64, Setting "s3_max_single_read_retries" UInt64, Setting "azure_max_single_read_retries" UInt64, Setting "azure_max_unexpected_write_error_retries" UInt64, Setting "s3_max_unexpected_write_error_retries" UInt64, Setting "azure_max_redirects" UInt64, Setting "azure_max_get_rps" UInt64, Setting "azure_max_get_burst" UInt64, Setting "azure_max_put_rps" UInt64, Setting "azure_max_put_burst" UInt64, Setting "s3_max_connections" UInt64, Setting "s3_max_get_rps" UInt64, Setting "s3_max_get_burst" UInt64, Setting "s3_max_put_rps" UInt64, Setting "s3_max_put_burst" UInt64, Setting "s3_list_object_keys_size" UInt64, Setting "azure_list_object_keys_size" UInt64, Setting "azure_sdk_max_retries" UInt64, Setting "azure_sdk_retry_initial_backoff_ms" UInt64, Setting "azure_sdk_retry_max_backoff_ms" UInt64, Setting "azure_request_timeout_ms" UInt64, Setting "azure_connect_timeout_ms" UInt64, Setting "s3_request_timeout_ms" UInt64, Setting "s3_connect_timeout_ms" UInt64, Setting "s3queue_default_zookeeper_path" ChString, Setting "hdfs_replication" UInt64, Setting "hsts_max_age" UInt64, Setting "max_remote_read_network_bandwidth" UInt64, Setting "max_remote_write_network_bandwidth" UInt64, Setting "max_local_read_bandwidth" UInt64, Setting "max_local_write_bandwidth" UInt64, Setting "stream_like_engine_insert_queue" ChString, Setting "load_balancing_first_offset" UInt64, Setting "min_count_to_compile_expression" UInt64, Setting "min_count_to_compile_aggregate_expression" UInt64, Setting "min_count_to_compile_sort_description" UInt64, Setting "group_by_two_level_threshold" UInt64, Setting "group_by_two_level_threshold_bytes" UInt64, Setting "aggregation_memory_efficient_merge_threads" UInt64, Setting "parallel_distributed_insert_select" UInt64, Setting "distributed_group_by_no_merge" UInt64, Setting "distributed_push_down_limit" UInt64, Setting "optimize_skip_unused_shards_limit" UInt64, Setting "force_optimize_skip_unused_shards" UInt64, Setting "optimize_skip_unused_shards_nesting" UInt64, Setting "force_optimize_skip_unused_shards_nesting" UInt64, Setting "output_format_compression_level" UInt64, Setting "output_format_compression_zstd_window_log" UInt64, Setting "merge_tree_min_rows_for_concurrent_read" UInt64, Setting "merge_tree_min_bytes_for_concurrent_read" UInt64, Setting "merge_tree_min_rows_for_seek" UInt64, Setting "merge_tree_min_bytes_for_seek" UInt64, Setting "merge_tree_coarse_index_granularity" UInt64, Setting "merge_tree_max_rows_to_use_cache" UInt64, Setting "merge_tree_max_bytes_to_use_cache" UInt64, Setting "mysql_max_rows_to_insert" UInt64, Setting "optimize_min_equality_disjunction_chain_length" UInt64, Setting "optimize_min_inequality_conjunction_chain_length" UInt64, Setting "min_bytes_to_use_direct_io" UInt64, Setting "min_bytes_to_use_mmap_io" UInt64, Setting "exclude_materialize_skip_indexes_on_insert" ChString, Setting "ignore_data_skipping_indices" ChString, Setting "force_data_skipping_indices" ChString, Setting "network_compression_method" ChString, Setting "priority" UInt64, Setting "log_queries_cut_to_length" UInt64, Setting "max_concurrent_queries_for_all_users" UInt64, Setting "max_concurrent_queries_for_user" UInt64, Setting "select_sequential_consistency" UInt64, Setting "table_function_remote_max_addresses" UInt64, Setting "read_backoff_max_throughput" UInt64, Setting "read_backoff_min_events" UInt64, Setting "read_backoff_min_concurrency" UInt64, Setting "count_distinct_implementation" ChString, Setting "max_http_get_redirects" UInt64, Setting "http_headers_progress_interval_ms" UInt64, Setting "http_response_buffer_size" UInt64, Setting "join_output_by_rowlist_perkey_rows_threshold" UInt64, Setting "query_plan_optimize_join_order_limit" UInt64, Setting "query_plan_max_step_description_length" UInt64, Setting "preferred_block_size_bytes" UInt64, Setting "max_replica_delay_for_distributed_queries" UInt64, Setting "preferred_max_column_in_block_size_bytes" UInt64, Setting "parts_to_delay_insert" UInt64, Setting "parts_to_throw_insert" UInt64, Setting "number_of_mutations_to_delay" UInt64, Setting "number_of_mutations_to_throw" UInt64, Setting "min_free_disk_bytes_to_perform_insert" UInt64, Setting "unknown_packet_in_send_data" UInt64, Setting "http_max_uri_size" UInt64, Setting "http_max_fields" UInt64, Setting "http_max_field_name_size" UInt64, Setting "http_max_field_value_size" UInt64, Setting "use_index_for_in_with_subqueries_max_values" UInt64, Setting "query_profiler_real_time_period_ns" UInt64, Setting "query_profiler_cpu_time_period_ns" UInt64, Setting "metrics_perf_events_list" ChString, Setting "max_rows_to_read" UInt64, Setting "max_bytes_to_read" UInt64, Setting "max_rows_to_read_leaf" UInt64, Setting "max_bytes_to_read_leaf" UInt64, Setting "max_rows_to_group_by" UInt64, Setting "max_bytes_before_external_group_by" UInt64, Setting "max_rows_to_sort" UInt64, Setting "max_bytes_to_sort" UInt64, Setting "prefer_external_sort_block_bytes" UInt64, Setting "max_bytes_before_external_sort" UInt64, Setting "max_bytes_before_remerge_sort" UInt64, Setting "max_result_rows" UInt64, Setting "max_result_bytes" UInt64, Setting "min_execution_speed" UInt64, Setting "max_execution_speed" UInt64, Setting "min_execution_speed_bytes" UInt64, Setting "max_execution_speed_bytes" UInt64, Setting "max_columns_to_read" UInt64, Setting "max_temporary_columns" UInt64, Setting "max_temporary_non_const_columns" UInt64, Setting "max_sessions_for_user" UInt64, Setting "max_subquery_depth" UInt64, Setting "max_analyze_depth" UInt64, Setting "max_ast_depth" UInt64, Setting "max_ast_elements" UInt64, Setting "max_expanded_ast_elements" UInt64, Setting "readonly" UInt64, Setting "max_rows_in_set" UInt64, Setting "max_bytes_in_set" UInt64, Setting "max_rows_in_join" UInt64, Setting "max_bytes_in_join" UInt64, Setting "cross_join_min_rows_to_compress" UInt64, Setting "cross_join_min_bytes_to_compress" UInt64, Setting "default_max_bytes_in_join" UInt64, Setting "partial_merge_join_left_table_buffer_bytes" UInt64, Setting "partial_merge_join_rows_in_right_blocks" UInt64, Setting "join_on_disk_max_files_to_merge" UInt64, Setting "max_rows_in_set_to_optimize_join" UInt64, Setting "temporary_files_codec" ChString, Setting "temporary_files_buffer_size" UInt64, Setting "max_rows_to_transfer" UInt64, Setting "max_bytes_to_transfer" UInt64, Setting "max_rows_in_distinct" UInt64, Setting "max_bytes_in_distinct" UInt64, Setting "max_memory_usage" UInt64, Setting "memory_overcommit_ratio_denominator" UInt64, Setting "max_memory_usage_for_user" UInt64, Setting "memory_overcommit_ratio_denominator_for_user" UInt64, Setting "max_untracked_memory" UInt64, Setting "memory_profiler_step" UInt64, Setting "memory_profiler_sample_min_allocation_size" UInt64, Setting "memory_profiler_sample_max_allocation_size" UInt64, Setting "memory_usage_overcommit_max_wait_microseconds" UInt64, Setting "max_network_bandwidth" UInt64, Setting "max_network_bytes" UInt64, Setting "max_network_bandwidth_for_user" UInt64, Setting "max_network_bandwidth_for_all_users" UInt64, Setting "max_temporary_data_on_disk_size_for_user" UInt64, Setting "max_temporary_data_on_disk_size_for_query" UInt64, Setting "backup_restore_keeper_max_retries" UInt64, Setting "backup_restore_keeper_retry_initial_backoff_ms" UInt64, Setting "backup_restore_keeper_retry_max_backoff_ms" UInt64, Setting "backup_restore_failure_after_host_disconnected_for_seconds" UInt64, Setting "backup_restore_keeper_max_retries_while_initializing" UInt64, Setting "backup_restore_keeper_max_retries_while_handling_error" UInt64, Setting "backup_restore_finish_timeout_after_error_sec" UInt64, Setting "backup_restore_keeper_value_max_size" UInt64, Setting "backup_restore_batch_size_for_keeper_multi" UInt64, Setting "backup_restore_batch_size_for_keeper_multiread" UInt64, Setting "backup_restore_keeper_fault_injection_seed" UInt64, Setting "backup_restore_s3_retry_attempts" UInt64, Setting "backup_restore_s3_retry_initial_backoff_ms" UInt64, Setting "backup_restore_s3_retry_max_backoff_ms" UInt64, Setting "max_backup_bandwidth" UInt64, Setting "log_comment" ChString, Setting "send_logs_source_regexp" ChString, Setting "low_cardinality_max_dictionary_size" UInt64, Setting "max_fetch_partition_retries_count" UInt64, Setting "http_max_multipart_form_data_size" UInt64, Setting "aggregation_in_order_max_block_bytes" UInt64, Setting "read_in_order_two_level_merge_threshold" UInt64, Setting "max_hyperscan_regexp_length" UInt64, Setting "max_hyperscan_regexp_total_length" UInt64, Setting "max_partitions_per_insert_block" UInt64, Setting "max_parts_to_move" UInt64, Setting "max_table_size_to_drop" UInt64, Setting "max_partition_size_to_drop" UInt64, Setting "postgresql_connection_pool_size" UInt64, Setting "postgresql_connection_attempt_timeout" UInt64, Setting "postgresql_connection_pool_wait_timeout" UInt64, Setting "postgresql_connection_pool_retries" UInt64, Setting "glob_expansion_max_elements" UInt64, Setting "odbc_bridge_connection_pool_size" UInt64, Setting "distributed_replica_error_cap" UInt64, Setting "distributed_replica_max_ignored_errors" UInt64, Setting "min_free_disk_space_for_temporary_data" UInt64, Setting "mutations_sync" UInt64, Setting "lightweight_deletes_sync" UInt64, Setting "max_parser_depth" UInt64, Setting "max_parser_backtracks" UInt64, Setting "max_recursive_cte_evaluation_depth" UInt64, Setting "function_implementation" ChString, Setting "force_optimize_projection_name" ChString, Setting "preferred_optimize_projection_name" ChString, Setting "max_projection_rows_to_use_projection_index" UInt64, Setting "min_table_rows_to_use_projection_index" UInt64, Setting "mutations_max_literal_size_to_replace" UInt64, Setting "query_cache_max_size_in_bytes" UInt64, Setting "query_cache_max_entries" UInt64, Setting "query_cache_min_query_runs" UInt64, Setting "query_cache_tag" ChString, Setting "merge_tree_storage_snapshot_sleep_ms" UInt64, Setting "insert_shard_id" UInt64, Setting "max_size_to_preallocate_for_aggregation" UInt64, Setting "max_size_to_preallocate_for_joins" UInt64, Setting "max_number_of_partitions_for_independent_aggregation" UInt64, Setting "database_replicated_initial_query_timeout_sec" UInt64, Setting "max_distributed_depth" UInt64, Setting "database_replicated_allow_replicated_engine_arguments" UInt64, Setting "database_replicated_allow_explicit_uuid" UInt64, Setting "cloud_mode_engine" UInt64, Setting "cloud_mode_database_engine" UInt64, Setting "distributed_ddl_entry_format_version" UInt64, Setting "external_storage_max_read_rows" UInt64, Setting "external_storage_max_read_bytes" UInt64, Setting "external_storage_connect_timeout_sec" UInt64, Setting "external_storage_rw_timeout_sec" UInt64, Setting "query_plan_max_optimizations_to_apply" UInt64, Setting "query_plan_max_limit_for_lazy_materialization" UInt64, Setting "regexp_max_matches_per_row" UInt64, Setting "limit" UInt64, Setting "offset" UInt64, Setting "function_range_max_elements_in_block" UInt64, Setting "function_sleep_max_microseconds_per_block" UInt64, Setting "function_visible_width_behavior" UInt64, Setting "local_filesystem_read_method" ChString, Setting "remote_filesystem_read_method" ChString, Setting "merge_tree_min_rows_for_concurrent_read_for_remote_filesystem" UInt64, Setting "merge_tree_min_bytes_for_concurrent_read_for_remote_filesystem" UInt64, Setting "remote_read_min_bytes_for_seek" UInt64, Setting "merge_tree_compact_parts_min_granules_to_multibuffer_read" UInt64, Setting "async_insert_max_data_size" UInt64, Setting "async_insert_max_query_number" UInt64, Setting "remote_fs_read_max_backoff_ms" UInt64, Setting "remote_fs_read_backoff_max_tries" UInt64, Setting "filesystem_cache_name" ChString, Setting "filesystem_cache_max_download_size" UInt64, Setting "filesystem_cache_segments_batch_size" UInt64, Setting "filesystem_cache_reserve_space_wait_lock_timeout_milliseconds" UInt64, Setting "filesystem_cache_boundary_alignment" UInt64, Setting "temporary_data_in_cache_reserve_space_wait_lock_timeout_milliseconds" UInt64, Setting "page_cache_block_size" UInt64, Setting "page_cache_lookahead_blocks" UInt64, Setting "prefetch_buffer_size" UInt64, Setting "filesystem_prefetch_step_bytes" UInt64, Setting "filesystem_prefetch_step_marks" UInt64, Setting "filesystem_prefetches_limit" UInt64, Setting "use_structure_from_insertion_table_in_table_functions" UInt64, Setting "http_max_tries" UInt64, Setting "http_retry_initial_backoff_ms" UInt64, Setting "http_retry_max_backoff_ms" UInt64, Setting "max_streams_for_merge_tree_reading" UInt64, Setting "compatibility" ChString, Setting "additional_result_filter" ChString, Setting "workload" ChString, Setting "rename_files_after_processing" ChString, Setting "distributed_cache_connect_max_tries" UInt64, Setting "distributed_cache_read_request_max_tries" UInt64, Setting "distributed_cache_receive_response_wait_milliseconds" UInt64, Setting "distributed_cache_receive_timeout_milliseconds" UInt64, Setting "distributed_cache_wait_connection_from_pool_milliseconds" UInt64, Setting "distributed_cache_alignment" UInt64, Setting "distributed_cache_max_unacked_inflight_packets" UInt64, Setting "distributed_cache_data_packet_ack_window" UInt64, Setting "distributed_cache_min_bytes_for_seek" UInt64, Setting "distributed_cache_credentials_refresh_period_seconds" UInt64, Setting "write_through_distributed_cache_buffer_size" UInt64, Setting "distributed_cache_connect_backoff_min_ms" UInt64, Setting "distributed_cache_connect_backoff_max_ms" UInt64, Setting "distributed_cache_connect_timeout_ms" UInt64, Setting "distributed_cache_receive_timeout_ms" UInt64, Setting "distributed_cache_send_timeout_ms" UInt64, Setting "distributed_cache_tcp_keep_alive_timeout_ms" UInt64, Setting "insert_deduplication_token" ChString, Setting "keeper_max_retries" UInt64, Setting "keeper_retry_initial_backoff_ms" UInt64, Setting "keeper_retry_max_backoff_ms" UInt64, Setting "insert_keeper_max_retries" UInt64, Setting "insert_keeper_retry_initial_backoff_ms" UInt64, Setting "insert_keeper_retry_max_backoff_ms" UInt64, Setting "insert_keeper_fault_injection_seed" UInt64, Setting "http_max_request_param_data_size" UInt64, Setting "default_view_definer" ChString, Setting "cache_warmer_threads" UInt64, Setting "parallel_replicas_count" UInt64, Setting "parallel_replica_offset" UInt64, Setting "parallel_replicas_custom_key" ChString, Setting "parallel_replicas_custom_key_range_lower" UInt64, Setting "parallel_replicas_custom_key_range_upper" UInt64, Setting "cluster_for_parallel_replicas" ChString, Setting "parallel_replicas_min_number_of_rows_per_replica" UInt64, Setting "parallel_replicas_mark_segment_size" UInt64, Setting "max_limit_for_vector_search_queries" UInt64, Setting "hnsw_candidate_list_size_for_search" UInt64, Setting "implicit_table_at_top_level" ChString, Setting "merge_table_max_tables_to_look_for_schema_inference" UInt64, Setting "max_autoincrement_series" UInt64, Setting "parallel_hash_join_threshold" UInt64, Setting "iceberg_insert_max_rows_in_data_file" UInt64, Setting "iceberg_insert_max_bytes_in_data_file" UInt64, Setting "min_outstreams_per_resize_after_split" UInt64, Setting "function_date_trunc_return_type_behavior" UInt64, Setting "join_to_sort_minimum_perkey_rows" UInt64, Setting "join_to_sort_maximum_table_rows" UInt64, Setting "iceberg_metadata_compression_method" ChString, Setting "distributed_plan_default_shuffle_join_bucket_count" UInt64, Setting "distributed_plan_default_reader_bucket_count" UInt64, Setting "distributed_plan_force_exchange_kind" ChString, Setting "distributed_plan_max_rows_to_broadcast" UInt64, Setting "join_runtime_filter_exact_values_limit" UInt64, Setting "join_runtime_bloom_filter_bytes" UInt64, Setting "join_runtime_bloom_filter_hash_functions" UInt64, Setting "promql_database" ChString, Setting "promql_table" ChString ]