citus/src/test/regress/sql
Onder Kalaci fc9a23792c COPY uses adaptive connection management on local node
With #4338, the executor is smart enough to failover to
local node if there is not enough space in max_connections
for remote connections.

For COPY, the logic is different. With #4034, we made COPY
work with the adaptive connection management slightly
differently. The cause of the difference is that COPY doesn't
know which placements are going to be accessed hence requires
to get connections up-front.

Similarly, COPY decides to use local execution up-front.

With this commit, we change the logic for COPY on local nodes:

Try to reserve a connection to local host. This logic follows
the same logic (e.g., citus.local_shared_pool_size) as the
executor because COPY also relies on TryToIncrementSharedConnectionCounter().
If reservation to local node fails, switch to local execution
Apart from this, if local execution is disabled, we follow the
exact same logic for multi-node Citus. It means that if we are
out of the connection, we'd give an error.
2021-02-04 09:45:07 +01:00
..
.gitignore Columnar: rename block to chunk 2020-12-03 08:50:19 -08:00
adaptive_executor.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
adaptive_executor_repartition.sql Fix partition column index issue (#4591) 2021-01-29 14:40:40 +03:00
add_coordinator.sql Replicate reference tables to coordinator. 2019-11-15 05:50:19 -08:00
aggregate_support.sql Distribute custom aggregates with multiple arguments (#4047) 2020-07-24 15:16:00 -07:00
alter_distributed_table.sql Fix dropping materialized views while doing alter table 2021-01-27 16:32:09 +03:00
alter_index.sql Add alter index set statistics support (#4455) 2021-01-05 13:23:11 +03:00
alter_role_propagation.sql Don't propagate ALTER ROLE SET when scoped to a different database (#4471) 2021-02-01 15:49:26 +03:00
alter_table_set_access_method.sql Disallow using alter_table udfs with tables having any identity cols (#4635) 2021-02-03 19:33:54 +03:00
am_alter.sql Columnar: Fix ALTER TABLE ... ADD COLUMN. 2021-02-01 11:40:17 -08:00
am_alter_set_type.sql Fix ALTER COLUMN ... SET TYPE for columnar 2020-11-19 15:36:45 -08:00
am_analyze.sql Columnar: Fix ANALYZE for large number of rows. 2020-12-10 09:52:33 -08:00
am_clean.sql move columnar test files 2020-11-17 18:55:34 +01:00
am_create.sql Only allow columnar tables with permanent storage (#4492). (#4495) 2021-01-13 10:37:34 -08:00
am_drop.sql More meaningful columnar metadata table names 2021-01-21 21:29:07 -08:00
am_empty.sql fix NaN cost estimate on empty columnar tables (#4593) 2021-01-27 17:32:17 +01:00
am_indexes.sql Columnar: disallow CREATE INDEX CONCURRENTLY 2021-02-03 12:10:00 -08:00
am_insert.sql Columnar: optimize write path. 2021-01-25 11:47:21 -08:00
am_join.sql rename cstore_tableam -> columnar 2020-11-19 12:15:51 -08:00
am_lz4.sql Columnar: enable zstd & lz4 compilation by default (#4402) 2020-12-21 12:11:58 -08:00
am_matview.sql More meaningful columnar metadata table names 2021-01-21 21:29:07 -08:00
am_memory.sql Rename cstore->columnar in SQL objects and errors. 2020-12-07 13:01:53 -08:00
am_query.sql Columnar: Fix lateral joins 2021-02-01 11:59:36 -08:00
am_recursive.sql More meaningful columnar metadata table names 2021-01-21 21:29:07 -08:00
am_rollback.sql More meaningful columnar metadata table names 2021-01-21 21:29:07 -08:00
am_tableoptions.sql Columnar: set default compression as zstd if available 2020-12-09 14:32:08 -08:00
am_transactions.sql rename cstore_tableam -> columnar 2020-11-19 12:15:51 -08:00
am_trigger.sql Stronger check for triggers on columnar tables (#4493). (#4494) 2021-01-13 10:30:53 -08:00
am_truncate.sql More meaningful columnar metadata table names 2021-01-21 21:29:07 -08:00
am_update_delete.sql Add tests for unsupported columnar storage features (#4397) 2020-12-09 00:08:45 -08:00
am_vacuum.sql More meaningful columnar metadata table names 2021-01-21 21:29:07 -08:00
am_zstd.sql Columnar: enable zstd & lz4 compilation by default (#4402) 2020-12-21 12:11:58 -08:00
anonymous_columns.sql fix sorting on string litteral (#4045) 2020-07-20 17:39:27 +02:00
auto_undist_citus_local.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
base_enable_mx.sql Add make check-base-mx 2019-09-13 17:19:35 +02:00
binary_protocol.sql Show amount of data received in EXPLAIN ANALYZE (#3901) 2020-06-15 16:01:05 +02:00
bool_agg.sql Use expressions in the ORDER BY in bool_agg 2018-02-27 23:52:44 +01:00
ch_bench_having.sql normalize some output and sort test result 2020-08-04 15:18:27 +03:00
ch_bench_having_mx.sql sort result in ch_bench_having_mx test 2020-08-04 15:10:22 +03:00
ch_bench_subquery_repartition.sql Add more failing tests, of which some have bad error messages 2020-01-16 18:30:30 +01:00
chbenchmark_all_queries.sql Replace flaky repartition analyze test with a non flaky one (#3950) 2020-06-25 15:19:15 +02:00
citus_local_dist_joins.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
citus_local_table_triggers.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
citus_local_tables.sql Disallow adding local table with identity column to metadata (#4633) 2021-02-03 19:05:17 +03:00
citus_local_tables_mx.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
citus_local_tables_queries.sql Add fkeys between citus local and reference tables in some tests (#4546) 2021-01-20 19:30:20 +03:00
citus_local_tables_queries_mx.sql Add fkeys between citus local and reference tables in some tests (#4546) 2021-01-20 19:30:20 +03:00
citus_table_triggers.sql Extend citus local table utility command support 2020-09-09 11:50:55 +03:00
columnar_citus_integration.sql Fix #4608 2021-02-01 16:23:16 -08:00
columnar_fallback_scan.sql Columnar: always disable parallel paths. (#4617) 2021-02-02 11:37:42 -08:00
columnar_partitioning.sql Columnar: fix inheritance planning. 2021-02-03 10:41:21 -08:00
coordinator_evaluation.sql Fix a crash with inserting domain composite types in coord. evaluation (#4231) 2020-10-13 14:19:59 +03:00
coordinator_evaluation_modify.sql Rename master evaluation to coordinator evaluation 2020-07-07 10:37:41 +02:00
coordinator_evaluation_select.sql Rename master evaluation to coordinator evaluation 2020-07-07 10:37:41 +02:00
coordinator_shouldhaveshards.sql Consider coordinator in intermediate result optimization 2021-02-03 20:02:03 +03:00
create_citus_local_table_cascade.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
create_ref_dist_from_citus_local.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
cross_join.sql Add regression tests for outer/cross JOINs 2020-10-14 15:17:30 +02:00
cte_inline.sql Support co-located/recurring sublinks in the target list 2020-12-13 15:45:24 +01:00
cte_nested_modification.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
cte_prepared_modify.sql Implement recursive planning for DML statements 2018-05-03 14:42:28 +02:00
cursors.sql Do not execute subplans multiple times with cursors 2020-11-20 10:43:56 +01:00
custom_aggregate_support.sql Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
data_types.sql Add regression tests with different data types 2020-12-04 10:25:00 +03:00
disable_object_propagation.sql Add jobs to run tests with pg 12 (#3033) 2019-10-02 15:33:12 +03:00
distributed_collations.sql Add distributioncolumncollation to to pg_dist_colocation 2019-12-09 19:51:40 +00:00
distributed_collations_conflict.sql Support creating collations as part of dependency resolution. Propagate ALTER/DROP on distributed collations 2019-12-09 04:42:51 +00:00
distributed_functions.sql Allow distribution of functions that read from reference tables 2020-09-01 07:28:34 +03:00
distributed_functions_conflict.sql create_distributed_function: accept aggregates 2019-11-06 18:23:37 +00:00
distributed_intermediate_results.sql Test RedistributeTaskListResult 2020-01-09 23:47:25 -08:00
distributed_procedure.sql not wait forever for metadata sync in tests (#3760) 2020-05-14 10:51:24 +03:00
distributed_types.sql Disallow field indirection in INSERT/UPDATE queries (#4241) 2020-10-14 14:11:59 +03:00
distributed_types_conflict.sql Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
distributed_types_xact_add_enum_value.sql Fix enum add value order and pg12 (#3082) 2019-10-07 17:16:19 +02:00
dml_recursive.sql Adjust the existing regression tests 2020-12-15 18:17:10 +03:00
ensure_no_intermediate_data_leak.sql test that we don't leak intermediate schemas (#3737) 2020-04-09 12:17:41 +03:00
ensure_no_shared_connection_leak.sql Temporarily disable connection leak tests that fail a lot (#3911) 2020-06-16 13:48:48 +02:00
escape_extension_name.sql Split propagate extension test and add alternative output (#3314) 2019-12-17 13:49:16 +03:00
expression_reference_join.sql Allow cartesian products on reference tables 2019-12-27 15:05:51 +01:00
failure_1pc_copy_append.sql SortList in FinalizedShardPlacementList, makes 3 failure tests consistent between 11/12 2019-08-22 19:30:56 +00:00
failure_1pc_copy_hash.sql Introduce the adaptive executor (#2798) 2019-06-28 14:04:40 +02:00
failure_add_disable_node.sql GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
failure_connection_establishment.sql Fix flappy failure test 2020-12-03 13:54:02 +01:00
failure_copy_on_hash.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
failure_copy_to_reference.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
failure_create_distributed_table_non_empty.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
failure_create_index_concurrently.sql Rethrow original concurrent index creation failure message (#4469) 2021-01-06 15:27:13 +03:00
failure_create_reference_table.sql Distribute Types to worker nodes (#2893) 2019-09-13 17:46:07 +02:00
failure_create_table.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
failure_cte_subquery.sql Locally execute queries that don't need any data access (#3410) 2020-01-23 18:28:34 +01:00
failure_ddl.sql Flaky test: Fix recover_prepared_transactions (#3205) 2019-11-19 17:49:13 +01:00
failure_distributed_results.sql Local node connection management 2020-12-03 14:16:13 +03:00
failure_failover_to_local_execution.sql Local node connection management 2020-12-03 14:16:13 +03:00
failure_insert_select_pushdown.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
failure_insert_select_repartition.sql Failure tests for INSERT/SELECT repartition 2020-01-16 23:24:52 -08:00
failure_insert_select_via_coordinator.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
failure_multi_dml.sql Modify tests to be consistent between versions 2019-08-22 19:30:50 +00:00
failure_multi_row_insert.sql not continue in sequential execution if a cancellation is received (#3289) 2019-12-12 17:22:30 +03:00
failure_multi_shard_update_delete.sql Make sure that tests are not failing randomly 2020-04-07 17:06:55 +02:00
failure_mx_metadata_sync.sql Failure&cancellation tests for mx metadata sync 2019-02-01 11:50:25 +03:00
failure_parallel_connection.sql Add failure test for parallel reference table join 2020-02-03 19:35:07 +01:00
failure_ref_tables.sql Add reference table failure tests 2018-10-09 09:39:30 -07:00
failure_replicated_partitions.sql Make sure to update shard states of partitions on failures 2020-01-06 12:26:08 +01:00
failure_savepoints.sql Check connections from connection_placement before polling 2020-04-06 17:45:44 +00:00
failure_setup.sql Prevent failure tests from hanging by using a port outside the ephemeral port range 2018-07-31 14:30:56 -07:00
failure_single_mod.sql Add single-shard modification failure tests 2018-10-23 23:31:40 +01:00
failure_single_select.sql SortList in FinalizedShardPlacementList, makes 3 failure tests consistent between 11/12 2019-08-22 19:30:56 +00:00
failure_test_helpers.sql Local node connection management 2020-12-03 14:16:13 +03:00
failure_truncate.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
failure_vacuum.sql Remove Postgres 10 support 2019-10-11 21:56:56 +00:00
fast_path_router_modify.sql Defer shard pruning for fast-path router queries to execution 2020-01-16 16:59:36 +01:00
fkeys_between_local_ref.sql Convert postgres tables to citus local when creating reference table having fkeys 2021-01-25 11:02:50 +03:00
follower_single_node.sql Add simple follower test for columnar. (#4432) 2020-12-18 13:59:20 -08:00
foreign_key_restriction_enforcement.sql Adds ORDER BY to flaky test (#4305) 2020-12-02 14:24:05 +03:00
foreign_key_to_reference_shard_rebalance.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
foreign_key_to_reference_table.sql Update foreign_key_to_reference_table so that test output doesn't change 2021-01-25 11:03:39 +03:00
geqo.sql Turn RelOptInfos to only used field of them, relids, to be able to copy 2020-10-22 13:42:28 +03:00
grant_on_schema_propagation.sql Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
having_subquery.sql Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
insert_select_connection_leak.sql Shorten insert_select_connection_leak_test 2020-09-18 10:07:15 +03:00
insert_select_into_local_table.sql Insert Select Into Local Table (#3870) 2020-06-12 17:06:31 +03:00
insert_select_repartition.sql Fix crash caused by EXPLAIN EXECUTE INSERT ... SELECT 2020-06-25 08:55:48 -07:00
intermediate_result_pruning.sql Fix intermediate result pruning for INSERT..SELECT 2020-04-07 11:07:49 +02:00
intermediate_results.sql Issue worker messages with the same log level 2020-04-14 21:08:25 +02:00
join_pushdown.sql rework ci 2020-12-18 18:04:45 +01:00
limit_intermediate_size.sql Local execution considers intermediate result size limit 2020-10-15 17:18:55 +02:00
local_dist_join_mixed.sql Fix attribute numbers in subquery conversions (#4426) 2020-12-18 20:25:41 +03:00
local_dist_join_modifications.sql Use BaseRestrictInfo for finding equality columns 2020-12-15 18:18:36 +03:00
local_shard_copy.sql Consider coordinator in intermediate result optimization 2021-02-03 20:02:03 +03:00
local_shard_execution.sql Support local execution for INSERT..SELECT with re-partitioning 2021-01-06 16:15:53 +01:00
local_shard_utility_command_execution.sql Record non-distributed table accesses in local executor (#4139) 2020-09-07 18:19:08 +03:00
local_table_join.sql Fix attribute numbers in subquery conversions (#4426) 2020-12-18 20:25:41 +03:00
locally_execute_intermediate_results.sql Expose partition column of subqueries in optimizer (#4355) 2020-12-18 20:32:52 +01:00
master_copy_shard_placement.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
materialized_view.sql Make sure that materialized views that contains only (#4499) 2021-01-13 13:17:43 +03:00
mixed_relkind_tests.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
multi_agg_approximate_distinct.sql Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_alter_table_add_constraints.sql Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_array_agg.sql Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_average_expression.sql Remove ALTER SEQUENCE from parallel groups 2017-05-16 11:05:34 -06:00
multi_basic_queries.sql Remove ALTER SEQUENCE from parallel groups 2017-05-16 11:05:34 -06:00
multi_behavioral_analytics_basics.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_behavioral_analytics_single_shard_queries.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_cache_invalidation.sql Fix inconsistent shard metadata issue 2019-12-24 08:01:32 +01:00
multi_citus_tools.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_cluster_management.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
multi_colocated_shard_rebalance.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
multi_colocated_shard_transfer.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_colocation_utils.sql Replace to update_distributed_table_colocation for tests 2021-01-20 17:30:06 +03:00
multi_complex_expressions.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_count_type_conversion.sql Remove ALTER SEQUENCE from parallel groups 2017-05-16 11:05:34 -06:00
multi_create_fdw.sql Use citus.next_shard_id where practical in regression tests 2017-11-15 10:12:05 +01:00
multi_create_shards.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_create_table.sql Recreate invalidation functions for Citus10 2021-01-13 23:18:07 +03:00
multi_create_table_constraints.sql Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_create_table_new_features.sql Add a CI check to see if all tests are part of a schedule (#3959) 2020-07-03 11:34:55 +02:00
multi_create_table_superuser.sql Adds next shard ids to multi_create_table tests 2020-04-10 15:54:47 +03:00
multi_cross_shard.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_data_types.sql Fix write queries with const expressions and COLLATE in various places (#3973) 2020-07-08 18:19:53 +02:00
multi_deparse_function.sql Properly escape ALTER FUNCTION .. SET deparsing. Also test 2019-11-25 23:01:30 +00:00
multi_deparse_procedure.sql Remove Postgres 10 support 2019-10-11 21:56:56 +00:00
multi_deparse_shard_query.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_distributed_transaction_id.sql Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_distribution_metadata.sql Rename RelayFileState to ShardState 2020-01-12 05:57:53 +00:00
multi_drop_extension.sql Replace to update_distributed_table_colocation for tests 2021-01-20 17:30:06 +03:00
multi_dropped_column_aliases.sql Use citus.next_shard_id where practical in regression tests 2017-11-15 10:12:05 +01:00
multi_explain.sql Sort explain analyze output by task time 2020-09-24 11:38:40 +03:00
multi_extension.sql Collapse Citus 7.* scripts into Citus 8.0-1 2020-12-21 22:55:51 +01:00
multi_follower_configure_followers.sql Add regression tests for follower clusters 2017-08-12 12:05:56 +02:00
multi_follower_dml.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
multi_follower_sanity_check.sql Add regression tests for follower clusters 2017-08-12 12:05:56 +02:00
multi_follower_select_statements.sql rework ci 2020-12-18 18:04:45 +01:00
multi_foreign_key.sql decrease log level to debug1 to prevent flaky debug 2020-08-04 15:18:27 +03:00
multi_foreign_key_relation_graph.sql Fix fkey graph test for self reference (#4450) 2020-12-28 12:47:39 +03:00
multi_function_evaluation.sql citus_evaluate_expression: call expand_function_arguments beforehand to avoid segfaulting on implicit parameters 2020-06-23 18:06:46 +00:00
multi_function_in_join.sql Add alternative output for multi_function_in_join 2020-08-04 15:18:27 +03:00
multi_generate_ddl_commands.sql propagation of CHECK statements to workers with parentheses (#4039) 2020-07-27 15:08:37 +03:00
multi_hash_pruning.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_having_pushdown.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_index_statements.sql Support CREATE INDEX commands without index name on citus tables (#4273) 2020-12-23 23:15:39 +03:00
multi_insert_select.sql Adds support for table undistribution 2020-08-05 14:36:03 +03:00
multi_insert_select_conflict.sql Update multi_insert_select_conflict 2020-02-03 13:13:30 -08:00
multi_insert_select_non_pushable_queries.sql Insert Select Into Local Table (#3870) 2020-06-12 17:06:31 +03:00
multi_insert_select_window.sql Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
multi_join_order_additional.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_join_order_tpch_repartition.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_join_order_tpch_small.sql Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_join_pruning.sql Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_json_agg.sql Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_json_object_agg.sql Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_jsonb_agg.sql Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_jsonb_object_agg.sql Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_limit_clause.sql Correctly handle non-constant LIMIT/OFFSET clauses 2020-04-09 19:59:50 +00:00
multi_limit_clause_approximate.sql Expand the set of aggregates which cannot have LIMIT approximated 2020-01-30 17:45:18 +00:00
multi_master_protocol.sql Modify tests to be consistent between versions 2019-08-22 19:30:50 +00:00
multi_metadata_access.sql Use citus.next_shard_id where practical in regression tests 2017-11-15 10:12:05 +01:00
multi_metadata_attributes.sql Add shouldhaveshards to pg_dist_node (#2960) 2019-10-22 16:47:16 +02:00
multi_metadata_sync.sql Replace to update_distributed_table_colocation for tests 2021-01-20 17:30:06 +03:00
multi_modifications.sql Adjust the existing regression tests 2020-12-15 18:17:10 +03:00
multi_modifying_xacts.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_move_mx.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
multi_multiuser.sql Replace to update_distributed_table_colocation for tests 2021-01-20 17:30:06 +03:00
multi_mx_add_coordinator.sql Allow distribution of functions that read from reference tables 2020-09-01 07:28:34 +03:00
multi_mx_alter_distributed_table.sql Rename citus_tables column names to be query-friendly 2021-01-21 18:58:30 +01:00
multi_mx_call.sql Allow distribution of functions that read from reference tables 2020-09-01 07:28:34 +03:00
multi_mx_create_table.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
multi_mx_ddl.sql Fix distributing tables owned by extensions 2020-09-10 04:46:11 +02:00
multi_mx_explain.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_function_call_delegation.sql Support use of binary protocol in between nodes (#3877) 2020-06-12 15:02:51 +02:00
multi_mx_function_table_reference.sql Allow distribution of functions that read from reference tables 2020-09-01 07:28:34 +03:00
multi_mx_hide_shard_names.sql Add shouldhaveshards to pg_dist_node (#2960) 2019-10-22 16:47:16 +02:00
multi_mx_insert_select_repartition.sql Support local execution for INSERT..SELECT with re-partitioning 2021-01-06 16:15:53 +01:00
multi_mx_metadata.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
multi_mx_modifications.sql Fix: distributed function with table reference in declare (#3384) 2020-01-16 14:21:54 +01:00
multi_mx_modifications_to_reference_tables.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_modifying_xacts.sql Introduce the concept of Local Execution 2019-09-12 11:51:25 +02:00
multi_mx_node_metadata.sql Reland #4419 2021-01-19 07:48:47 -08:00
multi_mx_partitioning.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_reference_table.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_join_w1.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_join_w2.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_udt_prepare.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_mx_repartition_udt_w1.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_udt_w2.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_router_planner.sql Address review feedback 2020-12-15 15:23:38 +01:00
multi_mx_schema_support.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_tpch_query1.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_tpch_query3.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_tpch_query6.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_mx_tpch_query7.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_mx_tpch_query7_nested.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_tpch_query10.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_tpch_query12.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_mx_tpch_query14.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_mx_tpch_query19.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_mx_transaction_recovery.sql Introduce the concept of Local Execution 2019-09-12 11:51:25 +02:00
multi_mx_truncate_from_worker.sql enable local execution in INSERT..SELECT and add more tests 2020-03-18 09:34:39 +03:00
multi_name_lengths.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
multi_name_resolution.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_null_minmax_value_pruning.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_orderby_limit_pushdown.sql Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_partition_pruning.sql Fix typos: 2019-11-25 23:24:13 +00:00
multi_partitioning.sql Introduce UDFs for fixing partitioned table constraint names 2021-01-29 17:32:20 +03:00
multi_partitioning_utils.sql Introduce UDFs for fixing partitioned table constraint names 2021-01-29 17:32:20 +03:00
multi_prepare_plsql.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_prepare_sql.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_prune_shard_list.sql Coerce types properly for INSERT 2020-06-10 10:40:28 +02:00
multi_query_directory_cleanup.sql citus_rm_job_directory for multi_query_directory_cleanup 2019-08-19 17:04:42 +00:00
multi_read_from_secondaries.sql Delete transactions when removing node 2020-12-07 11:35:20 +03:00
multi_real_time_transaction.sql Add tests that exercise parallel reference table join logic 2020-02-03 11:54:29 +01:00
multi_reference_table.sql Replace to update_distributed_table_colocation for tests 2021-01-20 17:30:06 +03:00
multi_remove_node_reference_table.sql Delete transactions when removing node 2020-12-07 11:35:20 +03:00
multi_repair_shards.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_repartition_join_planning.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_repartition_join_pruning.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_repartition_join_ref.sql Add tests for complex joins on reference tables 2019-12-27 15:05:51 +01:00
multi_repartition_join_task_assignment.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_repartition_udt.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_repartitioned_subquery_udf.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_replicate_reference_table.sql Automatically add placeholder record for coordinator 2021-01-08 15:09:53 +01:00
multi_router_planner.sql Add tests for router queries with catalog tables (#4422) 2020-12-17 15:07:50 +01:00
multi_router_planner_fast_path.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
multi_row_insert.sql Add ORDER BY to multi_row_insert.sql 2020-01-16 15:20:39 -08:00
multi_row_router_insert.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
multi_schema_support.sql Add tests for propagating alter schema rename 2020-12-02 15:18:26 +03:00
multi_select_distinct.sql Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
multi_select_for_update.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_shard_update_delete.sql Adjust the existing regression tests 2020-12-15 18:17:10 +03:00
multi_simple_queries.sql Adjust the existing regression tests 2020-12-15 18:17:10 +03:00
multi_single_relation_subquery.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_size_queries.sql Allow citus size functions on replicated tables 2020-12-03 16:33:24 +01:00
multi_sql_function.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_subquery.sql Support co-located/recurring sublinks in the target list 2020-12-13 15:45:24 +01:00
multi_subquery_behavioral_analytics.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_subquery_complex_queries.sql Address review feedback 2020-12-15 15:23:38 +01:00
multi_subquery_complex_reference_clause.sql Add regression tests for outer/cross JOINs 2020-10-14 15:17:30 +02:00
multi_subquery_in_where_clause.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_subquery_in_where_reference_clause.sql Loosen the requirement to pushdown a subquery with ref tables (#4110) 2020-08-14 12:11:15 +03:00
multi_subquery_misc.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_subquery_union.sql Fix potential segfault from standard_planner inlining functions 2019-11-21 18:47:36 +00:00
multi_subquery_window_functions.sql Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
multi_subtransactions.sql Fix Subtransaction memory leak 2020-07-09 12:33:39 -07:00
multi_table_ddl.sql Tests are updated to use create_distributed_table 2018-05-10 11:18:59 +03:00
multi_task_assignment_policy.sql Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_task_string_size.sql Remove unused GUCs 2021-01-15 13:30:45 +03:00
multi_test_catalog_views.sql Test more reference/local cases, also ALTER ROLE 2019-12-03 22:23:14 +00:00
multi_test_helpers.sql Fix relkind checks in planner for relkinds other than RELKIND_RELATION (#4294) 2020-11-05 14:21:02 +03:00
multi_test_helpers_superuser.sql Reland #4419 2021-01-19 07:48:47 -08:00
multi_tpch_query1.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query3.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query6.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query7.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query7_nested.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
multi_tpch_query10.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query12.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query14.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_tpch_query19.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
multi_transaction_recovery.sql Automatically add placeholder record for coordinator 2021-01-08 15:09:53 +01:00
multi_transactional_drop_shards.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
multi_truncate.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
multi_unsupported_worker_operations.sql Replace to update_distributed_table_colocation for tests 2021-01-20 17:30:06 +03:00
multi_upsert.sql Introduce the adaptive executor (#2798) 2019-06-28 14:04:40 +02:00
multi_utilities.sql Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_utility_statements.sql Defer shard pruning for fast-path router queries to execution 2020-01-16 16:59:36 +01:00
multi_utility_warnings.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
multi_view.sql Support reference table view in reference table modification 2020-10-16 11:31:24 +02:00
multi_working_columns.sql Remove ALTER SEQUENCE from parallel groups 2017-05-16 11:05:34 -06:00
mx_coordinator_shouldhaveshards.sql Consider coordinator in intermediate result optimization 2021-02-03 20:02:03 +03:00
mx_foreign_key_to_reference_table.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
node_conninfo_reload.sql Throttle connections to the worker nodes 2020-04-14 10:27:48 +02:00
non_colocated_join_order.sql Removes large_table_shard_count GUC 2018-04-29 10:34:50 +02:00
non_colocated_leaf_subquery_joins.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
non_colocated_subquery_joins.sql Update regression tests-2 2020-01-16 12:28:15 +01:00
null_parameters.sql not log in debug level in null parameters (#3718) 2020-04-06 17:59:46 +03:00
partitioned_intermediate_results.sql Partitioned task list results. 2020-01-09 10:32:58 -08:00
partitioning_issue_3970.sql Limit shardId in partitioned table constraint names to only CHECK 2021-01-29 17:29:53 +03:00
pg12.sql Skip copying GENERATED ALWAYS AS STORED cols in ReplaceTable (#4616) 2021-02-03 17:55:16 +03:00
pg13.sql Add subplan test with insert 2020-10-01 13:58:55 +03:00
pg13_propagate_statistics.sql Add separate pg13 test for stats targets 2020-12-24 18:01:25 +03:00
pg13_with_ties.sql Adds support for WITH TIES option 2020-10-12 19:34:18 +03:00
pg_dump.sql Add columnar pg_dump test. (#4433) 2020-12-22 15:57:35 -08:00
propagate_extension_commands.sql GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
propagate_set_commands.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
propagate_statistics.sql Fix assert failure when creating statistics 2021-01-15 19:36:58 +03:00
recursive_dml_queries_mx.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
recursive_dml_with_different_planners_executors.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
recursive_relation_planning_restriction_pushdown.sql Add more tests 2020-12-15 18:18:36 +03:00
recursive_view_local_table.sql Do not rely on set_rel_pathlist_hook for finding local relations 2020-11-06 11:14:30 +01:00
ref_citus_local_fkeys.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
relation_access_tracking.sql Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
remove_coordinator.sql Replicate reference tables to coordinator. 2019-11-15 05:50:19 -08:00
replicate_reference_tables_to_coordinator.sql Add more tests 2020-12-15 18:18:36 +03:00
replicated_partitioned_table.sql Remove Postgres 10 support 2019-10-11 21:56:56 +00:00
rollback_to_savepoint.sql Fix assertion error when rolling back to savepoint (#3868) 2020-06-30 11:31:46 +02:00
row_types.sql RECORD: Add support for more expression types 2019-11-27 17:07:22 +00:00
sequential_modifications.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
set_operation_and_local_tables.sql Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
set_operations.sql Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
set_role_in_transaction.sql Implement shared connection count reservation & enable `citus.max_shared_pool_size` for COPY 2020-08-03 18:51:40 +02:00
shard_move_deferred_delete.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
shard_rebalancer.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
shard_rebalancer_unit.sql Add the shard rebalancer implementation 2021-01-07 16:51:55 +01:00
shared_connection_stats.sql Fix a flaky behaviour in shared_connection_stats (#4596) 2021-01-28 18:42:49 +03:00
single_hash_repartition_join.sql remove task-tracker in comments, documentation 2020-07-21 16:21:01 +03:00
single_node.sql COPY uses adaptive connection management on local node 2021-02-04 09:45:07 +01:00
sql_procedure.sql Remove Postgres 10 support 2019-10-11 21:56:56 +00:00
sqlancer_failures.sql Add intermediate result tests with unsupported outer joins (#4262) 2020-10-20 12:11:18 +03:00
sqlsmith_failures.sql Fix for pruned target list entries (#3818) 2020-05-06 13:56:02 +02:00
ssl_by_default.sql ssl_by_default: remove stray PG10 check 2019-10-23 00:27:54 +00:00
statement_cancel_error_message.sql Fix wrong cancellation message about distributed deadlocks (#3956) 2020-06-30 14:57:46 +02:00
subqueries_deep.sql Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
subqueries_not_supported.sql Update check multi tests 2020-12-15 18:17:10 +03:00
subquery_and_cte.sql Loosen the requirement to pushdown a subquery with ref tables (#4110) 2020-08-14 12:11:15 +03:00
subquery_basics.sql Improve the relation restriction counters 2020-10-19 08:51:16 +02:00
subquery_complex_target_list.sql Make sure we don't wrap GROUP BY expressions in any_value 2020-05-05 05:12:45 +02:00
subquery_executors.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
subquery_in_targetlist.sql Expand support for subqueries in target list through recursive planning 2021-01-13 17:26:09 +01:00
subquery_in_where.sql Address review feedback 2020-12-15 15:23:38 +01:00
subquery_local_tables.sql Add test for issue, does not reproduce issue 2020-02-18 23:45:17 +00:00
subquery_partitioning.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
subquery_prepared_statements.sql Call 6 times not 7 in subquery_prepared_statements (#4357) 2020-11-30 21:20:51 +03:00
subquery_view.sql Add some more tests with views to test recursive planning on views (#4427) 2020-12-21 11:53:37 +03:00
tableam.sql Move local execution after remote execution (#4301) 2020-11-24 13:43:38 +01:00
tdigest_aggregate_support.sql Feature: tdigest aggregate (#3897) 2020-06-12 13:50:28 +02:00
undistribute_table.sql Prevent undistribute_table calls for partitions 2020-11-03 18:10:20 +03:00
undistribute_table_cascade.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
undistribute_table_cascade_mx.sql Rename udf in regression tests (as per prev commit) 2021-01-27 15:52:37 +03:00
upgrade_basic_after.sql Change citus truncate trigger to AFTER and add more upgrade tests (#3070) 2019-10-07 16:43:04 +02:00
upgrade_basic_before.sql Remove the word 'master' from Citus UDFs (#4472) 2021-01-13 12:10:43 +03:00
upgrade_columnar_after.sql more test fixes 2020-12-07 13:36:46 -08:00
upgrade_columnar_before.sql Columnar: Make compression level configurable 2020-12-09 08:48:50 -08:00
upgrade_distributed_function_after.sql Add upgrade test for distributed functions 2019-10-23 12:07:51 +02:00
upgrade_distributed_function_before.sql not wait forever in upgrade distributed function before (#3731) 2020-04-10 09:43:42 +03:00
upgrade_list_citus_objects.sql add pg upgrade tests verifying table am is created 2020-11-17 18:55:36 +01:00
upgrade_partition_constraints_after.sql Introduce UDFs for fixing partitioned table constraint names 2021-01-29 17:32:20 +03:00
upgrade_partition_constraints_before.sql Introduce UDFs for fixing partitioned table constraint names 2021-01-29 17:32:20 +03:00
upgrade_pg_dist_object_test_after.sql Introduce objects to dist. infrastructure when updating Citus (#3477) 2020-02-07 18:07:59 +03:00
upgrade_pg_dist_object_test_before.sql Introduce objects to dist. infrastructure when updating Citus (#3477) 2020-02-07 18:07:59 +03:00
upgrade_rebalance_strategy_after.sql Add the necessary changes for rebalance strategies on enterprise (#3325) 2019-12-19 15:23:08 +01:00
upgrade_rebalance_strategy_before.sql Add the necessary changes for rebalance strategies on enterprise (#3325) 2019-12-19 15:23:08 +01:00
upgrade_ref2ref_after.sql Change citus truncate trigger to AFTER and add more upgrade tests (#3070) 2019-10-07 16:43:04 +02:00
upgrade_ref2ref_before.sql Change citus truncate trigger to AFTER and add more upgrade tests (#3070) 2019-10-07 16:43:04 +02:00
upgrade_type_after.sql upgrade_type_after: ORDER BY 2020-04-01 01:07:21 +00:00
upgrade_type_before.sql Change citus truncate trigger to AFTER and add more upgrade tests (#3070) 2019-10-07 16:43:04 +02:00
validate_constraint.sql Distribute Types to worker nodes (#2893) 2019-09-13 17:46:07 +02:00
window_functions.sql Avoid setting hasWindowFuncs true after window functions have been optimized out of query 2020-04-17 12:22:48 +00:00
with_basics.sql Support co-located/recurring sublinks in the target list 2020-12-13 15:45:24 +01:00
with_dml.sql Update with_dml 2020-02-03 13:13:30 -08:00
with_executors.sql Adjust the existing regression tests 2020-12-15 18:17:10 +03:00
with_join.sql Update regression tests-2 2020-01-16 12:28:15 +01:00
with_modifying.sql Adjust the existing regression tests 2020-12-15 18:17:10 +03:00
with_nested.sql Add missing ORDER BY in a CTE (#3282) 2019-12-11 10:24:54 +01:00
with_partitioning.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
with_prepare.sql Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
with_set_operations.sql Update regression tests-2 2020-01-16 12:28:15 +01:00
with_transactions.sql Forbid using connections that sent intermediate results for data access and vice versa 2019-12-17 11:49:13 +01:00
with_where.sql Strip trailing whitespace and add final newline (#3186) 2019-11-21 14:25:37 +01:00
worker_binary_data_partition.sql Add user ID suffixes to filenames in check-worker tests 2018-11-23 08:36:12 +01:00
worker_create_table.sql Use citus.next_shard_id where practical in regression tests 2017-11-15 10:12:05 +01:00
worker_hash_partition.sql Add user ID suffixes to filenames in check-worker tests 2018-11-23 08:36:12 +01:00
worker_hash_partition_complex.sql Add user ID suffixes to filenames in check-worker tests 2018-11-23 08:36:12 +01:00
worker_merge_hash_files.sql Remove ALTER SEQUENCE from parallel groups 2017-05-16 11:05:34 -06:00
worker_merge_range_files.sql Remove ALTER SEQUENCE from parallel groups 2017-05-16 11:05:34 -06:00
worker_null_data_partition.sql Add user ID suffixes to filenames in check-worker tests 2018-11-23 08:36:12 +01:00
worker_range_partition.sql Add user ID suffixes to filenames in check-worker tests 2018-11-23 08:36:12 +01:00
worker_range_partition_complex.sql Add user ID suffixes to filenames in check-worker tests 2018-11-23 08:36:12 +01:00