indexes.td 45 KB

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