mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-21 23:21:59 +00:00
Fix tests
This commit is contained in:
parent
cb488681eb
commit
e290745fe1
@ -1,4 +1,5 @@
|
||||
set allow_experimental_variant_type=1;
|
||||
set allow_suspicious_types_in_order_by=1;
|
||||
|
||||
create table test (v1 Variant(String, UInt64, Array(UInt32)), v2 Variant(String, UInt64, Array(UInt32))) engine=Memory;
|
||||
|
||||
|
@ -1,4 +1,5 @@
|
||||
set allow_experimental_dynamic_type = 1;
|
||||
set allow_suspicious_types_in_order_by=1;
|
||||
|
||||
drop table if exists test;
|
||||
create table test (d1 Dynamic(max_types=2), d2 Dynamic(max_types=2)) engine=Memory;
|
||||
|
@ -1,6 +1,7 @@
|
||||
set allow_experimental_variant_type = 1;
|
||||
set use_variant_as_common_type = 1;
|
||||
set allow_experimental_dynamic_type = 1;
|
||||
set allow_suspicious_types_in_order_by = 1;
|
||||
|
||||
drop table if exists test;
|
||||
|
||||
|
@ -1,6 +1,7 @@
|
||||
set allow_experimental_variant_type = 1;
|
||||
set use_variant_as_common_type = 1;
|
||||
set allow_experimental_dynamic_type = 1;
|
||||
set allow_suspicious_types_in_order_by = 1;
|
||||
|
||||
drop table if exists test;
|
||||
|
||||
|
@ -1,4 +1,5 @@
|
||||
set allow_experimental_variant_type=1;
|
||||
set allow_suspicious_types_in_order_by=1;
|
||||
drop table if exists test;
|
||||
create table test (id UInt64, v Variant(UInt64, String)) engine=MergeTree order by (id, v);
|
||||
insert into test values (1, 1), (1, 'str_1'), (1, 2), (1, 'str_2');
|
||||
|
@ -1,4 +1,5 @@
|
||||
SET allow_experimental_dynamic_type=1;
|
||||
SET allow_suspicious_types_in_order_by=1;
|
||||
|
||||
DROP TABLE IF EXISTS null_table;
|
||||
CREATE TABLE null_table
|
||||
|
@ -1,5 +1,5 @@
|
||||
SET allow_experimental_dynamic_type=1;
|
||||
set min_compress_block_size = 585572, max_compress_block_size = 373374, max_block_size = 60768, max_joined_block_size_rows = 18966, max_insert_threads = 5, max_threads = 50, max_read_buffer_size = 708232, connect_timeout_with_failover_ms = 2000, connect_timeout_with_failover_secure_ms = 3000, idle_connection_timeout = 36000, use_uncompressed_cache = true, stream_like_engine_allow_direct_select = true, replication_wait_for_inactive_replica_timeout = 30, compile_aggregate_expressions = false, min_count_to_compile_aggregate_expression = 0, compile_sort_description = false, group_by_two_level_threshold = 1000000, group_by_two_level_threshold_bytes = 12610083, enable_memory_bound_merging_of_aggregation_results = false, min_chunk_bytes_for_parallel_parsing = 18769830, merge_tree_coarse_index_granularity = 12, min_bytes_to_use_direct_io = 10737418240, min_bytes_to_use_mmap_io = 10737418240, log_queries = true, insert_quorum_timeout = 60000, merge_tree_read_split_ranges_into_intersecting_and_non_intersecting_injection_probability = 0.05000000074505806, http_response_buffer_size = 294986, fsync_metadata = true, http_send_timeout = 60., http_receive_timeout = 60., opentelemetry_start_trace_probability = 0.10000000149011612, max_bytes_before_external_group_by = 1, max_bytes_before_external_sort = 10737418240, max_bytes_before_remerge_sort = 1326536545, max_untracked_memory = 1048576, memory_profiler_step = 1048576, log_comment = '03151_dynamic_type_scale_max_types.sql', send_logs_level = 'fatal', prefer_localhost_replica = false, optimize_read_in_order = false, optimize_aggregation_in_order = true, aggregation_in_order_max_block_bytes = 27069500, read_in_order_two_level_merge_threshold = 75, allow_introspection_functions = true, database_atomic_wait_for_drop_and_detach_synchronously = true, remote_filesystem_read_method = 'read', local_filesystem_read_prefetch = true, remote_filesystem_read_prefetch = false, merge_tree_compact_parts_min_granules_to_multibuffer_read = 119, async_insert_busy_timeout_max_ms = 5000, read_from_filesystem_cache_if_exists_otherwise_bypass_cache = true, filesystem_cache_segments_batch_size = 10, use_page_cache_for_disks_without_file_cache = true, page_cache_inject_eviction = true, allow_prefetched_read_pool_for_remote_filesystem = false, filesystem_prefetch_step_marks = 50, filesystem_prefetch_min_bytes_for_single_read_task = 16777216, filesystem_prefetch_max_memory_usage = 134217728, filesystem_prefetches_limit = 10, optimize_sorting_by_input_stream_properties = false, allow_experimental_dynamic_type = true, session_timezone = 'Africa/Khartoum', prefer_warmed_unmerged_parts_seconds = 2;
|
||||
SET allow_suspicious_types_in_order_by=1;
|
||||
|
||||
drop table if exists to_table;
|
||||
|
||||
|
@ -1,5 +1,6 @@
|
||||
SET allow_experimental_dynamic_type=1;
|
||||
SET allow_experimental_variant_type=1;
|
||||
SET allow_suspicious_types_in_order_by=1;
|
||||
|
||||
CREATE TABLE test_variable (v Variant(String, UInt32, IPv6, Bool, DateTime64)) ENGINE = Memory;
|
||||
CREATE TABLE test_dynamic (d Dynamic) ENGINE = Memory;
|
||||
|
@ -3,7 +3,7 @@
|
||||
SET allow_experimental_dynamic_type=1;
|
||||
SET allow_experimental_variant_type=1;
|
||||
SET allow_suspicious_low_cardinality_types=1;
|
||||
|
||||
SET allow_suspicious_types_in_order_by=1;
|
||||
|
||||
CREATE TABLE t (d Dynamic(max_types=254)) ENGINE = Memory;
|
||||
-- Integer types: signed and unsigned integers (UInt8, UInt16, UInt32, UInt64, UInt128, UInt256, Int8, Int16, Int32, Int64, Int128, Int256)
|
||||
|
@ -1,4 +1,5 @@
|
||||
SET allow_experimental_dynamic_type=1;
|
||||
SET allow_suspicious_types_in_order_by=1;
|
||||
|
||||
CREATE TABLE t (d Dynamic) ENGINE = Memory;
|
||||
|
||||
|
@ -1,4 +1,5 @@
|
||||
SET allow_experimental_dynamic_type=1;
|
||||
SET allow_suspicious_types_in_order_by=1;
|
||||
SELECT if(number % 2, number::Dynamic(max_types=3), ('str_' || toString(number))::Dynamic(max_types=2)) AS d, toTypeName(d), dynamicType(d) FROM numbers(4);
|
||||
CREATE TABLE dynamic_test_1 (d Dynamic(max_types=3)) ENGINE = Memory;
|
||||
INSERT INTO dynamic_test_1 VALUES ('str_1'), (42::UInt64);
|
||||
|
@ -1,4 +1,5 @@
|
||||
set allow_experimental_dynamic_type=1;
|
||||
set allow_suspicious_types_in_group_by=1;
|
||||
set cast_keep_nullable=1;
|
||||
SELECT toFixedString('str', 3), 3, CAST(if(1 = 0, toInt8(3), NULL), 'Int32') AS x from numbers(10) GROUP BY GROUPING SETS ((CAST(toInt32(1), 'Int32')), ('str', 3), (CAST(toFixedString('str', 3), 'Dynamic')), (CAST(toFixedString(toFixedString('str', 3), 3), 'Dynamic')));
|
||||
|
||||
|
@ -1,4 +1,5 @@
|
||||
SET allow_experimental_dynamic_type = 1;
|
||||
SET allow_suspicious_types_in_order_by = 1;
|
||||
DROP TABLE IF EXISTS t0;
|
||||
DROP TABLE IF EXISTS t1;
|
||||
CREATE TABLE t0 (c0 Int) ENGINE = AggregatingMergeTree() ORDER BY (c0);
|
||||
|
Loading…
Reference in New Issue
Block a user