citus/src/test/regress/expected
SaitTalhaNisanci b3af63c8ce
Remove task tracker executor (#3850)
* use adaptive executor even if task-tracker is set

* Update check-multi-mx tests for adaptive executor

Basically repartition joins are enabled where necessary. For parallel
tests max adaptive executor pool size is decresed to 2, otherwise we
would get too many clients error.

* Update limit_intermediate_size test

It seems that when we use adaptive executor instead of task tracker, we
exceed the intermediate result size less in the test. Therefore updated
the tests accordingly.

* Update multi_router_planner

It seems that there is one problem with multi_router_planner when we use
adaptive executor, we should fix the following error:
+ERROR:  relation "authors_range_840010" does not exist
+CONTEXT:  while executing command on localhost:57637

* update repartition join tests for check-multi

* update isolation tests for repartitioning

* Error out if shard_replication_factor > 1 with repartitioning

As we are removing the task tracker, we cannot switch to it if
shard_replication_factor > 1. In that case, we simply error out.

* Remove MULTI_EXECUTOR_TASK_TRACKER

* Remove multi_task_tracker_executor

Some utility methods are moved to task_execution_utils.c.

* Remove task tracker protocol methods

* Remove task_tracker.c methods

* remove unused methods from multi_server_executor

* fix style

* remove task tracker specific tests from worker_schedule

* comment out task tracker udf calls in tests

We were using task tracker udfs to test permissions in
multi_multiuser.sql. We should find some other way to test them, then we
should remove the commented out task tracker calls.

* remove task tracker test from follower schedule

* remove task tracker tests from multi mx schedule

* Remove task-tracker specific functions from worker functions

* remove multi task tracker extra schedule

* Remove unused methods from multi physical planner

* remove task_executor_type related things in tests

* remove LoadTuplesIntoTupleStore

* Do initial cleanup for repartition leftovers

During startup, task tracker would call TrackerCleanupJobDirectories and
TrackerCleanupJobSchemas to clean up leftover directories and job
schemas. With adaptive executor, while doing repartitions it is possible
to leak these things as well. We don't retry cleanups, so it is possible
to have leftover in case of errors.

TrackerCleanupJobDirectories is renamed as
RepartitionCleanupJobDirectories since it is repartition specific now,
however TrackerCleanupJobSchemas cannot be used currently because it is
task tracker specific. The thing is that this function is a no-op
currently.

We should add cleaning up intermediate schemas to DoInitialCleanup
method when that problem is solved(We might want to solve it in this PR
as well)

* Revert "remove task tracker tests from multi mx schedule"

This reverts commit 03ecc0a681.

* update multi mx repartition parallel tests

* not error with task_tracker_conninfo_cache_invalidate

* not run 4 repartition queries in parallel

It seems that when we run 4 repartition queries in parallel we get too
many clients error on CI even though we don't get it locally. Our guess
is that, it is because we open/close many connections without doing some
work and postgres has some delay to close the connections. Hence even
though connections are removed from the pg_stat_activity, they might
still not be closed. If the above assumption is correct, it is unlikely
for it to happen in practice because:
- There is some network latency in clusters, so this leaves some times
for connections to be able to close
- Repartition joins return some data and that also leaves some time for
connections to be fully closed.

As we don't get this error in our local, we currently assume that it is
not a bug. Ideally this wouldn't happen when we get rid of the
task-tracker repartition methods because they don't do any pruning and
might be opening more connections than necessary.

If this still gives us "too many clients" error, we can try to increase
the max_connections in our test suite(which is 100 by default).

Also there are different places where this error is given in postgres,
but adding some backtrace it seems that we get this from
ProcessStartupPacket. The backtraces can be found in this link:
https://circleci.com/gh/citusdata/citus/138702

* Set distributePlan->relationIdList when it is needed

It seems that we were setting the distributedPlan->relationIdList after
JobExecutorType is called, which would choose task-tracker if
replication factor > 1 and there is a repartition query. However, it
uses relationIdList to decide if the query has a repartition query, and
since it was not set yet, it would always think it is not a repartition
query and would choose adaptive executor when it should choose
task-tracker.

* use adaptive executor even with shard_replication_factor > 1

It seems that we were already using adaptive executor when
replication_factor > 1. So this commit removes the check.

* remove multi_resowner.c and deprecate some settings

* remove TaskExecution related leftovers

* change deprecated API error message

* not recursively plan single relatition repartition subquery

* recursively plan single relation repartition subquery

* test depreceated task tracker functions

* fix overlapping shard intervals in range-distributed test

* fix error message for citus_metadata_container

* drop task-tracker deprecated functions

* put the implemantation back to worker_cleanup_job_schema_cachesince citus cloud uses it

* drop some functions, add downgrade script

Some deprecated functions are dropped.
Downgrade script is added.
Some gucs are deprecated.
A new guc for repartition joins bucket size is added.

* order by a test to fix flappiness
2020-07-18 13:11:36 +03:00
..
.gitignore update gitignores with new files in test folder (#3749) 2020-04-13 17:09:18 +03:00
adaptive_executor.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
adaptive_executor_repartition.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
add_coordinator.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
aggregate_support.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
alter_role_propagation.out Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
anonymous_columns.out fix flappy tests due to undeterministic order of test output (#4029) 2020-07-14 15:47:29 +02:00
base_enable_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
binary_protocol.out Fix EXPLAIN ANALYZE received data counter issues (#3917) 2020-06-17 11:33:38 +02:00
bool_agg.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
ch_bench_having.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
ch_bench_having_mx.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
ch_bench_subquery_repartition.out Make tests fail with a useful error message 2020-01-16 18:30:30 +01:00
chbenchmark_all_queries.out Replace flaky repartition analyze test with a non flaky one (#3950) 2020-06-25 15:19:15 +02:00
coordinator_evaluation.out Rename master evaluation to coordinator evaluation 2020-07-07 10:37:41 +02:00
coordinator_evaluation_modify.out Rename master evaluation to coordinator evaluation 2020-07-07 10:37:41 +02:00
coordinator_evaluation_select.out Rename master evaluation to coordinator evaluation 2020-07-07 10:37:41 +02:00
coordinator_shouldhaveshards.out test coordinator reference-distributed table join (#3698) 2020-07-14 11:43:03 +03:00
create_table_triggers.out Error out for unsupported trigger objects 2020-05-31 23:10:01 +03:00
create_table_triggers_0.out Error out for unsupported trigger objects 2020-05-31 23:10:01 +03:00
cte_inline.out force aliases in deparsing for queries with anonymous column references (#4011) 2020-07-13 16:29:24 +02:00
cte_inline_0.out force aliases in deparsing for queries with anonymous column references (#4011) 2020-07-13 16:29:24 +02:00
cte_nested_modification.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
cte_prepared_modify.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
custom_aggregate_support.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
custom_aggregate_support_0.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
custom_aggregate_support_1.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
disable_object_propagation.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
distributed_collations.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
distributed_collations_conflict.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
distributed_functions.out not wait forever for metadata sync in tests (#3760) 2020-05-14 10:51:24 +03:00
distributed_functions_conflict.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
distributed_intermediate_results.out Test RedistributeTaskListResult 2020-01-09 23:47:25 -08:00
distributed_procedure.out not wait forever for metadata sync in tests (#3760) 2020-05-14 10:51:24 +03:00
distributed_types.out Fix composite create type deparsing to preserve typmod 2020-05-15 13:12:54 +00:00
distributed_types_conflict.out Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
distributed_types_xact_add_enum_value.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
distributed_types_xact_add_enum_value_0.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
dml_recursive.out force aliases in deparsing for queries with anonymous column references (#4011) 2020-07-13 16:29:24 +02:00
ensure_no_intermediate_data_leak.out test that we don't leak intermediate schemas (#3737) 2020-04-09 12:17:41 +03:00
ensure_no_shared_connection_leak.out Temporarily disable connection leak tests that fail a lot (#3911) 2020-06-16 13:48:48 +02:00
escape_extension_name.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
escape_extension_name_0.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
expression_reference_join.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
failure_1pc_copy_append.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_1pc_copy_hash.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_add_disable_node.out GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
failure_connection_establishment.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
failure_copy_on_hash.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_copy_to_reference.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
failure_create_distributed_table_non_empty.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
failure_create_index_concurrently.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
failure_create_reference_table.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
failure_create_table.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_cte_subquery.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_ddl.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_distributed_results.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_insert_select_pushdown.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_insert_select_repartition.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_insert_select_via_coordinator.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
failure_multi_dml.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_multi_row_insert.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_multi_shard_update_delete.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
failure_mx_metadata_sync.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
failure_parallel_connection.out Add failure test for parallel reference table join 2020-02-03 19:35:07 +01:00
failure_ref_tables.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_replicated_partitions.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_savepoints.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_setup.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
failure_single_mod.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_single_select.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_test_helpers.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
failure_truncate.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_vacuum.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
failure_vacuum_1.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
fast_path_router_modify.out Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
follower_single_node.out address feedback 2020-07-13 19:45:02 +03:00
foreign_key_restriction_enforcement.out Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
foreign_key_to_reference_table.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
full_join.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
grant_on_schema_propagation.out Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
having_subquery.out Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
insert_select_connection_leak.out Add insert/select connection leak tests 2020-01-30 14:09:07 -08:00
insert_select_into_local_table.out Insert Select Into Local Table (#3870) 2020-06-12 17:06:31 +03:00
insert_select_repartition.out Move more from insert_select_executor to insert_select_planner 2020-06-26 08:08:26 -07:00
intermediate_result_pruning.out Fix intermediate result pruning for INSERT..SELECT 2020-04-07 11:07:49 +02:00
intermediate_results.out Issue worker messages with the same log level 2020-04-14 21:08:25 +02:00
isolation_add_node_vs_reference_table_operations.out GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
isolation_add_remove_node.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_append_copy_vs_all.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
isolation_cancellation.out Add a CI check to see if all tests are part of a schedule (#3959) 2020-07-03 11:34:55 +02:00
isolation_citus_dist_activity.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_cluster_management.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_concurrent_dml.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_copy_placement_vs_copy_placement.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_copy_placement_vs_modification.out Tests for master_copy_shard_placement 2020-03-23 08:33:55 -07:00
isolation_copy_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_create_distributed_table.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_create_restore_point.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_create_table_vs_add_remove_node.out Prevent reference tables being dropped when replicating reference tables 2020-04-08 12:41:36 -07:00
isolation_data_migration.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_ddl_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_delete_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_dis2ref_foreign_keys_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_distributed_deadlock_detection.out Re-enable isolation test for reference tables + distributed deadlock detection 2020-04-24 11:53:03 +02:00
isolation_distributed_transaction_id.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_dml_vs_repair.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_drop_alter_index_select_for_update_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_drop_shards.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_drop_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_dump_global_wait_edges.out Detect deadlocks in replicate_reference_tables() 2020-04-15 11:06:18 -07:00
isolation_dump_local_wait_edges.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_ensure_dependency_activate_node.out Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
isolation_extension_commands.out Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
isolation_get_all_active_transactions.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_get_distributed_wait_queries_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_hash_copy_vs_all.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
isolation_insert_select_conflict.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_insert_select_repartition.out Isolation tests for INSERT/SELECT repartition 2020-01-16 23:24:52 -08:00
isolation_insert_select_vs_all.out Insert Select Into Local Table (#3870) 2020-06-12 17:06:31 +03:00
isolation_insert_select_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_insert_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_insert_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_insert_vs_vacuum.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_master_append_table.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_master_apply_delete.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_master_update_node.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_master_update_node_0.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_modify_with_subquery_vs_dml.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_multi_shard_modify_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_multiuser_locking.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_partitioned_copy_vs_all.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
isolation_progress_monitoring.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_range_copy_vs_all.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
isolation_ref2ref_foreign_keys.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_ref2ref_foreign_keys_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_ref_select_for_update_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_ref_update_delete_upsert_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_reference_copy_vs_all.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
isolation_reference_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_replace_wait_function.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_replicate_reference_tables_to_coordinator.out Re-enable isolation test for reference tables + distributed deadlock detection 2020-04-24 11:53:03 +02:00
isolation_select_for_update.out Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
isolation_select_vs_all.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
isolation_select_vs_all_on_mx.out Support use of binary protocol in between nodes (#3877) 2020-06-12 15:02:51 +02:00
isolation_shouldhaveshards.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_transaction_recovery.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_truncate_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_truncate_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_update_delete_upsert_vs_all_on_mx.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_update_node.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_update_node_lock_writes.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_update_vs_all.out Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
isolation_upsert_vs_all.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
isolation_validate_vs_insert.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
limit_intermediate_size.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
local_shard_copy.out Handle joins between local/reference/cte via router planner 2020-06-12 18:36:01 -07:00
local_shard_execution.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
local_shard_utility_command_execution.out Notice message to help truncate local data after distribution 2020-04-17 13:21:34 +03:00
locally_execute_intermediate_results.out Handle joins between local/reference/cte via router planner 2020-06-12 18:36:01 -07:00
master_copy_shard_placement.out Test master_copy_shard_placement errors on foreign constraints 2020-04-13 12:45:27 -07:00
materialized_view.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_703_upgrade.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_agg_approximate_distinct.out Implement pulling up rows to coordinator when aggregates cannot be pushed down. Enabled by default 2020-01-07 01:16:04 +00:00
multi_agg_approximate_distinct_0.out 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.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_array_agg.out 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.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_basic_queries.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_behavioral_analytics_basics.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_behavioral_analytics_single_shard_queries.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_binary_master_copy_format.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_cache_invalidation.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_citus_tools.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_cluster_management.out Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
multi_colocated_shard_transfer.out Rename RelayFileState to ShardState 2020-01-12 05:57:53 +00:00
multi_colocation_utils.out Add IsCitusTable check to citus table utilities (#4028) 2020-07-14 18:29:33 +03:00
multi_complex_expressions.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_complex_expressions_0.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_count_type_conversion.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_create_fdw.out Use citus.next_shard_id where practical in regression tests 2017-11-15 10:12:05 +01:00
multi_create_shards.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_create_table.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_create_table_constraints.out Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_create_table_new_features.out 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.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_cross_shard.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_data_types.out Fix write queries with const expressions and COLLATE in various places (#3973) 2020-07-08 18:19:53 +02:00
multi_deparse_function.out Propagate DROP ROUTINE, ALTER ROUTINE 2020-01-13 15:37:46 +00:00
multi_deparse_procedure.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_deparse_shard_query.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_distributed_transaction_id.out Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_distribution_metadata.out Rename RelayFileState to ShardState 2020-01-12 05:57:53 +00:00
multi_drop_extension.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_dropped_column_aliases.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_explain.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_extension.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_follower_configure_followers.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_follower_dml.out improve error message in secondaries (#4025) 2020-07-13 19:18:57 +03:00
multi_follower_sanity_check.out Add regression tests for follower clusters 2017-08-12 12:05:56 +02:00
multi_follower_select_statements.out add multi follower repartition tests 2020-07-13 19:50:50 +03:00
multi_foreign_key.out Improve error message when creating a foreign key to a local table 2020-07-13 13:57:22 +02:00
multi_foreign_key_relation_graph.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_function_evaluation.out 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.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
multi_generate_ddl_commands.out Append IF NOT EXISTS to deparsed CREATE SERVER commands (#3875) 2020-06-05 18:04:33 +03:00
multi_hash_pruning.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_having_pushdown.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_index_statements.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_insert_conflict.out Move more from insert_select_executor to insert_select_planner 2020-06-26 08:08:26 -07:00
multi_insert_select.out force aliases in deparsing for queries with anonymous column references (#4011) 2020-07-13 16:29:24 +02:00
multi_insert_select_conflict.out Move more from insert_select_executor to insert_select_planner 2020-06-26 08:08:26 -07:00
multi_insert_select_non_pushable_queries.out Move more from insert_select_executor to insert_select_planner 2020-06-26 08:08:26 -07:00
multi_insert_select_window.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
multi_join_order_additional.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_join_order_tpch_repartition.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_join_order_tpch_small.out Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_join_pruning.out Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_json_agg.out 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.out 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.out 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.out 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.out Correctly handle non-constant LIMIT/OFFSET clauses 2020-04-09 19:59:50 +00:00
multi_limit_clause_approximate.out Expand the set of aggregates which cannot have LIMIT approximated 2020-01-30 17:45:18 +00:00
multi_master_protocol.out Normalize tests: pg12 changes 2020-01-06 09:32:03 +01:00
multi_metadata_access.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_metadata_attributes.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_metadata_sync.out GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
multi_modifications.out Handle joins between local/reference/cte via router planner 2020-06-12 18:36:01 -07:00
multi_modifying_xacts.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
multi_multiuser.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_add_coordinator.out Handle joins between local/reference/cte via router planner 2020-06-12 18:36:01 -07:00
multi_mx_call.out Issue worker messages with the same log level 2020-04-14 21:08:25 +02:00
multi_mx_create_table.out Remove todo from reference_table_utils 2020-04-08 12:46:55 -07:00
multi_mx_ddl.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_explain.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_function_call_delegation.out Support use of binary protocol in between nodes (#3877) 2020-06-12 15:02:51 +02:00
multi_mx_function_table_reference.out Fix composite create type deparsing to preserve typmod 2020-05-15 13:12:54 +00:00
multi_mx_hide_shard_names.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_insert_select_repartition.out enable local execution in INSERT..SELECT and add more tests 2020-03-18 09:34:39 +03:00
multi_mx_metadata.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_modifications.out Fix: distributed function with table reference in declare (#3384) 2020-01-16 14:21:54 +01:00
multi_mx_modifications_to_reference_tables.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_modifying_xacts.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_node_metadata.out not wait forever for metadata sync in tests (#3760) 2020-05-14 10:51:24 +03:00
multi_mx_partitioning.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_mx_reference_table.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_join_w1.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_join_w2.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_udt_prepare.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_udt_w1.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_repartition_udt_w2.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_router_planner.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_schema_support.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_mx_tpch_query1.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query3.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query6.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query7.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query7_nested.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query10.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query12.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query14.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_tpch_query19.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_mx_transaction_recovery.out enable local execution in INSERT..SELECT and add more tests 2020-03-18 09:34:39 +03:00
multi_mx_truncate_from_worker.out use local execution within transaction block (#3714) 2020-04-09 12:41:58 +03:00
multi_name_lengths.out Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_name_resolution.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_null_minmax_value_pruning.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_orderby_limit_pushdown.out Refactor master query to be planned by postgres' planner (#3326) 2020-02-25 14:39:56 +01:00
multi_partition_pruning.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_partitioning.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_partitioning_utils.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_prepare_plsql.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_prepare_sql.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_prune_shard_list.out Coerce types properly for INSERT 2020-06-10 10:40:28 +02:00
multi_query_directory_cleanup.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_query_directory_cleanup_0.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_read_from_secondaries.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
multi_real_time_transaction.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_reference_table.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_remove_node_reference_table.out Remove todo from reference_table_utils 2020-04-08 12:46:55 -07:00
multi_repair_shards.out Rename RelayFileState to ShardState 2020-01-12 05:57:53 +00:00
multi_repartition_join_planning.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_repartition_join_pruning.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_repartition_join_ref.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_repartition_join_task_assignment.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_repartition_udt.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_repartitioned_subquery_udf.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_replicate_reference_table.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
multi_router_planner.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_router_planner_fast_path.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_row_insert.out Add ORDER BY to multi_row_insert.sql 2020-01-16 15:20:39 -08:00
multi_schema_support.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_select_distinct.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
multi_select_for_update.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_shard_modify.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_shard_update_delete.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_simple_queries.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_simple_queries_0.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_single_relation_subquery.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_size_queries.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_sql_function.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_subquery.out Defer get_agg_clause_costs, it happens later & avoids errors 2020-04-10 13:26:05 +00:00
multi_subquery_behavioral_analytics.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
multi_subquery_complex_queries.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
multi_subquery_complex_reference_clause.out force aliases in deparsing for queries with anonymous column references (#4011) 2020-07-13 16:29:24 +02:00
multi_subquery_in_where_clause.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
multi_subquery_in_where_reference_clause.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
multi_subquery_misc.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_subquery_union.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_subquery_window_functions.out Show query text in EXPLAIN output 2020-06-11 02:19:55 -07:00
multi_subtransactions.out Fix Subtransaction memory leak 2020-07-09 12:33:39 -07:00
multi_table_ddl.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_task_assignment_policy.out Merge branch 'improve-shard-pruning' of https://github.com/MarkusSintonen/citus into MarkusSintonen-improve-shard-pruning 2020-02-26 07:13:33 -08:00
multi_task_string_size.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_test_catalog_views.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_test_helpers.out address feedback from Sait Talha & Hadi 2020-06-12 18:36:02 -07:00
multi_test_helpers_superuser.out Fix Subtransaction memory leak 2020-07-09 12:33:39 -07:00
multi_tpch_query1.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query3.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query6.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query7.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query7_nested.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query10.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query12.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query14.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_tpch_query19.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_transaction_recovery.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_transactional_drop_shards.out GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
multi_truncate.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
multi_unsupported_worker_operations.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
multi_upgrade_reference_table.out Remove todo from reference_table_utils 2020-04-08 12:46:55 -07:00
multi_upsert.out Merge remote-tracking branch 'origin/master' into normalized-test-output 2020-01-06 09:36:04 +01:00
multi_utilities.out Adds public host to only hyperscale tests 2020-04-10 15:54:47 +03:00
multi_utility_statements.out Defer shard pruning for fast-path router queries to execution 2020-01-16 16:59:36 +01:00
multi_utility_warnings.out Add the necessary changes for rebalance strategies on enterprise (#3325) 2019-12-19 15:23:08 +01:00
multi_view.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
multi_working_columns.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
mx_foreign_key_to_reference_table.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
node_conninfo_reload.out Improve connection error message from the worker nodes 2020-04-20 13:32:55 +02:00
non_colocated_join_order.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
non_colocated_leaf_subquery_joins.out Update regression tests-1 2020-01-16 12:28:15 +01:00
non_colocated_subquery_joins.out Update regression tests-2 2020-01-16 12:28:15 +01:00
null_parameters.out not log in debug level in null parameters (#3718) 2020-04-06 17:59:46 +03:00
partitioned_intermediate_results.out Partitioned task list results. 2020-01-09 10:32:58 -08:00
pg12.out Fix COPY TO's COPY (SELECT) with distributed table having generated columns 2020-04-28 14:40:47 +00:00
pg12_1.out Create a test 'pg12' for pg12 features & error on unsupported new features 2019-08-22 19:30:56 +00:00
pg_dump.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
propagate_extension_commands.out GUC for replicate reference tables on activate. 2020-04-08 12:42:45 -07:00
propagate_set_commands.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
recursive_dml_queries_mx.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
recursive_dml_with_different_planners_executors.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
relation_access_tracking.out Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
remove_coordinator.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
replicate_reference_tables_to_coordinator.out address feedback from Sait Talha & Hadi 2020-06-12 18:36:02 -07:00
replicated_partitioned_table.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
rollback_to_savepoint.out Fix assertion error when rolling back to savepoint (#3868) 2020-06-30 11:31:46 +02:00
row_types.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
sequential_modifications.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
set_operation_and_local_tables.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
set_operations.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
set_role_in_transaction.out Error out when using different users in the same transaction (#3869) 2020-06-10 14:07:40 +02:00
shared_connection_stats.out Copy doesn't use more than MaxAdaptiveExecutor 2020-06-10 16:46:21 +03:00
shared_connection_waits.out Throttle connections to the worker nodes 2020-04-14 10:27:48 +02:00
single_hash_repartition_join.out test task tracker repartition with replication >1 (#3944) 2020-06-24 14:54:20 +03:00
single_node.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
sql_procedure.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
sqlancer_failures.out Fix write queries with const expressions and COLLATE in various places (#3973) 2020-07-08 18:19:53 +02:00
sqlsmith_failures.out Fix for pruned target list entries (#3818) 2020-05-06 13:56:02 +02:00
ssl_by_default.out Use Microsoft approved cipher string (#3639) 2020-03-24 15:51:44 +01:00
statement_cancel_error_message.out Fix wrong cancellation message about distributed deadlocks (#3956) 2020-06-30 14:57:46 +02:00
subqueries_deep.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
subqueries_not_supported.out Add support for window functions on coordinator 2020-03-25 15:31:20 +00:00
subquery_and_cte.out Update regression tests-2 2020-01-16 12:28:15 +01:00
subquery_basics.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
subquery_complex_target_list.out Make sure we don't wrap GROUP BY expressions in any_value 2020-05-05 05:12:45 +02:00
subquery_executors.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
subquery_in_where.out Remove assertion for subqueries in WHERE clause ANDed with FALSE 2020-05-04 10:52:15 +02:00
subquery_local_tables.out Add test for issue, does not reproduce issue 2020-02-18 23:45:17 +00:00
subquery_partitioning.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
subquery_prepared_statements.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
subquery_view.out Update regression tests-2 2020-01-16 12:28:15 +01:00
task_tracker_assign_task.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
task_tracker_cleanup_job.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
task_tracker_create_table.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
task_tracker_partition_task.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
tdigest_aggregate_support.out fix test output for tdigest (#3909) 2020-06-12 20:54:27 +02:00
tdigest_aggregate_support_0.out Feature: tdigest aggregate (#3897) 2020-06-12 13:50:28 +02:00
upgrade_basic_after.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
upgrade_basic_before.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
upgrade_distributed_function_after.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
upgrade_distributed_function_before.out not wait forever in upgrade distributed function before (#3731) 2020-04-10 09:43:42 +03:00
upgrade_pg_dist_object_test_after.out Refactor alter role to work on distributed roles (#3739) 2020-04-16 12:23:27 +02:00
upgrade_pg_dist_object_test_before.out Introduce objects to dist. infrastructure when updating Citus (#3477) 2020-02-07 18:07:59 +03:00
upgrade_rebalance_strategy_after.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
upgrade_rebalance_strategy_before.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
upgrade_ref2ref_after.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
upgrade_ref2ref_before.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
upgrade_type_after.out upgrade_type_after: ORDER BY 2020-04-01 01:07:21 +00:00
upgrade_type_before.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
validate_constraint.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
window_functions.out Avoid setting hasWindowFuncs true after window functions have been optimized out of query 2020-04-17 12:22:48 +00:00
with_basics.out Add new regression tests 2020-04-07 17:06:55 +02:00
with_dml.out Update with_dml 2020-02-03 13:13:30 -08:00
with_executors.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00
with_join.out Update regression tests-2 2020-01-16 12:28:15 +01:00
with_modifying.out force aliases in deparsing for queries with anonymous column references (#4011) 2020-07-13 16:29:24 +02:00
with_nested.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
with_partitioning.out Fix typo: longer visible -> no longer visible (#3803) 2020-04-27 16:32:46 +03:00
with_prepare.out Allow routing modifying CTEs 2020-06-11 15:14:06 +00:00
with_set_operations.out Update regression tests-2 2020-01-16 12:28:15 +01:00
with_transactions.out Normalize tests: s/read_intermediate_result\('[0-9]+_/read_intermediate_result('XXX_/g 2020-01-06 09:32:03 +01:00
with_where.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_binary_data_partition.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_create_table.out Use citus.next_shard_id where practical in regression tests 2017-11-15 10:12:05 +01:00
worker_hash_partition.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_hash_partition_complex.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_merge_hash_files.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_merge_range_files.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_null_data_partition.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_range_partition.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_range_partition_complex.out Normalize tests: Remove trailing whitespace 2020-01-06 09:32:03 +01:00
worker_remove_files.out Remove task tracker executor (#3850) 2020-07-18 13:11:36 +03:00