indexes.td 61 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587
  1. # Copyright Materialize, Inc. and contributors. All rights reserved.
  2. #
  3. # Use of this software is governed by the Business Source License
  4. # included in the LICENSE file at the root of this repository.
  5. #
  6. # As of the Change Date specified in that file, in accordance with
  7. # the Business Source License, use of this software will be governed
  8. # by the Apache License, Version 2.0.
  9. $ set-sql-timeout duration=1s
  10. $ set-arg-default single-replica-cluster=quickstart
  11. $ set-regex match=cluster1|quickstart replacement=<VARIABLE_OUTPUT>
  12. $ set writer-schema={
  13. "name": "row",
  14. "type": "record",
  15. "fields": [
  16. {"name": "a", "type": "long"},
  17. {"name": "b", "type": "int"}
  18. ]
  19. }
  20. $ kafka-create-topic topic=data
  21. $ kafka-ingest topic=data format=avro schema=${writer-schema}
  22. {"a": 1, "b": 1}
  23. # Sources do not have indexes automatically created
  24. > CREATE CONNECTION kafka_conn
  25. TO KAFKA (BROKER '${testdrive.kafka-addr}', SECURITY PROTOCOL PLAINTEXT);
  26. > CREATE SOURCE data
  27. IN CLUSTER ${arg.single-replica-cluster}
  28. FROM KAFKA CONNECTION kafka_conn (TOPIC 'testdrive-data-${testdrive.seed}')
  29. FORMAT AVRO USING SCHEMA '${writer-schema}'
  30. > SET CLUSTER TO mz_catalog_server
  31. > SHOW INDEXES ON data
  32. > SHOW INDEXES ON data
  33. name on cluster key comment
  34. --------------------------------------------------------------------------
  35. > SET CLUSTER TO quickstart
  36. # Sources can have default indexes added
  37. > CREATE DEFAULT INDEX ON data
  38. > SET CLUSTER TO mz_catalog_server
  39. > SHOW INDEXES ON data
  40. name on cluster key comment
  41. -------------------------------------------------------------------------------------------
  42. data_primary_idx data <VARIABLE_OUTPUT> {a,b} ""
  43. > SET CLUSTER TO quickstart
  44. > SELECT index_position FROM mz_index_columns WHERE index_id LIKE '%u%'
  45. index_position
  46. --------------
  47. 1
  48. 2
  49. > SELECT position, name FROM mz_columns where id LIKE '%u%';
  50. position name
  51. ----------------------
  52. 1 a
  53. 1 partition
  54. 2 b
  55. 2 offset
  56. # Views do not have indexes automatically created
  57. > CREATE VIEW data_view as SELECT * from data
  58. > SET CLUSTER TO mz_catalog_server
  59. > SHOW INDEXES ON data_view
  60. name on cluster key comment
  61. --------------------------------------------------------------------------
  62. > SET CLUSTER TO quickstart
  63. # Views can have default indexes added
  64. > CREATE DEFAULT INDEX ON data_view
  65. > SET CLUSTER TO mz_catalog_server
  66. > SHOW INDEXES ON data_view
  67. name on cluster key comment
  68. ---------------------------------------------------------------------------------------------------
  69. data_view_primary_idx data_view <VARIABLE_OUTPUT> {a,b} ""
  70. > SET CLUSTER TO quickstart
  71. # Materialized views do not have indexes automatically created
  72. > CREATE MATERIALIZED VIEW matv AS
  73. SELECT b, sum(a) FROM data GROUP BY b
  74. > SET CLUSTER TO mz_catalog_server
  75. > SHOW INDEXES ON matv
  76. name on cluster key comment
  77. --------------------------------------------------------------------------
  78. > SET CLUSTER TO quickstart
  79. # Materialized views can have default indexes added
  80. > CREATE DEFAULT INDEX ON matv
  81. > SET CLUSTER TO mz_catalog_server
  82. > SHOW INDEXES ON matv
  83. name on cluster key comment
  84. --------------------------------------------------------------------------------------------
  85. matv_primary_idx matv <VARIABLE_OUTPUT> {b} ""
  86. > SET CLUSTER TO quickstart
  87. # IF NOT EXISTS prevents adding multiple default indexes
  88. > CREATE DEFAULT INDEX IF NOT EXISTS ON data_view
  89. > SET CLUSTER TO mz_catalog_server
  90. > SHOW INDEXES ON data_view
  91. name on cluster key comment
  92. -------------------------------------------------------------------------------------------------
  93. data_view_primary_idx data_view <VARIABLE_OUTPUT> {a,b} ""
  94. > SET CLUSTER TO quickstart
  95. # Additional default indexes have the same structure as the first
  96. > CREATE DEFAULT INDEX ON matv
  97. > SET CLUSTER TO mz_catalog_server
  98. > SHOW INDEXES ON matv
  99. name on cluster key comment
  100. ------------------------------------------------------------------------------------------------
  101. matv_primary_idx matv <VARIABLE_OUTPUT> {b} ""
  102. matv_primary_idx1 matv <VARIABLE_OUTPUT> {b} ""
  103. > SET CLUSTER TO quickstart
  104. # Default indexes can be named
  105. > CREATE DEFAULT INDEX named_idx ON data_view
  106. > SET CLUSTER TO mz_catalog_server
  107. > SHOW INDEXES ON data_view
  108. name on cluster key comment
  109. -----------------------------------------------------------------------------------------------
  110. data_view_primary_idx data_view <VARIABLE_OUTPUT> {a,b} ""
  111. named_idx data_view <VARIABLE_OUTPUT> {a,b} ""
  112. > SET CLUSTER TO quickstart
  113. > DROP INDEX data_view_primary_idx
  114. > DROP INDEX named_idx
  115. # Indexes with specified columns can be automatically named
  116. > CREATE INDEX ON data_view(a)
  117. > SET CLUSTER TO mz_catalog_server
  118. > SHOW INDEXES ON data_view
  119. name on cluster key comment
  120. -------------------------------------------------------------------------------------------
  121. data_view_a_idx data_view <VARIABLE_OUTPUT> {a} ""
  122. > SET CLUSTER TO quickstart
  123. > DROP INDEX data_view_a_idx
  124. # Automatically named indexes rename expression columns to "expr" and join all columns with underscores.
  125. > CREATE INDEX ON data_view(b, a)
  126. > CREATE INDEX ON data_view(b - a, a)
  127. > SET CLUSTER TO mz_catalog_server
  128. > SHOW INDEXES ON data_view
  129. name on cluster key comment
  130. -----------------------------------------------------------------------------------------------
  131. data_view_b_a_idx data_view <VARIABLE_OUTPUT> {b,a} ""
  132. data_view_expr_a_idx data_view <VARIABLE_OUTPUT> "{b - a,a}" ""
  133. > SET CLUSTER TO quickstart
  134. > DROP INDEX data_view_b_a_idx
  135. > DROP INDEX data_view_expr_a_idx
  136. # Indexes can be both explicitly named and explicitly structured
  137. > CREATE INDEX named_idx ON data_view (b - a, a)
  138. > SET CLUSTER TO mz_catalog_server
  139. > SHOW INDEXES ON data_view
  140. name on cluster key comment
  141. ---------------------------------------------------------------------------------------------
  142. named_idx data_view <VARIABLE_OUTPUT> "{b - a,a}" ""
  143. > SET CLUSTER TO quickstart
  144. > DROP INDEX named_idx
  145. # Default indexes only check for names, not structures
  146. > CREATE INDEX data_view_primary_idx ON data_view (b - a, a)
  147. > CREATE DEFAULT INDEX IF NOT EXISTS ON data_view
  148. > SET CLUSTER TO mz_catalog_server
  149. > SHOW INDEXES ON data_view
  150. name on cluster key comment
  151. ------------------------------------------------------------------------------------------------------
  152. data_view_primary_idx data_view <VARIABLE_OUTPUT> "{b - a,a}" ""
  153. > SET CLUSTER TO quickstart
  154. > CREATE TABLE foo (
  155. a int NOT NULL,
  156. b decimal(13, 1),
  157. z text
  158. )
  159. > CREATE DEFAULT INDEX ON foo
  160. > CREATE INDEX ON foo (a + b)
  161. > CREATE INDEX ON foo (substr(z, 3))
  162. > SET CLUSTER TO mz_catalog_server
  163. > SHOW INDEXES ON foo
  164. foo_primary_idx foo <VARIABLE_OUTPUT> {a,b,z} ""
  165. foo_expr_idx foo <VARIABLE_OUTPUT> "{a + b}" ""
  166. foo_expr_idx1 foo <VARIABLE_OUTPUT> "{pg_catalog.substr(z, 3)}" ""
  167. > SHOW INDEXES ON foo WHERE name = 'noexist'
  168. > SHOW INDEXES ON foo WHERE name = 'foo_expr_idx'
  169. foo_expr_idx foo <VARIABLE_OUTPUT> "{a + b}" ""
  170. > SHOW INDEXES ON foo LIKE 'foo_primary%'
  171. foo_primary_idx foo <VARIABLE_OUTPUT> {a,b,z} ""
  172. ! SHOW INDEXES ON nonexistent
  173. contains:unknown catalog item 'nonexistent'
  174. ! SHOW INDEXES ON foo_primary_idx
  175. contains:cannot show indexes on materialize.public.foo_primary_idx because it is a index
  176. > SET CLUSTER TO quickstart
  177. > CREATE CLUSTER clstr REPLICAS (r1 (SIZE '1'))
  178. > CREATE DEFAULT INDEX IN CLUSTER clstr ON foo;
  179. > SET CLUSTER TO mz_catalog_server
  180. > SHOW INDEXES IN CLUSTER clstr WHERE on = 'foo'
  181. foo_primary_idx1 foo clstr {a,b,z} ""
  182. > SHOW INDEXES FROM public WHERE name = 'foo_primary_idx1'
  183. foo_primary_idx1 foo clstr {a,b,z} ""
  184. > SET CLUSTER TO quickstart
  185. > DROP TABLE foo CASCADE
  186. > DROP SOURCE data CASCADE
  187. > SET CLUSTER TO mz_catalog_server
  188. ! SHOW INDEXES FROM public ON foo
  189. contains:Cannot specify both FROM and ON
  190. ! SHOW INDEXES FROM nonexistent
  191. contains:unknown schema 'nonexistent'
  192. > SET CLUSTER TO quickstart
  193. > CREATE TABLE bar ();
  194. > CREATE INDEX bar_ind ON bar ();
  195. > SET CLUSTER TO mz_catalog_server
  196. > SHOW INDEXES
  197. bar_ind bar <VARIABLE_OUTPUT> {} ""
  198. > SET CLUSTER TO quickstart
  199. > DROP TABLE bar CASCADE
  200. > CREATE SCHEMA foo
  201. > CREATE TABLE foo.bar (a INT)
  202. > CREATE INDEX bar_ind ON foo.bar (a)
  203. > SET CLUSTER TO mz_catalog_server
  204. > SHOW INDEXES ON foo.bar
  205. bar_ind bar <VARIABLE_OUTPUT> {a} ""
  206. > SET CLUSTER TO quickstart
  207. > DROP CLUSTER clstr CASCADE;
  208. $ postgres-execute connection=postgres://mz_system@${testdrive.materialize-internal-sql-addr}/materialize
  209. ALTER SYSTEM SET enable_rbac_checks TO true
  210. >[version<=13100] SHOW INDEXES IN CLUSTER mz_catalog_server
  211. mz_active_peeks_per_worker_s2_primary_idx mz_active_peeks_per_worker mz_catalog_server {id,worker_id} ""
  212. mz_arrangement_batches_raw_s2_primary_idx mz_arrangement_batches_raw mz_catalog_server {operator_id,worker_id} ""
  213. mz_arrangement_records_raw_s2_primary_idx mz_arrangement_records_raw mz_catalog_server {operator_id,worker_id} ""
  214. mz_arrangement_sharing_raw_s2_primary_idx mz_arrangement_sharing_raw mz_catalog_server {operator_id,worker_id} ""
  215. mz_arrangement_heap_capacity_raw_s2_primary_idx mz_arrangement_heap_capacity_raw mz_catalog_server {operator_id,worker_id} ""
  216. mz_arrangement_heap_allocations_raw_s2_primary_idx mz_arrangement_heap_allocations_raw mz_catalog_server {operator_id,worker_id} ""
  217. mz_arrangement_heap_size_raw_s2_primary_idx mz_arrangement_heap_size_raw mz_catalog_server {operator_id,worker_id} ""
  218. mz_arrangement_batcher_allocations_raw_s2_primary_idx mz_arrangement_batcher_allocations_raw mz_catalog_server {operator_id,worker_id} ""
  219. mz_arrangement_batcher_capacity_raw_s2_primary_idx mz_arrangement_batcher_capacity_raw mz_catalog_server {operator_id,worker_id} ""
  220. mz_arrangement_batcher_records_raw_s2_primary_idx mz_arrangement_batcher_records_raw mz_catalog_server {operator_id,worker_id} ""
  221. mz_arrangement_batcher_size_raw_s2_primary_idx mz_arrangement_batcher_size_raw mz_catalog_server {operator_id,worker_id} ""
  222. mz_cluster_deployment_lineage_ind mz_cluster_deployment_lineage mz_catalog_server {cluster_id} ""
  223. mz_cluster_replica_history_ind mz_cluster_replica_history mz_catalog_server {dropped_at} ""
  224. mz_cluster_replica_name_history_ind mz_cluster_replica_name_history mz_catalog_server {id} ""
  225. mz_cluster_replica_metrics_ind mz_cluster_replica_metrics mz_catalog_server {replica_id} ""
  226. mz_cluster_replica_metrics_history_ind mz_cluster_replica_metrics_history mz_catalog_server {replica_id} ""
  227. mz_cluster_replica_sizes_ind mz_cluster_replica_sizes mz_catalog_server {size} ""
  228. mz_cluster_replica_statuses_ind mz_cluster_replica_statuses mz_catalog_server {replica_id} ""
  229. mz_cluster_replica_status_history_ind mz_cluster_replica_status_history mz_catalog_server {replica_id} ""
  230. mz_cluster_replicas_ind mz_cluster_replicas mz_catalog_server {id} ""
  231. mz_clusters_ind mz_clusters mz_catalog_server {id} ""
  232. mz_columns_ind mz_columns mz_catalog_server {name} ""
  233. mz_comments_ind mz_comments mz_catalog_server {id} ""
  234. mz_compute_dependencies_ind mz_compute_dependencies mz_catalog_server {dependency_id} ""
  235. mz_compute_dataflow_global_ids_per_worker_s2_primary_idx mz_compute_dataflow_global_ids_per_worker mz_catalog_server {id,worker_id} ""
  236. mz_compute_error_counts_raw_s2_primary_idx mz_compute_error_counts_raw mz_catalog_server {export_id,worker_id} ""
  237. mz_compute_exports_per_worker_s2_primary_idx mz_compute_exports_per_worker mz_catalog_server {export_id,worker_id} ""
  238. mz_compute_frontiers_per_worker_s2_primary_idx mz_compute_frontiers_per_worker mz_catalog_server {export_id,worker_id} ""
  239. mz_compute_hydration_times_per_worker_s2_primary_idx mz_compute_hydration_times_per_worker mz_catalog_server {export_id,worker_id} ""
  240. mz_compute_import_frontiers_per_worker_s2_primary_idx mz_compute_import_frontiers_per_worker mz_catalog_server {export_id,import_id,worker_id} ""
  241. mz_compute_lir_mapping_per_worker_s2_primary_idx mz_compute_lir_mapping_per_worker mz_catalog_server {global_id,lir_id,worker_id} ""
  242. mz_compute_operator_durations_histogram_raw_s2_primary_idx mz_compute_operator_durations_histogram_raw mz_catalog_server {id,worker_id,duration_ns} ""
  243. mz_connections_ind mz_connections mz_catalog_server {schema_id} ""
  244. mz_console_cluster_utilization_overview_ind mz_console_cluster_utilization_overview mz_catalog_server {cluster_id} ""
  245. mz_continual_tasks_ind mz_continual_tasks mz_catalog_server {id} ""
  246. mz_databases_ind mz_databases mz_catalog_server {name} ""
  247. mz_dataflow_addresses_per_worker_s2_primary_idx mz_dataflow_addresses_per_worker mz_catalog_server {id,worker_id} ""
  248. mz_dataflow_channels_per_worker_s2_primary_idx mz_dataflow_channels_per_worker mz_catalog_server {id,worker_id} ""
  249. mz_dataflow_operator_reachability_raw_s2_primary_idx mz_dataflow_operator_reachability_raw mz_catalog_server {address,port,worker_id,update_type,time} ""
  250. mz_dataflow_operators_per_worker_s2_primary_idx mz_dataflow_operators_per_worker mz_catalog_server {id,worker_id} ""
  251. mz_dataflow_shutdown_durations_histogram_raw_s2_primary_idx mz_dataflow_shutdown_durations_histogram_raw mz_catalog_server {worker_id,duration_ns} ""
  252. mz_frontiers_ind mz_frontiers mz_catalog_server {object_id} ""
  253. mz_indexes_ind mz_indexes mz_catalog_server {id} ""
  254. mz_kafka_sources_ind mz_kafka_sources mz_catalog_server {id} ""
  255. mz_materialized_views_ind mz_materialized_views mz_catalog_server {id} ""
  256. mz_message_batch_counts_received_raw_s2_primary_idx mz_message_batch_counts_received_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  257. mz_message_batch_counts_sent_raw_s2_primary_idx mz_message_batch_counts_sent_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  258. mz_message_counts_received_raw_s2_primary_idx mz_message_counts_received_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  259. mz_message_counts_sent_raw_s2_primary_idx mz_message_counts_sent_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  260. mz_object_dependencies_ind mz_object_dependencies mz_catalog_server {object_id} ""
  261. mz_object_history_ind mz_object_history mz_catalog_server {id} ""
  262. mz_object_lifetimes_ind mz_object_lifetimes mz_catalog_server {id} ""
  263. mz_object_transitive_dependencies_ind mz_object_transitive_dependencies mz_catalog_server {object_id} ""
  264. mz_objects_ind mz_objects mz_catalog_server {schema_id} ""
  265. mz_notices_ind mz_notices mz_catalog_server {id} ""
  266. mz_peek_durations_histogram_raw_s2_primary_idx mz_peek_durations_histogram_raw mz_catalog_server {worker_id,type,duration_ns} ""
  267. mz_recent_activity_log_thinned_ind mz_recent_activity_log_thinned mz_catalog_server {sql_hash} ""
  268. mz_recent_storage_usage_ind mz_recent_storage_usage mz_catalog_server {object_id} ""
  269. mz_roles_ind mz_roles mz_catalog_server {id} ""
  270. mz_scheduling_elapsed_raw_s2_primary_idx mz_scheduling_elapsed_raw mz_catalog_server {id,worker_id} ""
  271. mz_scheduling_parks_histogram_raw_s2_primary_idx mz_scheduling_parks_histogram_raw mz_catalog_server {worker_id,slept_for_ns,requested_ns} ""
  272. mz_schemas_ind mz_schemas mz_catalog_server {database_id} ""
  273. mz_secrets_ind mz_secrets mz_catalog_server {name} ""
  274. mz_show_all_objects_ind mz_show_all_objects mz_catalog_server {schema_id} ""
  275. mz_show_cluster_replicas_ind mz_show_cluster_replicas mz_catalog_server {cluster} ""
  276. mz_show_clusters_ind mz_show_clusters mz_catalog_server {name} ""
  277. mz_show_columns_ind mz_show_columns mz_catalog_server {id} ""
  278. mz_show_connections_ind mz_show_connections mz_catalog_server {schema_id} ""
  279. mz_show_databases_ind mz_show_databases mz_catalog_server {name} ""
  280. mz_show_indexes_ind mz_show_indexes mz_catalog_server {schema_id} ""
  281. mz_show_materialized_views_ind mz_show_materialized_views mz_catalog_server {schema_id} ""
  282. mz_show_roles_ind mz_show_roles mz_catalog_server {name} ""
  283. mz_show_schemas_ind mz_show_schemas mz_catalog_server {database_id} ""
  284. mz_show_secrets_ind mz_show_secrets mz_catalog_server {schema_id} ""
  285. mz_show_sinks_ind mz_show_sinks mz_catalog_server {schema_id} ""
  286. mz_show_sources_ind mz_show_sources mz_catalog_server {schema_id} ""
  287. mz_show_tables_ind mz_show_tables mz_catalog_server {schema_id} ""
  288. mz_show_types_ind mz_show_types mz_catalog_server {schema_id} ""
  289. mz_show_views_ind mz_show_views mz_catalog_server {schema_id} ""
  290. mz_sink_statistics_ind mz_sink_statistics mz_catalog_server {id} ""
  291. mz_sink_status_history_ind mz_sink_status_history mz_catalog_server {sink_id} ""
  292. mz_source_statistics_with_history_ind mz_source_statistics_with_history mz_catalog_server {id,replica_id} ""
  293. mz_sink_statuses_ind mz_sink_statuses mz_catalog_server {id} ""
  294. mz_sinks_ind mz_sinks mz_catalog_server {id} ""
  295. mz_source_statistics_ind mz_source_statistics mz_catalog_server {id,replica_id} ""
  296. mz_source_status_history_ind mz_source_status_history mz_catalog_server {source_id} ""
  297. mz_source_statuses_ind mz_source_statuses mz_catalog_server {id} ""
  298. mz_sources_ind mz_sources mz_catalog_server {id} ""
  299. mz_tables_ind mz_tables mz_catalog_server {schema_id} ""
  300. mz_types_ind mz_types mz_catalog_server {schema_id} ""
  301. mz_recent_sql_text_ind mz_recent_sql_text mz_catalog_server {sql_hash} ""
  302. mz_views_ind mz_views mz_catalog_server {schema_id} ""
  303. mz_wallclock_global_lag_recent_history_ind mz_wallclock_global_lag_recent_history mz_catalog_server {object_id} ""
  304. mz_webhook_sources_ind mz_webhook_sources mz_catalog_server {id} ""
  305. pg_attrdef_all_databases_ind pg_attrdef_all_databases mz_catalog_server {oid,adrelid,adnum,adbin,adsrc} ""
  306. pg_attribute_all_databases_ind pg_attribute_all_databases mz_catalog_server {attrelid,attname,atttypid,attlen,attnum,atttypmod,attnotnull,atthasdef,attidentity,attgenerated,attisdropped,attcollation,database_name,pg_type_database_name} ""
  307. pg_class_all_databases_ind pg_class_all_databases mz_catalog_server {relname} ""
  308. pg_description_all_databases_ind pg_description_all_databases mz_catalog_server {objoid,classoid,objsubid,description,oid_database_name,class_database_name} ""
  309. pg_namespace_all_databases_ind pg_namespace_all_databases mz_catalog_server {nspname} ""
  310. pg_type_all_databases_ind pg_type_all_databases mz_catalog_server {oid} ""
  311. >[13100<version<14900] SHOW INDEXES IN CLUSTER mz_catalog_server
  312. mz_active_peeks_per_worker_s2_primary_idx mz_active_peeks_per_worker mz_catalog_server {id,worker_id} ""
  313. mz_arrangement_batches_raw_s2_primary_idx mz_arrangement_batches_raw mz_catalog_server {operator_id,worker_id} ""
  314. mz_arrangement_records_raw_s2_primary_idx mz_arrangement_records_raw mz_catalog_server {operator_id,worker_id} ""
  315. mz_arrangement_sharing_raw_s2_primary_idx mz_arrangement_sharing_raw mz_catalog_server {operator_id,worker_id} ""
  316. mz_arrangement_heap_capacity_raw_s2_primary_idx mz_arrangement_heap_capacity_raw mz_catalog_server {operator_id,worker_id} ""
  317. mz_arrangement_heap_allocations_raw_s2_primary_idx mz_arrangement_heap_allocations_raw mz_catalog_server {operator_id,worker_id} ""
  318. mz_arrangement_heap_size_raw_s2_primary_idx mz_arrangement_heap_size_raw mz_catalog_server {operator_id,worker_id} ""
  319. mz_arrangement_batcher_allocations_raw_s2_primary_idx mz_arrangement_batcher_allocations_raw mz_catalog_server {operator_id,worker_id} ""
  320. mz_arrangement_batcher_capacity_raw_s2_primary_idx mz_arrangement_batcher_capacity_raw mz_catalog_server {operator_id,worker_id} ""
  321. mz_arrangement_batcher_records_raw_s2_primary_idx mz_arrangement_batcher_records_raw mz_catalog_server {operator_id,worker_id} ""
  322. mz_arrangement_batcher_size_raw_s2_primary_idx mz_arrangement_batcher_size_raw mz_catalog_server {operator_id,worker_id} ""
  323. mz_cluster_deployment_lineage_ind mz_cluster_deployment_lineage mz_catalog_server {cluster_id} ""
  324. mz_cluster_replica_frontiers_ind mz_cluster_replica_frontiers mz_catalog_server {object_id} ""
  325. mz_cluster_replica_history_ind mz_cluster_replica_history mz_catalog_server {dropped_at} ""
  326. mz_cluster_replica_name_history_ind mz_cluster_replica_name_history mz_catalog_server {id} ""
  327. mz_cluster_replica_metrics_ind mz_cluster_replica_metrics mz_catalog_server {replica_id} ""
  328. mz_cluster_replica_metrics_history_ind mz_cluster_replica_metrics_history mz_catalog_server {replica_id} ""
  329. mz_cluster_replica_sizes_ind mz_cluster_replica_sizes mz_catalog_server {size} ""
  330. mz_cluster_replica_statuses_ind mz_cluster_replica_statuses mz_catalog_server {replica_id} ""
  331. mz_cluster_replica_status_history_ind mz_cluster_replica_status_history mz_catalog_server {replica_id} ""
  332. mz_cluster_replicas_ind mz_cluster_replicas mz_catalog_server {id} ""
  333. mz_clusters_ind mz_clusters mz_catalog_server {id} ""
  334. mz_columns_ind mz_columns mz_catalog_server {name} ""
  335. mz_comments_ind mz_comments mz_catalog_server {id} ""
  336. mz_compute_dependencies_ind mz_compute_dependencies mz_catalog_server {dependency_id} ""
  337. mz_compute_dataflow_global_ids_per_worker_s2_primary_idx mz_compute_dataflow_global_ids_per_worker mz_catalog_server {id,worker_id} ""
  338. mz_compute_error_counts_raw_s2_primary_idx mz_compute_error_counts_raw mz_catalog_server {export_id,worker_id} ""
  339. mz_compute_exports_per_worker_s2_primary_idx mz_compute_exports_per_worker mz_catalog_server {export_id,worker_id} ""
  340. mz_compute_frontiers_per_worker_s2_primary_idx mz_compute_frontiers_per_worker mz_catalog_server {export_id,worker_id} ""
  341. mz_compute_hydration_times_ind mz_compute_hydration_times mz_catalog_server {replica_id} ""
  342. mz_compute_hydration_times_per_worker_s2_primary_idx mz_compute_hydration_times_per_worker mz_catalog_server {export_id,worker_id} ""
  343. mz_compute_import_frontiers_per_worker_s2_primary_idx mz_compute_import_frontiers_per_worker mz_catalog_server {export_id,import_id,worker_id} ""
  344. mz_compute_lir_mapping_per_worker_s2_primary_idx mz_compute_lir_mapping_per_worker mz_catalog_server {global_id,lir_id,worker_id} ""
  345. mz_compute_operator_durations_histogram_raw_s2_primary_idx mz_compute_operator_durations_histogram_raw mz_catalog_server {id,worker_id,duration_ns} ""
  346. mz_connections_ind mz_connections mz_catalog_server {schema_id} ""
  347. mz_console_cluster_utilization_overview_ind mz_console_cluster_utilization_overview mz_catalog_server {cluster_id} ""
  348. mz_continual_tasks_ind mz_continual_tasks mz_catalog_server {id} ""
  349. mz_databases_ind mz_databases mz_catalog_server {name} ""
  350. mz_dataflow_addresses_per_worker_s2_primary_idx mz_dataflow_addresses_per_worker mz_catalog_server {id,worker_id} ""
  351. mz_dataflow_channels_per_worker_s2_primary_idx mz_dataflow_channels_per_worker mz_catalog_server {id,worker_id} ""
  352. mz_dataflow_operator_reachability_raw_s2_primary_idx mz_dataflow_operator_reachability_raw mz_catalog_server {id,worker_id,source,port,update_type,time} ""
  353. mz_dataflow_operators_per_worker_s2_primary_idx mz_dataflow_operators_per_worker mz_catalog_server {id,worker_id} ""
  354. mz_dataflow_shutdown_durations_histogram_raw_s2_primary_idx mz_dataflow_shutdown_durations_histogram_raw mz_catalog_server {worker_id,duration_ns} ""
  355. mz_frontiers_ind mz_frontiers mz_catalog_server {object_id} ""
  356. mz_indexes_ind mz_indexes mz_catalog_server {id} ""
  357. mz_kafka_sources_ind mz_kafka_sources mz_catalog_server {id} ""
  358. mz_materialized_views_ind mz_materialized_views mz_catalog_server {id} ""
  359. mz_message_batch_counts_received_raw_s2_primary_idx mz_message_batch_counts_received_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  360. mz_message_batch_counts_sent_raw_s2_primary_idx mz_message_batch_counts_sent_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  361. mz_message_counts_received_raw_s2_primary_idx mz_message_counts_received_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  362. mz_message_counts_sent_raw_s2_primary_idx mz_message_counts_sent_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  363. mz_object_dependencies_ind mz_object_dependencies mz_catalog_server {object_id} ""
  364. mz_object_history_ind mz_object_history mz_catalog_server {id} ""
  365. mz_object_lifetimes_ind mz_object_lifetimes mz_catalog_server {id} ""
  366. mz_object_transitive_dependencies_ind mz_object_transitive_dependencies mz_catalog_server {object_id} ""
  367. mz_objects_ind mz_objects mz_catalog_server {schema_id} ""
  368. mz_notices_ind mz_notices mz_catalog_server {id} ""
  369. mz_peek_durations_histogram_raw_s2_primary_idx mz_peek_durations_histogram_raw mz_catalog_server {worker_id,type,duration_ns} ""
  370. mz_recent_activity_log_thinned_ind mz_recent_activity_log_thinned mz_catalog_server {sql_hash} ""
  371. mz_recent_storage_usage_ind mz_recent_storage_usage mz_catalog_server {object_id} ""
  372. mz_roles_ind mz_roles mz_catalog_server {id} ""
  373. mz_scheduling_elapsed_raw_s2_primary_idx mz_scheduling_elapsed_raw mz_catalog_server {id,worker_id} ""
  374. mz_scheduling_parks_histogram_raw_s2_primary_idx mz_scheduling_parks_histogram_raw mz_catalog_server {worker_id,slept_for_ns,requested_ns} ""
  375. mz_schemas_ind mz_schemas mz_catalog_server {database_id} ""
  376. mz_secrets_ind mz_secrets mz_catalog_server {name} ""
  377. mz_show_all_objects_ind mz_show_all_objects mz_catalog_server {schema_id} ""
  378. mz_show_cluster_replicas_ind mz_show_cluster_replicas mz_catalog_server {cluster} ""
  379. mz_show_clusters_ind mz_show_clusters mz_catalog_server {name} ""
  380. mz_show_columns_ind mz_show_columns mz_catalog_server {id} ""
  381. mz_show_connections_ind mz_show_connections mz_catalog_server {schema_id} ""
  382. mz_show_databases_ind mz_show_databases mz_catalog_server {name} ""
  383. mz_show_indexes_ind mz_show_indexes mz_catalog_server {schema_id} ""
  384. mz_show_materialized_views_ind mz_show_materialized_views mz_catalog_server {schema_id} ""
  385. mz_show_roles_ind mz_show_roles mz_catalog_server {name} ""
  386. mz_show_schemas_ind mz_show_schemas mz_catalog_server {database_id} ""
  387. mz_show_secrets_ind mz_show_secrets mz_catalog_server {schema_id} ""
  388. mz_show_sinks_ind mz_show_sinks mz_catalog_server {schema_id} ""
  389. mz_show_sources_ind mz_show_sources mz_catalog_server {schema_id} ""
  390. mz_show_tables_ind mz_show_tables mz_catalog_server {schema_id} ""
  391. mz_show_types_ind mz_show_types mz_catalog_server {schema_id} ""
  392. mz_show_views_ind mz_show_views mz_catalog_server {schema_id} ""
  393. mz_sink_statistics_ind mz_sink_statistics mz_catalog_server {id} ""
  394. mz_sink_status_history_ind mz_sink_status_history mz_catalog_server {sink_id} ""
  395. mz_source_statistics_with_history_ind mz_source_statistics_with_history mz_catalog_server {id} ""
  396. mz_sink_statuses_ind mz_sink_statuses mz_catalog_server {id} ""
  397. mz_sinks_ind mz_sinks mz_catalog_server {id} ""
  398. mz_source_statistics_ind mz_source_statistics mz_catalog_server {id} ""
  399. mz_source_status_history_ind mz_source_status_history mz_catalog_server {source_id} ""
  400. mz_source_statuses_ind mz_source_statuses mz_catalog_server {id} ""
  401. mz_sources_ind mz_sources mz_catalog_server {id} ""
  402. mz_tables_ind mz_tables mz_catalog_server {schema_id} ""
  403. mz_types_ind mz_types mz_catalog_server {schema_id} ""
  404. mz_recent_sql_text_ind mz_recent_sql_text mz_catalog_server {sql_hash} ""
  405. mz_views_ind mz_views mz_catalog_server {schema_id} ""
  406. mz_wallclock_global_lag_recent_history_ind mz_wallclock_global_lag_recent_history mz_catalog_server {object_id} ""
  407. mz_webhook_sources_ind mz_webhook_sources mz_catalog_server {id} ""
  408. pg_attrdef_all_databases_ind pg_attrdef_all_databases mz_catalog_server {oid,adrelid,adnum,adbin,adsrc} ""
  409. pg_attribute_all_databases_ind pg_attribute_all_databases mz_catalog_server {attrelid,attname,atttypid,attlen,attnum,atttypmod,attnotnull,atthasdef,attidentity,attgenerated,attisdropped,attcollation,database_name,pg_type_database_name} ""
  410. pg_class_all_databases_ind pg_class_all_databases mz_catalog_server {relname} ""
  411. pg_description_all_databases_ind pg_description_all_databases mz_catalog_server {objoid,classoid,objsubid,description,oid_database_name,class_database_name} ""
  412. pg_namespace_all_databases_ind pg_namespace_all_databases mz_catalog_server {nspname} ""
  413. pg_type_all_databases_ind pg_type_all_databases mz_catalog_server {oid} ""
  414. >[version>=14900] SHOW INDEXES IN CLUSTER mz_catalog_server
  415. mz_active_peeks_per_worker_s2_primary_idx mz_active_peeks_per_worker mz_catalog_server {id,worker_id} ""
  416. mz_arrangement_batches_raw_s2_primary_idx mz_arrangement_batches_raw mz_catalog_server {operator_id,worker_id} ""
  417. mz_arrangement_records_raw_s2_primary_idx mz_arrangement_records_raw mz_catalog_server {operator_id,worker_id} ""
  418. mz_arrangement_sharing_raw_s2_primary_idx mz_arrangement_sharing_raw mz_catalog_server {operator_id,worker_id} ""
  419. mz_arrangement_heap_capacity_raw_s2_primary_idx mz_arrangement_heap_capacity_raw mz_catalog_server {operator_id,worker_id} ""
  420. mz_arrangement_heap_allocations_raw_s2_primary_idx mz_arrangement_heap_allocations_raw mz_catalog_server {operator_id,worker_id} ""
  421. mz_arrangement_heap_size_raw_s2_primary_idx mz_arrangement_heap_size_raw mz_catalog_server {operator_id,worker_id} ""
  422. mz_arrangement_batcher_allocations_raw_s2_primary_idx mz_arrangement_batcher_allocations_raw mz_catalog_server {operator_id,worker_id} ""
  423. mz_arrangement_batcher_capacity_raw_s2_primary_idx mz_arrangement_batcher_capacity_raw mz_catalog_server {operator_id,worker_id} ""
  424. mz_arrangement_batcher_records_raw_s2_primary_idx mz_arrangement_batcher_records_raw mz_catalog_server {operator_id,worker_id} ""
  425. mz_arrangement_batcher_size_raw_s2_primary_idx mz_arrangement_batcher_size_raw mz_catalog_server {operator_id,worker_id} ""
  426. mz_cluster_deployment_lineage_ind mz_cluster_deployment_lineage mz_catalog_server {cluster_id} ""
  427. mz_cluster_replica_frontiers_ind mz_cluster_replica_frontiers mz_catalog_server {object_id} ""
  428. mz_cluster_replica_history_ind mz_cluster_replica_history mz_catalog_server {dropped_at} ""
  429. mz_cluster_replica_name_history_ind mz_cluster_replica_name_history mz_catalog_server {id} ""
  430. mz_cluster_replica_metrics_ind mz_cluster_replica_metrics mz_catalog_server {replica_id} ""
  431. mz_cluster_replica_metrics_history_ind mz_cluster_replica_metrics_history mz_catalog_server {replica_id} ""
  432. mz_cluster_replica_sizes_ind mz_cluster_replica_sizes mz_catalog_server {size} ""
  433. mz_cluster_replica_statuses_ind mz_cluster_replica_statuses mz_catalog_server {replica_id} ""
  434. mz_cluster_replica_status_history_ind mz_cluster_replica_status_history mz_catalog_server {replica_id} ""
  435. mz_cluster_replicas_ind mz_cluster_replicas mz_catalog_server {id} ""
  436. mz_clusters_ind mz_clusters mz_catalog_server {id} ""
  437. mz_columns_ind mz_columns mz_catalog_server {name} ""
  438. mz_comments_ind mz_comments mz_catalog_server {id} ""
  439. mz_compute_dependencies_ind mz_compute_dependencies mz_catalog_server {dependency_id} ""
  440. mz_compute_dataflow_global_ids_per_worker_s2_primary_idx mz_compute_dataflow_global_ids_per_worker mz_catalog_server {id,worker_id} ""
  441. mz_compute_error_counts_raw_s2_primary_idx mz_compute_error_counts_raw mz_catalog_server {export_id,worker_id} ""
  442. mz_compute_exports_per_worker_s2_primary_idx mz_compute_exports_per_worker mz_catalog_server {export_id,worker_id} ""
  443. mz_compute_frontiers_per_worker_s2_primary_idx mz_compute_frontiers_per_worker mz_catalog_server {export_id,worker_id} ""
  444. mz_compute_hydration_times_ind mz_compute_hydration_times mz_catalog_server {replica_id} ""
  445. mz_compute_hydration_times_per_worker_s2_primary_idx mz_compute_hydration_times_per_worker mz_catalog_server {export_id,worker_id} ""
  446. mz_compute_import_frontiers_per_worker_s2_primary_idx mz_compute_import_frontiers_per_worker mz_catalog_server {export_id,import_id,worker_id} ""
  447. mz_compute_lir_mapping_per_worker_s2_primary_idx mz_compute_lir_mapping_per_worker mz_catalog_server {global_id,lir_id,worker_id} ""
  448. mz_compute_operator_durations_histogram_raw_s2_primary_idx mz_compute_operator_durations_histogram_raw mz_catalog_server {id,worker_id,duration_ns} ""
  449. mz_connections_ind mz_connections mz_catalog_server {schema_id} ""
  450. mz_console_cluster_utilization_overview_ind mz_console_cluster_utilization_overview mz_catalog_server {cluster_id} ""
  451. mz_continual_tasks_ind mz_continual_tasks mz_catalog_server {id} ""
  452. mz_databases_ind mz_databases mz_catalog_server {name} ""
  453. mz_dataflow_addresses_per_worker_s2_primary_idx mz_dataflow_addresses_per_worker mz_catalog_server {id,worker_id} ""
  454. mz_dataflow_channels_per_worker_s2_primary_idx mz_dataflow_channels_per_worker mz_catalog_server {id,worker_id} ""
  455. mz_dataflow_operator_reachability_raw_s2_primary_idx mz_dataflow_operator_reachability_raw mz_catalog_server {id,worker_id,source,port,update_type,time} ""
  456. mz_dataflow_operators_per_worker_s2_primary_idx mz_dataflow_operators_per_worker mz_catalog_server {id,worker_id} ""
  457. mz_dataflow_shutdown_durations_histogram_raw_s2_primary_idx mz_dataflow_shutdown_durations_histogram_raw mz_catalog_server {worker_id,duration_ns} ""
  458. mz_frontiers_ind mz_frontiers mz_catalog_server {object_id} ""
  459. mz_indexes_ind mz_indexes mz_catalog_server {id} ""
  460. mz_kafka_sources_ind mz_kafka_sources mz_catalog_server {id} ""
  461. mz_materialized_views_ind mz_materialized_views mz_catalog_server {id} ""
  462. mz_message_batch_counts_received_raw_s2_primary_idx mz_message_batch_counts_received_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  463. mz_message_batch_counts_sent_raw_s2_primary_idx mz_message_batch_counts_sent_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  464. mz_message_counts_received_raw_s2_primary_idx mz_message_counts_received_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  465. mz_message_counts_sent_raw_s2_primary_idx mz_message_counts_sent_raw mz_catalog_server {channel_id,from_worker_id,to_worker_id} ""
  466. mz_object_dependencies_ind mz_object_dependencies mz_catalog_server {object_id} ""
  467. mz_object_history_ind mz_object_history mz_catalog_server {id} ""
  468. mz_object_lifetimes_ind mz_object_lifetimes mz_catalog_server {id} ""
  469. mz_object_transitive_dependencies_ind mz_object_transitive_dependencies mz_catalog_server {object_id} ""
  470. mz_objects_ind mz_objects mz_catalog_server {schema_id} ""
  471. mz_notices_ind mz_notices mz_catalog_server {id} ""
  472. mz_peek_durations_histogram_raw_s2_primary_idx mz_peek_durations_histogram_raw mz_catalog_server {worker_id,type,duration_ns} ""
  473. mz_recent_activity_log_thinned_ind mz_recent_activity_log_thinned mz_catalog_server {sql_hash} ""
  474. mz_recent_storage_usage_ind mz_recent_storage_usage mz_catalog_server {object_id} ""
  475. mz_roles_ind mz_roles mz_catalog_server {id} ""
  476. mz_scheduling_elapsed_raw_s2_primary_idx mz_scheduling_elapsed_raw mz_catalog_server {id,worker_id} ""
  477. mz_scheduling_parks_histogram_raw_s2_primary_idx mz_scheduling_parks_histogram_raw mz_catalog_server {worker_id,slept_for_ns,requested_ns} ""
  478. mz_schemas_ind mz_schemas mz_catalog_server {database_id} ""
  479. mz_secrets_ind mz_secrets mz_catalog_server {name} ""
  480. mz_show_all_objects_ind mz_show_all_objects mz_catalog_server {schema_id} ""
  481. mz_show_cluster_replicas_ind mz_show_cluster_replicas mz_catalog_server {cluster} ""
  482. mz_show_clusters_ind mz_show_clusters mz_catalog_server {name} ""
  483. mz_show_columns_ind mz_show_columns mz_catalog_server {id} ""
  484. mz_show_connections_ind mz_show_connections mz_catalog_server {schema_id} ""
  485. mz_show_databases_ind mz_show_databases mz_catalog_server {name} ""
  486. mz_show_indexes_ind mz_show_indexes mz_catalog_server {schema_id} ""
  487. mz_show_materialized_views_ind mz_show_materialized_views mz_catalog_server {schema_id} ""
  488. mz_show_roles_ind mz_show_roles mz_catalog_server {name} ""
  489. mz_show_schemas_ind mz_show_schemas mz_catalog_server {database_id} ""
  490. mz_show_secrets_ind mz_show_secrets mz_catalog_server {schema_id} ""
  491. mz_show_sinks_ind mz_show_sinks mz_catalog_server {schema_id} ""
  492. mz_show_sources_ind mz_show_sources mz_catalog_server {schema_id} ""
  493. mz_show_tables_ind mz_show_tables mz_catalog_server {schema_id} ""
  494. mz_show_types_ind mz_show_types mz_catalog_server {schema_id} ""
  495. mz_show_views_ind mz_show_views mz_catalog_server {schema_id} ""
  496. mz_sink_statistics_ind mz_sink_statistics mz_catalog_server {id,replica_id} ""
  497. mz_sink_status_history_ind mz_sink_status_history mz_catalog_server {sink_id} ""
  498. mz_source_statistics_with_history_ind mz_source_statistics_with_history mz_catalog_server {id,replica_id} ""
  499. mz_sink_statuses_ind mz_sink_statuses mz_catalog_server {id} ""
  500. mz_sinks_ind mz_sinks mz_catalog_server {id} ""
  501. mz_source_statistics_ind mz_source_statistics mz_catalog_server {id,replica_id} ""
  502. mz_source_status_history_ind mz_source_status_history mz_catalog_server {source_id} ""
  503. mz_source_statuses_ind mz_source_statuses mz_catalog_server {id} ""
  504. mz_sources_ind mz_sources mz_catalog_server {id} ""
  505. mz_tables_ind mz_tables mz_catalog_server {schema_id} ""
  506. mz_types_ind mz_types mz_catalog_server {schema_id} ""
  507. mz_recent_sql_text_ind mz_recent_sql_text mz_catalog_server {sql_hash} ""
  508. mz_views_ind mz_views mz_catalog_server {schema_id} ""
  509. mz_wallclock_global_lag_recent_history_ind mz_wallclock_global_lag_recent_history mz_catalog_server {object_id} ""
  510. mz_webhook_sources_ind mz_webhook_sources mz_catalog_server {id} ""
  511. pg_attrdef_all_databases_ind pg_attrdef_all_databases mz_catalog_server {oid,adrelid,adnum,adbin,adsrc} ""
  512. pg_attribute_all_databases_ind pg_attribute_all_databases mz_catalog_server {attrelid,attname,atttypid,attlen,attnum,atttypmod,attnotnull,atthasdef,attidentity,attgenerated,attisdropped,attcollation,database_name,pg_type_database_name} ""
  513. pg_class_all_databases_ind pg_class_all_databases mz_catalog_server {relname} ""
  514. pg_description_all_databases_ind pg_description_all_databases mz_catalog_server {objoid,classoid,objsubid,description,oid_database_name,class_database_name} ""
  515. pg_namespace_all_databases_ind pg_namespace_all_databases mz_catalog_server {nspname} ""
  516. pg_type_all_databases_ind pg_type_all_databases mz_catalog_server {oid} ""