diff --git a/product_docs/docs/pgd/5.6/monitoring/sql.mdx b/product_docs/docs/pgd/5.6/monitoring/sql.mdx index f4305f6d66c..a57699aefc5 100644 --- a/product_docs/docs/pgd/5.6/monitoring/sql.mdx +++ b/product_docs/docs/pgd/5.6/monitoring/sql.mdx @@ -90,6 +90,23 @@ The `catchup_state` can be one of the following: 40 = done ``` +## Monitoring the manager worker + +The manager worker is responsible for many background tasks, including the managing of all the other workers. As such it is important to know what it's doing, especially in cases where it might seem stuck. + +Accordingly, the [`bdr.stat_worker`](/pgd/latest/reference/catalogs-visible/#bdrstat_worker) view provides per worker statistics for PGD workers, including manager workers. With respect to ensuring manager workers do not get stuck, the current task they are executing would be reported in their `query` field prefixed by "pgd manager:". + +The `worker_backend_state` field for manager workers also reports whether the manager is idle or busy. + +## Monitoring Routing + +Routing is a critical part of PGD for ensuring a seemless application experience and conflict avoidance. Routing changes should happen quickly, including the detections of failures. At the same time we want to have as few disruptions as possible. We also want to ensure good load balancing for use-cases where it's supported. + +Monitoring all of these is important for noticing issues, debugging issues, as well as informing more optimal configurations. Accoringly, there are two main views for monitoring statistics to do with routing: + +- [`bdr.stat_routing_state`](/pgd/latest/reference/catalogs-visible/#bdrstat_routing_state) for monitoring the state of the connection routing with PGD Proxy uses to route the connections. +- [`bdr.stat_routing_candidate_state`](/pgd/latest/reference/catalogs-visible/#bdrstat_routing_candidate_state) for information about routing candidate nodes from the point of view of the Raft leader (the view is empty on other nodes). + ## Monitoring Replication Peers You use two main views for monitoring of replication activity: @@ -244,7 +261,7 @@ server's current WAL insert position. ### Monitoring incoming replication -You can monitor incoming replication (also called subscriptions) by querying +You can monitor incoming replication (also called subscriptions) at a high level by querying the `bdr.subscription_summary` view. This query shows the list of known subscriptions to other nodes in the EDB Postgres Distributed cluster and the state of the replication worker: @@ -266,6 +283,8 @@ sub_slot_name | bdr_postgres_bdrgroup_node1 subscription_status | replicating ``` +You can further monitor subscriptions by monitoring subscription summary statistics through [`bdr.stat_subscription`](/pgd/latest/reference/catalogs-visible/#bdrstat_subscription), and by monitoring the subscription replication receivers and subscription replication writers, using [`bdr.stat_receiver`](/pgd/latest/reference/catalogs-visible/#bdrstat_receiver) and [`bdr.stat_writer`](/pgd/latest/reference/catalogs-visible/#bdrstat_writer), respectively. + ### Monitoring WAL senders using LCR If the [decoding worker](../decoding_worker/) is enabled, you can monitor information about the @@ -307,7 +326,7 @@ So this view offers these insights into the state of a PGD system: - The wait_event column has enhanced information, if the reason for waiting is related to PGD. - The `query` column is blank in PGD workers, except - when a writer process is executing DDL. + when a writer process is executing DDL, or for when a manager worker is active (in which case the entry in the `query` column will be prefixed with "`pgd manager:`"). The `bdr.workers` view shows PGD worker-specific details that aren't available from `bdr.stat_activity`. @@ -340,6 +359,16 @@ means that the writer is the first one to commit. Value `-1` means that the commit position isn't yet known, which can happen for a streaming transaction or when the writer isn't currently applying any transaction. +## Monitoring commit scopes + +Commit scopes are our durability and consistency configuration framework. As such, they affect the performance of transactions, so it is important to get statistics on them. Moreover, because in failure scenarios transactions might appear to be stuck due to the commit scope configuration, we need insight into what commit scope is being used, what it's waiting on, and so on. + +Accordingly, these two views show relevant statistics about commit scopes: + +- [bdr.stat_commit_scope](/pgd/latest/reference/catalogs-visible/#bdrstat_commit_scope) for cumulative statistics for each commit scope. + +- [bdr.stat_commit_scope_state](/pgd/latest/reference/catalogs-visible/#bdrstat_commit_scope_state) for information about the current use of commit scopes by backend processes. + ## Monitoring global locks The global lock, which is currently used only for DDL replication, is a heavyweight @@ -451,8 +480,9 @@ nddl | 2 In this case, the subscription connected three times to the upstream, inserted 10 rows, and performed two DDL commands inside five transactions. -You can reset the stats counters for these views to zero using the functions -[`bdr.reset_subscription_stats`](/pgd/latest/reference/functions-internal#bdrreset_subscription_stats) and [`bdr.reset_relation_stats`](/pgd/latest/reference/functions-internal#bdrreset_relation_stats). +You can reset the stats counters for these views to zero using the functions [`bdr.reset_subscription_stats`](/pgd/latest/reference/functions-internal#bdrreset_subscription_stats) and [`bdr.reset_relation_stats`](/pgd/latest/reference/functions-internal#bdrreset_relation_stats). + +PGD also monitors statistics regarding subscription replication receivers and subscription replication writers for each subscription, using [`bdr.stat_receiver`](/pgd/latest/reference/catalogs-visible/#bdrstat_receiver) and [`bdr.stat_writer`](/pgd/latest/reference/catalogs-visible/#bdrstat_writer), respectively. ## Standard PostgreSQL statistics views @@ -623,9 +653,11 @@ to provide a cluster-wide Raft check. For example: bdrdb=# SELECT * FROM bdr.monitor_group_raft(); node_group_name | status | message ----------------|--------+------------------------------------- -myroup | OK | Raft Consensus is working correctly +mygroup | OK | Raft Consensus is working correctly ``` +Two further views that can give a finer-grained look at the state of Raft consensus are [`bdr.stat_raft_state`](/pgd/latest/reference/catalogs-visible/#bdrstat_raft_state), which provides the state of the Raft consensus on the local node, and [`bdr.stat_raft_followers_state`](/pgd/latest/reference/catalogs-visible/#bdrstat_raft_followers_state), which provides a view when on the Raft leader (it is empty on other nodes) regarding the state of the followers of that Raft leader. + ## Monitoring replication slots Each PGD node keeps: diff --git a/product_docs/docs/pgd/5.6/reference/catalogs-visible.mdx b/product_docs/docs/pgd/5.6/reference/catalogs-visible.mdx index 2800bbbeb86..abaee342e92 100644 --- a/product_docs/docs/pgd/5.6/reference/catalogs-visible.mdx +++ b/product_docs/docs/pgd/5.6/reference/catalogs-visible.mdx @@ -852,9 +852,118 @@ for internal PGD bookkeeping. Dynamic activity for each backend or worker process. -This contains the same information as `pg_stat_activity`, except `wait_event` +This contains the same information as [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW), except `wait_event` is set correctly when the wait relates to PGD. +### `bdr.stat_commit_scope` + +A view containing statistics for each commit scope. + +#### `bdr.stat_commit_scope` columns + +| Column | Type | Description | +| ------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------------------- | +| commit_scope_name | name | Name of the commit scope +| group_name | name | Name of group for which the commit scope is defined +| ncalls | bigint | The number of times the commit scope was used +| ncommits | bigint | The number of successful commits were made with the commit scope +| naborts | bigint | The number of times the commit scope used was eventually aborted +| total_commit_time | double precision | Total time spent committing using the commit scope +| min_commit_time | double precision | Minimum time spent committing using the commit scope +| max_commit_time | double precision | Maximum time spend committing using the commit scope +| mean_commit_time | double precision | Mean time spent committing using the commit scope +| stats_reset | timestamp with time zone | Time at which all statistics in the view were last reset + +### `bdr.stat_commit_scope_state` + +A view of information about the current use of commit scopes by backends. + +#### `bdr.stat_commit_scope_state` columns + +| Column | Type | Description | +| ------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------------------- | +| pid | integer | Process ID of the backend +| commit_scope_name | name | Name of the commit scope being used +| group_name | name | Name of group for which the commit scope is defined +| waiting_op_num | integer | Index of the first operation in the commit scope that is not satisfied yet +| waiting_prepare_confirmations| integer | The number of PREPARE confirmations that are still needed by the operation +| waiting_commit_confirmations| integer | The number of COMMIT confirmations that are still needed by the operation +| waiting_lsn_confirmations| integer | The number of LSN confirmations that are still needed by the operation + +### `bdr.stat_raft_followers_state` + +A view of the state of the raft leader's followers on the Raft leader node (empty on other nodes). + +#### `bdr.stat_raft_followers_state` columns + +| Column | Type | Description | +| ------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------------------- | +| group_name | name | The group this information is for (each group can have a separate consensus configured) +| node_name | name | Name of the follower node +| sent_commit_index | bigint | Latest Raft index sent to the follower node +| match_index | bigint | Raft index we expect to match the next response from the follower node +| last_message_time | timestamp with time zone | Last message (any, including requests) seen from the follower node +| last_heartbeat_send_time| timestamp with time zone| Last time the leader sent heartbeat to the follower node +| last_heartbeat_response_time| Lasat time the leader has seen a heartbeat response from the follower node +| approx_clock_drift_ms| bigint | Approximate clock drift seen by the leader against the follower node in milliseconds + +### `bdr.stat_raft_state` + +A view describing the state of the Raft consensus on the local node. + +#### `bdr.stat_raft_state` columns + +| Column | Type | Description | +| ------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------------------- | +| group_name | name | The group this information is for (each group can have a separate consensus configured) +| raft_stat | text | State of the local node in the Raft ('LEADER', 'CANDIDATE', 'FOLLOWER', 'STOPPED') +| leader_name | name | Name of the Raft leader, if any +| voted_for_name | name | The node the local node voted for as leader last vote +| is_voting | boolean | The local node part of Raft is voting +| heartbeat_timeout_ms| bigint | The heartbeat timeout on the local node +| heartbeat_elapsed_ms| bigint | The number of milliseconds that have elapsed since the local node has seen a heartbeat from the leader +| current_term | bigint | The current Raft term the local node is at +| commit_index | bigint | The current Raft commit index the local node is at +| apply_index | bigint | The Raft commit index the local node applied to catalogs +| last_log_term | bigint | Last Raft term in the request log +| last_log_index | bigint | Last Raft index in the request log +| oldest_log_index | bigint | Oldest Raft index still in the request log +| newest_prunable_log_index| bigint | Newest Raft index that can be safely removed from the request log +| snapshot_term | bigint | Raft term of the last snapshot +| snapshot_index | bigint | Raft index of the last snapshot +| nnodes | integer | Number of nodes in the Raft consensus (should normally be the same as the number of nodes in the group) +| nvoting_nodes | integer | Number of voting nodes in the Raft consensus + +### `bdr.stat_receiver` + +A view containing all the necessary info about the replication subscription receiver processes. + +#### `bdr.stat_receiver` columns + +| Column | Type | Description | +| ------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------------------- | +| worker_role | text | Role of the BDR worker (always 'receiver') +| worker_state | text | State of receiver worker (can be 'running', 'down', or 'disabled') +| worker_pid | integer | Process id of the receiver worker +| sub_name | name | Name of the subscription the receiver belongs to +| sub_slot_name | name | Replication slot name used by the receiver +| source_name | name | Source node for this receiver (the one it connects to), this is normally the same as the origin node, but is different for forward mode subscriptions +| origin_name | name | The origin node for this receiver (the one it receives forwarded changes from), this is normally the same as the source node, but is different for forward mode subscriptions +| subscription_mode | char | Mode of the subscription, see [`bdr.subscription_summary`](/pgd/latest/reference/catalogs-visible/#bdrsubscription_summary) for more details +| sub_replication_sets| text[] | Replication sets this receiver is subscribed to +| sub_apply_delay | interval | Apply delay interval +| receive_lsn | pg_lsn | LSN of the last change received so far +| receive_commit_lsn | pg_lsn | LSN of the last commit received so far +| xact_apply_lsn | pg_lsn | Last applied transaction LSN +| xact_flush_lsn | pg_lsn | Last flushed transaction LSN +| xact_apply_timestamp| timestamp with time zone | Last applied transaction (commit) timestamp +| worker_start | timestamp with time zone | Time at which the receiver started +| worker_xact_start | timestamp with time zome | Time at which the receiver started local db transaction (if it is currently processing a local transaction), usually NULL, see `xact_start` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| worker_backend_state_change | timestamp with time zone | Backend state change timestamp, see `state_change` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| worker_backend_state| text | Current backend state, see `state` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| wait_event_type | text | Type of wait event the receiver is currently waiting on (if any), see `wait_event_type` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| wait_event | text | Exact event the receiver is currently waiting on (if any, see `wait_event` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) + ### `bdr.stat_relation` Shows apply statistics for each relation. Contains data only if tracking is enabled with @@ -888,6 +997,35 @@ You can reset the stored relation statistics by calling | lock_acquire_time | double precision | Total time spent acquiring locks on the relation, in milliseconds (if `bdr.track_apply_lock_timing` is enabled, otherwise zero) | | stats_reset | timestamp with time zone | Time of the last statistics reset (performed by `bdr.reset_relation_stats()`) | +### `bdr.stat_routing_candidate_state` + +A view of information about the routing candidate nodes on the Raft leader (empty on other nodes). + +#### `bdr.stat_routing_candidate_state` columns + +| Column | Type | Description | +| ------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------------------- | +| node_group_name | name | The group this information is for (each group can have a separate routing proxy) +| node_name | name | Candidate node name +| node_route_fence | boolean | The node is fenced (when true it cannot become leader or read-only connection target) +| node_route_reads | boolean | The node is being considered as a read-only connection target +| node_route_writes | boolean | The node is being considered as a write lead candidate. +| last_message_time | timestamp with time zone | The time of the last Raft message (any, including requests) seen by this node (used to check liveness of node) + +### `bdr.stat_routing_state` + +A view of the state of the connection routing which PGD Proxy uses to route the connections. + +#### `bdr.stat_routing_state` columns + +| Column | Type | Description | +| -------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------- | +| node_group_name | name | The group this is information for (each group can have a separate routing proxy) +| write_lead_name | name | Name of the write lead node +| previous_write_lead_name| name | Name of the previous write lead node +| read_names | name[] | Array of nodes to which read-only connections are routed +| write_candidate_names| name[] | Nodes that match all criteria needed to become write lead in case of failover +| read_candidate_names | name[] | Nodes that match all criteria needed to become read-only connection targets in case of failover ### `bdr.stat_subscription` @@ -949,6 +1087,75 @@ You can reset the stored subscription statistics by calling | ncommit_waits | bigint | Number of fully applied transactions that had to wait before being committed. See [Parallel Apply](../parallelapply) | | stats_reset | timestamp with time zone | Time of the last statistics reset (performed by `bdr.reset_subscription_stats()`) | +### `bdr.stat_worker` + +A view containing summary information and per worker statistics for PGD manager workers. + +#### `bdr.stat_worker` columns + +| Column | Type | Description | +| -------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------- | +| worker_role | text | Role of the BDR worker +| worker_pid | integer | Process id of the worker +| sub_name | name | Name of the subscription the worker is related to, if any +| worker_start | timestamp with time zone | Time at which the worker started +| worker_xact_start | timestamp with time zone | Time at which the worker started the local db transaction, see `xact_start` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| worker_xid | xid | Transaction id of the worker, see `backend_xid` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| worker_xmin | xid | Oldest transaction id needed by the worker, see `backend_xmin` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| worker_backend_state_change| timestamp with time zone| Backend state change timestamp see `state_change` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| worker_backend_state | text | Current backend state see `state` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details +| wait_event_type | text | The type of wait event the worker is currently waitiing on, if any (see `wait_event_type` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| wait_event | text | The exact event the worker is waiting on, if any (see `wait_event` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| blocked_by_pids | integer[] | List of PIDs blocking the worker, if any +| query | text | Query currently being run by the worker +| worker_query_start | timestamp with time zone | Timestamp at which the current query run by the worker started + +### `bdr.stat_writer` + +A view containing summary information and statistics for each subscription replication writer. There can be multiple writers for each subscription. + +#### `bdr.stat_writer` columns + +| Column | Type | Description | +| -------------------- | ------------------------ | ------------------------------------------------------------------------------------------------------------------- | +| worker_role | text | Role of the BDR worker (always 'writer') +| worker_state | text | State of the worker (can be 'running', 'down', or 'disabled') +| worker_pid | integer | Process id of the writer +| sub_name | name | Name of the subscription the writer belongs to +| writer_nr | integer | Writer index in the writer group for the same subscription +| nxacts | bigint | The number of transactions the writer has processed since start +| ncommits | bigint | The number of commits the writer processed since start +| naborts | bigint | The number of aborts the writer processed since start +| commit_queue_position| integer | Position in the commit queue, when serializing transactions against other writers in the same writer group +| xact_source_xid | xid | Transaction id of the currently processed transaction on the source node +| xact_source_commit_lsn| pg_lsn | LSN of the currently processed transaction on the source node +| xact_nchanges | bigint | The number of changes in the currently processed transaction that have been written (updated every 1000 changes) +| xact_origin_node_name| name | Origin node of the currently processed transaction +| xact_origin_lsn | pg_lsn | Origin LSN of the currently processed transaction +| xact_origin_timestamp| timestamp with time zone | Origin commit timestamp of the currently processed transaction +| streaming_allowed | boolean | The writer can receive direct stream for large transactions +| is_streaming | boolean | The writer is currently receiving a direct stream of a large transaction +| nstream_file | bigint | The number of stream files the writer has processed +| nstream_writer | bigint | The number of directly streamed transactions the writer has processed +| worker_start | timestamp with time zone | The time at which the writer started +| worker_xact_start | timestamp with time zone | The time at which the writer start the local db transaction (see xact_start in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| worker_xid | xid | Transaction id of the worker (see `backend_xid` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| worker_xmin | xid | Oldest transaction id needed by the worker (see `backend_xmin` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| worker_backend_state_change| timestamp with time zone| Backend state change timestamp (see `state_change` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| worker_backend_state | text | Current backend state (see `state` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| wait_event_type | text | The type of wait event the writer is currently waiting on, if any (see `event_type` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| wait_event | text | The exact event the writer is waiting on, if any (see `wait_event` in [`pg_stat_activity`](https://www.postgresql.org/docs/current/monitoring-stats.html#MONITORING-PG-STAT-ACTIVITY-VIEW) for more details) +| blocked_by_pids | integer[] | List of PIDs blocking the writer, if any +| query | text | Query currently being run by the writer (normally only set for DDL) +| worker_query_start | timestamp with time zone | Timestamp at which the current query run by the worker started +| command_progress_cmdtag| text | For commands with progress tracking, identifies the command current processed by the writer (can be one of 'CREATE INDEX', 'CREATE INDEX CONCURRENTLY', 'REINDEX', 'REINDEX CONCURRENTLY', 'CLUSTER', and 'VACUUM FULL') +| command_progress_relation| text | For commands with progress tracking, identifies therelation which the command is working on +| command_progress_phase| text | For commands with progress tracking, name of the current phase the command is in, refer to [Progress Reporting](https://www.postgresql.org/docs/current/progress-reporting.html) in the Postgres documentation for details +| command_progress_count| integer | For commands with progress tracking, the number of phases this command has gone through +| command_progress_phase_nr | integer | For commands with progress tracking, the number of the phase of `command_progress_count` +| command_progress_phase_tuples_total| real | For commands with progress tracking, the number of rows the current phase of the command has to process (if the phase is process rows) +| command_progress_tuples_done| bigint | For commands with progress tracking, the number of rows the current phase of the command has already processed (if the phase is process rows) + ### `bdr.subscription` This catalog table lists all the subscriptions owned by the local PGD diff --git a/product_docs/docs/pgd/5.6/reference/index.json b/product_docs/docs/pgd/5.6/reference/index.json index 8163fee48bb..4e2b1c44920 100644 --- a/product_docs/docs/pgd/5.6/reference/index.json +++ b/product_docs/docs/pgd/5.6/reference/index.json @@ -1,350 +1,342 @@ { - "bdrcamo_decision_journal": "/pgd/latest/reference/catalogs-visible#bdrcamo_decision_journal", - "bdrcommit_scopes": "/pgd/latest/reference/catalogs-visible#bdrcommit_scopes", - "bdrconflict_history": "/pgd/latest/reference/catalogs-visible#bdrconflict_history", - "bdrconflict_history_summary": "/pgd/latest/reference/catalogs-visible#bdrconflict_history_summary", - "bdrconsensus_kv_data": "/pgd/latest/reference/catalogs-visible#bdrconsensus_kv_data", - "bdrcrdt_handlers": "/pgd/latest/reference/catalogs-visible#bdrcrdt_handlers", - "bdrddl_replication": "/pgd/latest/reference/pgd-settings#bdrddl_replication", - "bdrdepend": "/pgd/latest/reference/catalogs-visible#bdrdepend", - "bdrglobal_consensus_journal": "/pgd/latest/reference/catalogs-visible#bdrglobal_consensus_journal", - "bdrglobal_consensus_journal_details": "/pgd/latest/reference/catalogs-visible#bdrglobal_consensus_journal_details", - "bdrglobal_consensus_response_journal": "/pgd/latest/reference/catalogs-visible#bdrglobal_consensus_response_journal", - "bdrglobal_lock": "/pgd/latest/reference/catalogs-visible#bdrglobal_lock", - "bdrglobal_locks": "/pgd/latest/reference/catalogs-visible#bdrglobal_locks", - "bdrgroup_camo_details": "/pgd/latest/reference/catalogs-visible#bdrgroup_camo_details", - "bdrgroup_raft_details": "/pgd/latest/reference/catalogs-visible#bdrgroup_raft_details", - "bdrgroup_replslots_details": "/pgd/latest/reference/catalogs-visible#bdrgroup_replslots_details", - "bdrgroup_subscription_summary": "/pgd/latest/reference/catalogs-visible#bdrgroup_subscription_summary", - "bdrgroup_versions_details": "/pgd/latest/reference/catalogs-visible#bdrgroup_versions_details", - "bdrlocal_consensus_snapshot": "/pgd/latest/reference/catalogs-visible#bdrlocal_consensus_snapshot", - "bdrlocal_consensus_state": "/pgd/latest/reference/catalogs-visible#bdrlocal_consensus_state", - "bdrlocal_node": "/pgd/latest/reference/catalogs-visible#bdrlocal_node", - "bdrlocal_node_summary": "/pgd/latest/reference/catalogs-visible#bdrlocal_node_summary", - "bdrlocal_sync_status": "/pgd/latest/reference/catalogs-visible#bdrlocal_sync_status", - "bdrnode": "/pgd/latest/reference/catalogs-visible#bdrnode", - "bdrnode_catchup_info": "/pgd/latest/reference/catalogs-visible#bdrnode_catchup_info", - "bdrnode_catchup_info_details": "/pgd/latest/reference/catalogs-visible#bdrnode_catchup_info_details", - "bdrnode_conflict_resolvers": "/pgd/latest/reference/catalogs-visible#bdrnode_conflict_resolvers", - "bdrnode_group": "/pgd/latest/reference/catalogs-visible#bdrnode_group", - "bdrnode_group_replication_sets": "/pgd/latest/reference/catalogs-visible#bdrnode_group_replication_sets", - "bdrnode_group_summary": "/pgd/latest/reference/catalogs-visible#bdrnode_group_summary", - "bdrnode_local_info": "/pgd/latest/reference/catalogs-visible#bdrnode_local_info", - "bdrnode_log_config": "/pgd/latest/reference/catalogs-visible#bdrnode_log_config", - "bdrnode_peer_progress": "/pgd/latest/reference/catalogs-visible#bdrnode_peer_progress", - "bdrnode_replication_rates": "/pgd/latest/reference/catalogs-visible#bdrnode_replication_rates", - "bdrnode_slots": "/pgd/latest/reference/catalogs-visible#bdrnode_slots", - "bdrnode_summary": "/pgd/latest/reference/catalogs-visible#bdrnode_summary", - "bdrqueue": "/pgd/latest/reference/catalogs-visible#bdrqueue", - "bdrreplication_set": "/pgd/latest/reference/catalogs-visible#bdrreplication_set", - "bdrreplication_set_table": "/pgd/latest/reference/catalogs-visible#bdrreplication_set_table", - "bdrreplication_set_ddl": "/pgd/latest/reference/catalogs-visible#bdrreplication_set_ddl", - "bdrreplication_sets": "/pgd/latest/reference/catalogs-visible#bdrreplication_sets", - "bdrschema_changes": "/pgd/latest/reference/catalogs-visible#bdrschema_changes", - "bdrsequence_alloc": "/pgd/latest/reference/catalogs-visible#bdrsequence_alloc", - "bdrsequences": "/pgd/latest/reference/catalogs-visible#bdrsequences", - "bdrstat_activity": "/pgd/latest/reference/catalogs-visible#bdrstat_activity", - "bdrstat_relation": "/pgd/latest/reference/catalogs-visible#bdrstat_relation", - "bdrstat_subscription": "/pgd/latest/reference/catalogs-visible#bdrstat_subscription", - "bdrsubscription": "/pgd/latest/reference/catalogs-visible#bdrsubscription", - "bdrsubscription_summary": "/pgd/latest/reference/catalogs-visible#bdrsubscription_summary", - "bdrtables": "/pgd/latest/reference/catalogs-visible#bdrtables", - "bdrtaskmgr_work_queue": "/pgd/latest/reference/catalogs-visible#bdrtaskmgr_work_queue", - "bdrtaskmgr_workitem_status": "/pgd/latest/reference/catalogs-visible#bdrtaskmgr_workitem_status", - "bdrtaskmgr_local_work_queue": "/pgd/latest/reference/catalogs-visible#bdrtaskmgr_local_work_queue", - "bdrtaskmgr_local_workitem_status": "/pgd/latest/reference/catalogs-visible#bdrtaskmgr_local_workitem_status", - "bdrtrigger": "/pgd/latest/reference/catalogs-visible#bdrtrigger", - "bdrtriggers": "/pgd/latest/reference/catalogs-visible#bdrtriggers", - "bdrworkers": "/pgd/latest/reference/catalogs-visible#bdrworkers", - "bdrwriters": "/pgd/latest/reference/catalogs-visible#bdrwriters", - "bdrworker_tasks": "/pgd/latest/reference/catalogs-visible#bdrworker_tasks", - "bdrbdr_version": "/pgd/latest/reference/functions#bdrbdr_version", - "bdrbdr_version_num": "/pgd/latest/reference/functions#bdrbdr_version_num", - "bdrget_relation_stats": "/pgd/latest/reference/functions#bdrget_relation_stats", - "bdrget_subscription_stats": "/pgd/latest/reference/functions#bdrget_subscription_stats", - "bdrlocal_node_id": "/pgd/latest/reference/functions#bdrlocal_node_id", - "bdrlast_committed_lsn": "/pgd/latest/reference/functions#bdrlast_committed_lsn", - "transaction_id": "/pgd/latest/reference/functions#transaction_id", - "bdris_node_connected": "/pgd/latest/reference/functions#bdris_node_connected", - "bdris_node_ready": "/pgd/latest/reference/functions#bdris_node_ready", - "bdrconsensus_disable": "/pgd/latest/reference/functions#bdrconsensus_disable", - "bdrconsensus_enable": "/pgd/latest/reference/functions#bdrconsensus_enable", - "bdrconsensus_proto_version": "/pgd/latest/reference/functions#bdrconsensus_proto_version", - "bdrconsensus_snapshot_export": "/pgd/latest/reference/functions#bdrconsensus_snapshot_export", - "bdrconsensus_snapshot_import": "/pgd/latest/reference/functions#bdrconsensus_snapshot_import", - "bdrconsensus_snapshot_verify": "/pgd/latest/reference/functions#bdrconsensus_snapshot_verify", - "bdrget_consensus_status": "/pgd/latest/reference/functions#bdrget_consensus_status", - "bdrget_raft_status": "/pgd/latest/reference/functions#bdrget_raft_status", - "bdrraft_leadership_transfer": "/pgd/latest/reference/functions#bdrraft_leadership_transfer", - "bdrwait_slot_confirm_lsn": "/pgd/latest/reference/functions#bdrwait_slot_confirm_lsn", - "bdrwait_for_apply_queue": "/pgd/latest/reference/functions#bdrwait_for_apply_queue", - "bdrget_node_sub_receive_lsn": "/pgd/latest/reference/functions#bdrget_node_sub_receive_lsn", - "bdrget_node_sub_apply_lsn": "/pgd/latest/reference/functions#bdrget_node_sub_apply_lsn", - "bdrreplicate_ddl_command": "/pgd/latest/reference/functions#bdrreplicate_ddl_command", - "bdrrun_on_all_nodes": "/pgd/latest/reference/functions#bdrrun_on_all_nodes", - "bdrrun_on_nodes": "/pgd/latest/reference/functions#bdrrun_on_nodes", - "bdrrun_on_group": "/pgd/latest/reference/functions#bdrrun_on_group", - "bdrglobal_lock_table": "/pgd/latest/reference/functions#bdrglobal_lock_table", - "bdrwait_for_xid_progress": "/pgd/latest/reference/functions#bdrwait_for_xid_progress", - "bdrlocal_group_slot_name": "/pgd/latest/reference/functions#bdrlocal_group_slot_name", - "bdrnode_group_type": "/pgd/latest/reference/functions#bdrnode_group_type", - "bdralter_node_kind": "/pgd/latest/reference/functions#bdralter_node_kind", - "bdralter_subscription_skip_changes_upto": "/pgd/latest/reference/functions#bdralter_subscription_skip_changes_upto", - "bdrglobal_advisory_lock": "/pgd/latest/reference/functions#bdrglobal_advisory_lock", - "bdrglobal_advisory_unlock": "/pgd/latest/reference/functions#bdrglobal_advisory_unlock", - "bdrmonitor_group_versions": "/pgd/latest/reference/functions#bdrmonitor_group_versions", - "bdrmonitor_group_raft": "/pgd/latest/reference/functions#bdrmonitor_group_raft", - "bdrmonitor_local_replslots": "/pgd/latest/reference/functions#bdrmonitor_local_replslots", - "bdrwal_sender_stats": "/pgd/latest/reference/functions#bdrwal_sender_stats", - "bdrget_decoding_worker_stat": "/pgd/latest/reference/functions#bdrget_decoding_worker_stat", - "bdrlag_control": "/pgd/latest/reference/functions#bdrlag_control", - "bdris_camo_partner_connected": "/pgd/latest/reference/functions#bdris_camo_partner_connected", - "bdris_camo_partner_ready": "/pgd/latest/reference/functions#bdris_camo_partner_ready", - "bdrget_configured_camo_partner": "/pgd/latest/reference/functions#bdrget_configured_camo_partner", - "bdrwait_for_camo_partner_queue": "/pgd/latest/reference/functions#bdrwait_for_camo_partner_queue", - "bdrcamo_transactions_resolved": "/pgd/latest/reference/functions#bdrcamo_transactions_resolved", - "bdrlogical_transaction_status": "/pgd/latest/reference/functions#bdrlogical_transaction_status", - "bdradd_commit_scope": "/pgd/latest/reference/functions#bdradd_commit_scope", - "bdralter_commit_scope": "/pgd/latest/reference/functions#bdralter_commit_scope", - "bdrremove_commit_scope": "/pgd/latest/reference/functions#bdrremove_commit_scope", - "bdrdefault_conflict_detection": "/pgd/latest/reference/pgd-settings#bdrdefault_conflict_detection", - "bdrdefault_sequence_kind": "/pgd/latest/reference/pgd-settings#bdrdefault_sequence_kind", - "bdrdefault_replica_identity": "/pgd/latest/reference/pgd-settings#bdrdefault_replica_identity", - "bdrrole_replication": "/pgd/latest/reference/pgd-settings#bdrrole_replication", - "bdrddl_locking": "/pgd/latest/reference/pgd-settings#bdrddl_locking", - "bdrtruncate_locking": "/pgd/latest/reference/pgd-settings#bdrtruncate_locking", - "bdrglobal_lock_max_locks": "/pgd/latest/reference/pgd-settings#bdrglobal_lock_max_locks", - "bdrglobal_lock_timeout": "/pgd/latest/reference/pgd-settings#bdrglobal_lock_timeout", - "bdrglobal_lock_statement_timeout": "/pgd/latest/reference/pgd-settings#bdrglobal_lock_statement_timeout", - "bdrglobal_lock_idle_timeout": "/pgd/latest/reference/pgd-settings#bdrglobal_lock_idle_timeout", - "bdrlock_table_locking": "/pgd/latest/reference/pgd-settings#bdrlock_table_locking", - "bdrpredictive_checks": "/pgd/latest/reference/pgd-settings#bdrpredictive_checks", - "bdrreplay_progress_frequency": "/pgd/latest/reference/pgd-settings#bdrreplay_progress_frequency", - "bdrstandby_slot_names": "/pgd/latest/reference/pgd-settings#bdrstandby_slot_names", - "bdrwriters_per_subscription": "/pgd/latest/reference/pgd-settings#bdrwriters_per_subscription", - "bdrmax_writers_per_subscription": "/pgd/latest/reference/pgd-settings#bdrmax_writers_per_subscription", - "bdrxact_replication": "/pgd/latest/reference/pgd-settings#bdrxact_replication", - "bdrpermit_unsafe_commands": "/pgd/latest/reference/pgd-settings#bdrpermit_unsafe_commands", - "bdrbatch_inserts": "/pgd/latest/reference/pgd-settings#bdrbatch_inserts", - "bdrmaximum_clock_skew": "/pgd/latest/reference/pgd-settings#bdrmaximum_clock_skew", - "bdrmaximum_clock_skew_action": "/pgd/latest/reference/pgd-settings#bdrmaximum_clock_skew_action", - "bdraccept_connections": "/pgd/latest/reference/pgd-settings#bdraccept_connections", - "bdrstandby_slots_min_confirmed": "/pgd/latest/reference/pgd-settings#bdrstandby_slots_min_confirmed", - "bdrwriter_input_queue_size": "/pgd/latest/reference/pgd-settings#bdrwriter_input_queue_size", - "bdrwriter_output_queue_size": "/pgd/latest/reference/pgd-settings#bdrwriter_output_queue_size", - "bdrmin_worker_backoff_delay": "/pgd/latest/reference/pgd-settings#bdrmin_worker_backoff_delay", - "bdrcrdt_raw_value": "/pgd/latest/reference/pgd-settings#bdrcrdt_raw_value", - "bdrcommit_scope": "/pgd/latest/reference/pgd-settings#bdrcommit_scope", - "bdrcamo_local_mode_delay": "/pgd/latest/reference/pgd-settings#bdrcamo_local_mode_delay", - "bdrcamo_enable_client_warnings": "/pgd/latest/reference/pgd-settings#bdrcamo_enable_client_warnings", - "bdrdefault_streaming_mode": "/pgd/latest/reference/pgd-settings#bdrdefault_streaming_mode", - "bdrlag_control_max_commit_delay": "/pgd/latest/reference/pgd-settings#bdrlag_control_max_commit_delay", - "bdrlag_control_max_lag_size": "/pgd/latest/reference/pgd-settings#bdrlag_control_max_lag_size", - "bdrlag_control_max_lag_time": "/pgd/latest/reference/pgd-settings#bdrlag_control_max_lag_time", - "bdrlag_control_min_conforming_nodes": "/pgd/latest/reference/pgd-settings#bdrlag_control_min_conforming_nodes", - "bdrlag_control_commit_delay_adjust": "/pgd/latest/reference/pgd-settings#bdrlag_control_commit_delay_adjust", - "bdrlag_control_sample_interval": "/pgd/latest/reference/pgd-settings#bdrlag_control_sample_interval", - "bdrlag_control_commit_delay_start": "/pgd/latest/reference/pgd-settings#bdrlag_control_commit_delay_start", - "bdrtimestamp_snapshot_keep": "/pgd/latest/reference/pgd-settings#bdrtimestamp_snapshot_keep", - "bdrdebug_level": "/pgd/latest/reference/pgd-settings#bdrdebug_level", - "bdrtrace_level": "/pgd/latest/reference/pgd-settings#bdrtrace_level", - "bdrtrack_subscription_apply": "/pgd/latest/reference/pgd-settings#bdrtrack_subscription_apply", - "bdrtrack_relation_apply": "/pgd/latest/reference/pgd-settings#bdrtrack_relation_apply", - "bdrtrack_apply_lock_timing": "/pgd/latest/reference/pgd-settings#bdrtrack_apply_lock_timing", - "bdrenable_wal_decoder": "/pgd/latest/reference/pgd-settings#bdrenable_wal_decoder", - "bdrreceive_lcr": "/pgd/latest/reference/pgd-settings#bdrreceive_lcr", - "bdrlcr_cleanup_interval": "/pgd/latest/reference/pgd-settings#bdrlcr_cleanup_interval", - "bdrglobal_connection_timeout": "/pgd/latest/reference/pgd-settings#bdrglobal_connection_timeout", - "bdrglobal_keepalives": "/pgd/latest/reference/pgd-settings#bdrglobal_keepalives", - "bdrglobal_keepalives_idle": "/pgd/latest/reference/pgd-settings#bdrglobal_keepalives_idle", - "bdrglobal_keepalives_interval": "/pgd/latest/reference/pgd-settings#bdrglobal_keepalives_interval", - "bdrglobal_keepalives_count": "/pgd/latest/reference/pgd-settings#bdrglobal_keepalives_count", - "bdrglobal_tcp_user_timeout": "/pgd/latest/reference/pgd-settings#bdrglobal_tcp_user_timeout", - "bdrraft_global_election_timeout": "/pgd/latest/reference/pgd-settings#bdrraft_global_election_timeout", - "bdrraft_group_election_timeout": "/pgd/latest/reference/pgd-settings#bdrraft_group_election_timeout", - "bdrraft_response_timeout": "/pgd/latest/reference/pgd-settings#bdrraft_response_timeout", - "bdrraft_keep_min_entries": "/pgd/latest/reference/pgd-settings#bdrraft_keep_min_entries", - "bdrraft_log_min_apply_duration": "/pgd/latest/reference/pgd-settings#bdrraft_log_min_apply_duration", - "bdrraft_log_min_message_duration": "/pgd/latest/reference/pgd-settings#bdrraft_log_min_message_duration", - "bdrraft_group_max_connections": "/pgd/latest/reference/pgd-settings#bdrraft_group_max_connections", - "bdrbackwards_compatibility": "/pgd/latest/reference/pgd-settings#bdrbackwards_compatibility", - "bdrtrack_replication_estimates": "/pgd/latest/reference/pgd-settings#bdrtrack_replication_estimates", - "bdrlag_tracker_apply_rate_weight": "/pgd/latest/reference/pgd-settings#bdrlag_tracker_apply_rate_weight", - "bdrenable_auto_sync_reconcile": "/pgd/latest/reference/pgd-settings#bdrenable_auto_sync_reconcile", - "list-of-node-states": "/pgd/latest/reference/nodes#list-of-node-states", - "node-management-commands": "/pgd/latest/reference/nodes#node-management-commands", - "bdr_init_physical": "/pgd/latest/reference/nodes#bdr_init_physical", - "bdralter_node_group_option": "/pgd/latest/reference/nodes-management-interfaces#bdralter_node_group_option", - "bdralter_node_interface": "/pgd/latest/reference/nodes-management-interfaces#bdralter_node_interface", - "bdralter_node_option": "/pgd/latest/reference/nodes-management-interfaces#bdralter_node_option", - "bdralter_subscription_enable": "/pgd/latest/reference/nodes-management-interfaces#bdralter_subscription_enable", - "bdralter_subscription_disable": "/pgd/latest/reference/nodes-management-interfaces#bdralter_subscription_disable", - "bdrcreate_node": "/pgd/latest/reference/nodes-management-interfaces#bdrcreate_node", - "bdrcreate_node_group": "/pgd/latest/reference/nodes-management-interfaces#bdrcreate_node_group", - "bdrjoin_node_group": "/pgd/latest/reference/nodes-management-interfaces#bdrjoin_node_group", - "bdrpart_node": "/pgd/latest/reference/nodes-management-interfaces#bdrpart_node", - "bdrpromote_node": "/pgd/latest/reference/nodes-management-interfaces#bdrpromote_node", - "bdrswitch_node_group": "/pgd/latest/reference/nodes-management-interfaces#bdrswitch_node_group", - "bdrwait_for_join_completion": "/pgd/latest/reference/nodes-management-interfaces#bdrwait_for_join_completion", - "bdralter_node_group_config": "/pgd/latest/reference/nodes-management-interfaces#bdralter_node_group_config", - "bdrdrop_node_group": "/pgd/latest/reference/nodes-management-interfaces#bdrdrop_node_group", - "bdrcreate_proxy": "/pgd/latest/reference/routing#bdrcreate_proxy", - "bdralter_proxy_option": "/pgd/latest/reference/routing#bdralter_proxy_option", - "bdrdrop_proxy": "/pgd/latest/reference/routing#bdrdrop_proxy", - "bdrrouting_leadership_transfer": "/pgd/latest/reference/routing#bdrrouting_leadership_transfer", - "cs.commit-scope-syntax": "/pgd/latest/reference/commit-scopes#commit-scope-syntax", - "cs.commit-scope-groups": "/pgd/latest/reference/commit-scopes#commit-scope-groups", - "cs.any": "/pgd/latest/reference/commit-scopes#any", - "cs.any-not": "/pgd/latest/reference/commit-scopes#any-not", - "cs.majority": "/pgd/latest/reference/commit-scopes#majority", - "cs.majority-not": "/pgd/latest/reference/commit-scopes#majority-not", - "cs.all": "/pgd/latest/reference/commit-scopes#all", - "cs.all-not": "/pgd/latest/reference/commit-scopes#all-not", - "cs.confirmation-level": "/pgd/latest/reference/commit-scopes#confirmation-level", - "cs.on-received": "/pgd/latest/reference/commit-scopes#on-received", - "cs.on-replicated": "/pgd/latest/reference/commit-scopes#on-replicated", - "cs.on-durable": "/pgd/latest/reference/commit-scopes#on-durable", - "cs.on-visible": "/pgd/latest/reference/commit-scopes#on-visible", - "cs.commit-scope-kinds": "/pgd/latest/reference/commit-scopes#commit-scope-kinds", - "cs.group-commit": "/pgd/latest/reference/commit-scopes#group-commit", - "cs.group-commit-parameters": "/pgd/latest/reference/commit-scopes#group-commit-parameters", - "cs.abort-on-parameters": "/pgd/latest/reference/commit-scopes#abort-on-parameters", - "cs.transaction_tracking-settings": "/pgd/latest/reference/commit-scopes#transaction_tracking-settings", - "cs.conflict_resolution-settings": "/pgd/latest/reference/commit-scopes#conflict_resolution-settings", - "cs.commit_decision-settings": "/pgd/latest/reference/commit-scopes#commit_decision-settings", - "cs.camo": "/pgd/latest/reference/commit-scopes#camo", - "cs.degrade-on-parameters": "/pgd/latest/reference/commit-scopes#degrade-on-parameters", - "cs.lag-control": "/pgd/latest/reference/commit-scopes#lag-control", - "cs.lag-control-parameters": "/pgd/latest/reference/commit-scopes#lag-control-parameters", - "cs.synchronous_commit": "/pgd/latest/reference/commit-scopes#synchronous_commit", - "conflict-detection": "/pgd/latest/reference/conflicts#conflict-detection", - "list-of-conflict-types": "/pgd/latest/reference/conflicts#list-of-conflict-types", - "conflict-resolution": "/pgd/latest/reference/conflicts#conflict-resolution", - "list-of-conflict-resolvers": "/pgd/latest/reference/conflicts#list-of-conflict-resolvers", - "default-conflict-resolvers": "/pgd/latest/reference/conflicts#default-conflict-resolvers", - "list-of-conflict-resolutions": "/pgd/latest/reference/conflicts#list-of-conflict-resolutions", - "conflict-logging": "/pgd/latest/reference/conflicts#conflict-logging", - "bdralter_table_conflict_detection": "/pgd/latest/reference/conflict_functions#bdralter_table_conflict_detection", - "bdralter_node_set_conflict_resolver": "/pgd/latest/reference/conflict_functions#bdralter_node_set_conflict_resolver", - "bdralter_node_set_log_config": "/pgd/latest/reference/conflict_functions#bdralter_node_set_log_config", - "bdrcreate_replication_set": "/pgd/latest/reference/repsets-management#bdrcreate_replication_set", - "bdralter_replication_set": "/pgd/latest/reference/repsets-management#bdralter_replication_set", - "bdrdrop_replication_set": "/pgd/latest/reference/repsets-management#bdrdrop_replication_set", - "bdralter_node_replication_sets": "/pgd/latest/reference/repsets-management#bdralter_node_replication_sets", - "bdrreplication_set_add_table": "/pgd/latest/reference/repsets-membership#bdrreplication_set_add_table", - "bdrreplication_set_remove_table": "/pgd/latest/reference/repsets-membership#bdrreplication_set_remove_table", - "bdrreplication_set_add_ddl_filter": "/pgd/latest/reference/repsets-ddl-filtering#bdrreplication_set_add_ddl_filter", - "bdrreplication_set_remove_ddl_filter": "/pgd/latest/reference/repsets-ddl-filtering#bdrreplication_set_remove_ddl_filter", - "pgd_bench": "/pgd/latest/reference/testingandtuning#pgd_bench", - "bdralter_sequence_set_kind": "/pgd/latest/reference/sequences#bdralter_sequence_set_kind", - "bdrextract_timestamp_from_snowflakeid": "/pgd/latest/reference/sequences#bdrextract_timestamp_from_snowflakeid", - "bdrextract_nodeid_from_snowflakeid": "/pgd/latest/reference/sequences#bdrextract_nodeid_from_snowflakeid", - "bdrextract_localseqid_from_snowflakeid": "/pgd/latest/reference/sequences#bdrextract_localseqid_from_snowflakeid", - "bdrtimestamp_to_snowflakeid": "/pgd/latest/reference/sequences#bdrtimestamp_to_snowflakeid", - "bdrextract_timestamp_from_timeshard": "/pgd/latest/reference/sequences#bdrextract_timestamp_from_timeshard", - "bdrextract_nodeid_from_timeshard": "/pgd/latest/reference/sequences#bdrextract_nodeid_from_timeshard", - "bdrextract_localseqid_from_timeshard": "/pgd/latest/reference/sequences#bdrextract_localseqid_from_timeshard", - "bdrtimestamp_to_timeshard": "/pgd/latest/reference/sequences#bdrtimestamp_to_timeshard", - "bdrgen_ksuuid_v2": "/pgd/latest/reference/sequences#bdrgen_ksuuid_v2", - "bdrksuuid_v2_cmp": "/pgd/latest/reference/sequences#bdrksuuid_v2_cmp", - "bdrextract_timestamp_from_ksuuid_v2": "/pgd/latest/reference/sequences#bdrextract_timestamp_from_ksuuid_v2", - "bdrgen_ksuuid": "/pgd/latest/reference/sequences#bdrgen_ksuuid", - "bdruuid_v1_cmp": "/pgd/latest/reference/sequences#bdruuid_v1_cmp", - "bdrextract_timestamp_from_ksuuid": "/pgd/latest/reference/sequences#bdrextract_timestamp_from_ksuuid", - "bdrautopartition": "/pgd/latest/reference/autopartition#bdrautopartition", - "bdrdrop_autopartition": "/pgd/latest/reference/autopartition#bdrdrop_autopartition", - "bdrautopartition_wait_for_partitions": "/pgd/latest/reference/autopartition#bdrautopartition_wait_for_partitions", - "bdrautopartition_wait_for_partitions_on_all_nodes": "/pgd/latest/reference/autopartition#bdrautopartition_wait_for_partitions_on_all_nodes", - "bdrautopartition_find_partition": "/pgd/latest/reference/autopartition#bdrautopartition_find_partition", - "bdrautopartition_enable": "/pgd/latest/reference/autopartition#bdrautopartition_enable", - "bdrautopartition_disable": "/pgd/latest/reference/autopartition#bdrautopartition_disable", - "internal-functions": "/pgd/latest/reference/autopartition#internal-functions", - "bdrautopartition_create_partition": "/pgd/latest/reference/autopartition#bdrautopartition_create_partition", - "bdrautopartition_drop_partition": "/pgd/latest/reference/autopartition#bdrautopartition_drop_partition", - "bdrcreate_conflict_trigger": "/pgd/latest/reference/streamtriggers/interfaces#bdrcreate_conflict_trigger", - "bdrcreate_transform_trigger": "/pgd/latest/reference/streamtriggers/interfaces#bdrcreate_transform_trigger", - "bdrdrop_trigger": "/pgd/latest/reference/streamtriggers/interfaces#bdrdrop_trigger", - "bdrtrigger_get_row": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrtrigger_get_row", - "bdrtrigger_get_committs": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrtrigger_get_committs", - "bdrtrigger_get_xid": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrtrigger_get_xid", - "bdrtrigger_get_type": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrtrigger_get_type", - "bdrtrigger_get_conflict_type": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrtrigger_get_conflict_type", - "bdrtrigger_get_origin_node_id": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrtrigger_get_origin_node_id", - "bdrri_fkey_on_del_trigger": "/pgd/latest/reference/streamtriggers/rowfunctions#bdrri_fkey_on_del_trigger", - "tg_name": "/pgd/latest/reference/streamtriggers/rowvariables#tg_name", - "tg_when": "/pgd/latest/reference/streamtriggers/rowvariables#tg_when", - "tg_level": "/pgd/latest/reference/streamtriggers/rowvariables#tg_level", - "tg_op": "/pgd/latest/reference/streamtriggers/rowvariables#tg_op", - "tg_relid": "/pgd/latest/reference/streamtriggers/rowvariables#tg_relid", - "tg_table_name": "/pgd/latest/reference/streamtriggers/rowvariables#tg_table_name", - "tg_table_schema": "/pgd/latest/reference/streamtriggers/rowvariables#tg_table_schema", - "tg_nargs": "/pgd/latest/reference/streamtriggers/rowvariables#tg_nargs", - "tg_argv": "/pgd/latest/reference/streamtriggers/rowvariables#tg_argv", - "bdrautopartition_partitions": "/pgd/latest/reference/catalogs-internal#bdrautopartition_partitions", - "bdrautopartition_rules": "/pgd/latest/reference/catalogs-internal#bdrautopartition_rules", - "bdrddl_epoch": "/pgd/latest/reference/catalogs-internal#bdrddl_epoch", - "bdrevent_history": "/pgd/latest/reference/catalogs-internal#bdrevent_history", - "bdrevent_summary": "/pgd/latest/reference/catalogs-internal#bdrevent_summary", - "bdrnode_config": "/pgd/latest/reference/catalogs-internal#bdrnode_config", - "bdrnode_group_config": "/pgd/latest/reference/catalogs-internal#bdrnode_group_config", - "bdrnode_group_routing_config_summary": "/pgd/latest/reference/catalogs-internal#bdrnode_group_routing_config_summary", - "bdrnode_group_routing_info": "/pgd/latest/reference/catalogs-internal#bdrnode_group_routing_info", - "bdrnode_group_routing_summary": "/pgd/latest/reference/catalogs-internal#bdrnode_group_routing_summary", - "bdrnode_routing_config_summary": "/pgd/latest/reference/catalogs-internal#bdrnode_routing_config_summary", - "bdrproxy_config": "/pgd/latest/reference/catalogs-internal#bdrproxy_config", - "bdrproxy_config_summary": "/pgd/latest/reference/catalogs-internal#bdrproxy_config_summary", - "bdrsequence_kind": "/pgd/latest/reference/catalogs-internal#bdrsequence_kind", - "bdrbdr_get_commit_decisions": "/pgd/latest/reference/functions-internal#bdrbdr_get_commit_decisions", - "bdrbdr_track_commit_decision": "/pgd/latest/reference/functions-internal#bdrbdr_track_commit_decision", - "bdrconsensus_kv_fetch": "/pgd/latest/reference/functions-internal#bdrconsensus_kv_fetch", - "bdrconsensus_kv_store": "/pgd/latest/reference/functions-internal#bdrconsensus_kv_store", - "bdrdecode_message_payload": "/pgd/latest/reference/functions-internal#bdrdecode_message_payload", - "bdrdecode_message_response_payload": "/pgd/latest/reference/functions-internal#bdrdecode_message_response_payload", - "bdrdifference_fix_origin_create": "/pgd/latest/reference/functions-internal#bdrdifference_fix_origin_create", - "bdrdifference_fix_session_reset": "/pgd/latest/reference/functions-internal#bdrdifference_fix_session_reset", - "bdrdifference_fix_session_setup": "/pgd/latest/reference/functions-internal#bdrdifference_fix_session_setup", - "bdrdifference_fix_xact_set_avoid_conflict": "/pgd/latest/reference/functions-internal#bdrdifference_fix_xact_set_avoid_conflict", - "bdrdrop_node": "/pgd/latest/reference/functions-internal#bdrdrop_node", - "bdrget_global_locks": "/pgd/latest/reference/functions-internal#bdrget_global_locks", - "bdrget_node_conflict_resolvers": "/pgd/latest/reference/functions-internal#bdrget_node_conflict_resolvers", - "bdrget_slot_flush_timestamp": "/pgd/latest/reference/functions-internal#bdrget_slot_flush_timestamp", - "bdrinternal_alter_sequence_set_kind": "/pgd/latest/reference/functions-internal#bdrinternal_alter_sequence_set_kind", - "bdrinternal_replication_set_add_table": "/pgd/latest/reference/functions-internal#bdrinternal_replication_set_add_table", - "bdrinternal_replication_set_remove_table": "/pgd/latest/reference/functions-internal#bdrinternal_replication_set_remove_table", - "bdrinternal_submit_join_request": "/pgd/latest/reference/functions-internal#bdrinternal_submit_join_request", - "bdrisolation_test_session_is_blocked": "/pgd/latest/reference/functions-internal#bdrisolation_test_session_is_blocked", - "bdrlocal_node_info": "/pgd/latest/reference/functions-internal#bdrlocal_node_info", - "bdrmsgb_connect": "/pgd/latest/reference/functions-internal#bdrmsgb_connect", - "bdrmsgb_deliver_message": "/pgd/latest/reference/functions-internal#bdrmsgb_deliver_message", - "bdrnode_catchup_state_name": "/pgd/latest/reference/functions-internal#bdrnode_catchup_state_name", - "bdrnode_kind_name": "/pgd/latest/reference/functions-internal#bdrnode_kind_name", - "bdrpeer_state_name": "/pgd/latest/reference/functions-internal#bdrpeer_state_name", - "bdrpg_xact_origin": "/pgd/latest/reference/functions-internal#bdrpg_xact_origin", - "bdrrequest_replay_progress_update": "/pgd/latest/reference/functions-internal#bdrrequest_replay_progress_update", - "bdrreset_relation_stats": "/pgd/latest/reference/functions-internal#bdrreset_relation_stats", - "bdrreset_subscription_stats": "/pgd/latest/reference/functions-internal#bdrreset_subscription_stats", - "bdrresynchronize_table_from_node": "/pgd/latest/reference/functions-internal#bdrresynchronize_table_from_node", - "bdrseq_currval": "/pgd/latest/reference/functions-internal#bdrseq_currval", - "bdrseq_lastval": "/pgd/latest/reference/functions-internal#bdrseq_lastval", - "bdrseq_nextval": "/pgd/latest/reference/functions-internal#bdrseq_nextval", - "bdrshow_subscription_status": "/pgd/latest/reference/functions-internal#bdrshow_subscription_status", - "bdrshow_workers": "/pgd/latest/reference/functions-internal#bdrshow_workers", - "bdrshow_writers": "/pgd/latest/reference/functions-internal#bdrshow_writers", - "bdrtaskmgr_set_leader": "/pgd/latest/reference/functions-internal#bdrtaskmgr_set_leader", - "bdrtaskmgr_get_last_completed_workitem": "/pgd/latest/reference/functions-internal#bdrtaskmgr_get_last_completed_workitem", - "bdrtaskmgr_work_queue_check_status": "/pgd/latest/reference/functions-internal#bdrtaskmgr_work_queue_check_status", - "bdrpglogical_proto_version_ranges": "/pgd/latest/reference/functions-internal#bdrpglogical_proto_version_ranges", - "bdrget_min_required_replication_slots": "/pgd/latest/reference/functions-internal#bdrget_min_required_replication_slots", - "bdrget_min_required_worker_processes": "/pgd/latest/reference/functions-internal#bdrget_min_required_worker_processes", - "bdrstat_get_activity": "/pgd/latest/reference/functions-internal#bdrstat_get_activity", - "bdrworker_role_id_name": "/pgd/latest/reference/functions-internal#bdrworker_role_id_name", - "bdrlag_history": "/pgd/latest/reference/functions-internal#bdrlag_history", - "bdrget_raft_instance_by_nodegroup": "/pgd/latest/reference/functions-internal#bdrget_raft_instance_by_nodegroup", - "bdrmonitor_camo_on_all_nodes": "/pgd/latest/reference/functions-internal#bdrmonitor_camo_on_all_nodes", - "bdrmonitor_raft_details_on_all_nodes": "/pgd/latest/reference/functions-internal#bdrmonitor_raft_details_on_all_nodes", - "bdrmonitor_replslots_details_on_all_nodes": "/pgd/latest/reference/functions-internal#bdrmonitor_replslots_details_on_all_nodes", - "bdrmonitor_subscription_details_on_all_nodes": "/pgd/latest/reference/functions-internal#bdrmonitor_subscription_details_on_all_nodes", - "bdrmonitor_version_details_on_all_nodes": "/pgd/latest/reference/functions-internal#bdrmonitor_version_details_on_all_nodes", - "bdrnode_group_member_info": "/pgd/latest/reference/functions-internal#bdrnode_group_member_info", - "bdrcolumn_timestamps_create": "/pgd/latest/reference/clcd#bdrcolumn_timestamps_create" + "bdrcamo_decision_journal": "/pgd/5.6/reference/catalogs-visible#bdrcamo_decision_journal", + "bdrcommit_scopes": "/pgd/5.6/reference/catalogs-visible#bdrcommit_scopes", + "bdrconflict_history": "/pgd/5.6/reference/catalogs-visible#bdrconflict_history", + "bdrconflict_history_summary": "/pgd/5.6/reference/catalogs-visible#bdrconflict_history_summary", + "bdrconsensus_kv_data": "/pgd/5.6/reference/catalogs-visible#bdrconsensus_kv_data", + "bdrcrdt_handlers": "/pgd/5.6/reference/catalogs-visible#bdrcrdt_handlers", + "bdrddl_replication": "/pgd/5.6/reference/pgd-settings#bdrddl_replication", + "bdrdepend": "/pgd/5.6/reference/catalogs-visible#bdrdepend", + "bdrglobal_consensus_journal": "/pgd/5.6/reference/catalogs-visible#bdrglobal_consensus_journal", + "bdrglobal_consensus_journal_details": "/pgd/5.6/reference/catalogs-visible#bdrglobal_consensus_journal_details", + "bdrglobal_consensus_response_journal": "/pgd/5.6/reference/catalogs-visible#bdrglobal_consensus_response_journal", + "bdrglobal_lock": "/pgd/5.6/reference/catalogs-visible#bdrglobal_lock", + "bdrglobal_locks": "/pgd/5.6/reference/catalogs-visible#bdrglobal_locks", + "bdrgroup_camo_details": "/pgd/5.6/reference/catalogs-visible#bdrgroup_camo_details", + "bdrgroup_raft_details": "/pgd/5.6/reference/catalogs-visible#bdrgroup_raft_details", + "bdrgroup_replslots_details": "/pgd/5.6/reference/catalogs-visible#bdrgroup_replslots_details", + "bdrgroup_subscription_summary": "/pgd/5.6/reference/catalogs-visible#bdrgroup_subscription_summary", + "bdrgroup_versions_details": "/pgd/5.6/reference/catalogs-visible#bdrgroup_versions_details", + "bdrlocal_consensus_snapshot": "/pgd/5.6/reference/catalogs-visible#bdrlocal_consensus_snapshot", + "bdrlocal_consensus_state": "/pgd/5.6/reference/catalogs-visible#bdrlocal_consensus_state", + "bdrlocal_node": "/pgd/5.6/reference/catalogs-visible#bdrlocal_node", + "bdrlocal_node_summary": "/pgd/5.6/reference/catalogs-visible#bdrlocal_node_summary", + "bdrlocal_sync_status": "/pgd/5.6/reference/catalogs-visible#bdrlocal_sync_status", + "bdrnode": "/pgd/5.6/reference/catalogs-visible#bdrnode", + "bdrnode_catchup_info": "/pgd/5.6/reference/catalogs-visible#bdrnode_catchup_info", + "bdrnode_catchup_info_details": "/pgd/5.6/reference/catalogs-visible#bdrnode_catchup_info_details", + "bdrnode_conflict_resolvers": "/pgd/5.6/reference/catalogs-visible#bdrnode_conflict_resolvers", + "bdrnode_group": "/pgd/5.6/reference/catalogs-visible#bdrnode_group", + "bdrnode_group_replication_sets": "/pgd/5.6/reference/catalogs-visible#bdrnode_group_replication_sets", + "bdrnode_group_summary": "/pgd/5.6/reference/catalogs-visible#bdrnode_group_summary", + "bdrnode_local_info": "/pgd/5.6/reference/catalogs-visible#bdrnode_local_info", + "bdrnode_log_config": "/pgd/5.6/reference/catalogs-visible#bdrnode_log_config", + "bdrnode_peer_progress": "/pgd/5.6/reference/catalogs-visible#bdrnode_peer_progress", + "bdrnode_replication_rates": "/pgd/5.6/reference/catalogs-visible#bdrnode_replication_rates", + "bdrnode_slots": "/pgd/5.6/reference/catalogs-visible#bdrnode_slots", + "bdrnode_summary": "/pgd/5.6/reference/catalogs-visible#bdrnode_summary", + "bdrqueue": "/pgd/5.6/reference/catalogs-visible#bdrqueue", + "bdrreplication_set": "/pgd/5.6/reference/catalogs-visible#bdrreplication_set", + "bdrreplication_set_table": "/pgd/5.6/reference/catalogs-visible#bdrreplication_set_table", + "bdrreplication_set_ddl": "/pgd/5.6/reference/catalogs-visible#bdrreplication_set_ddl", + "bdrreplication_sets": "/pgd/5.6/reference/catalogs-visible#bdrreplication_sets", + "bdrschema_changes": "/pgd/5.6/reference/catalogs-visible#bdrschema_changes", + "bdrsequence_alloc": "/pgd/5.6/reference/catalogs-visible#bdrsequence_alloc", + "bdrsequences": "/pgd/5.6/reference/catalogs-visible#bdrsequences", + "bdrstat_activity": "/pgd/5.6/reference/catalogs-visible#bdrstat_activity", + "bdrstat_commit_scope": "/pgd/5.6/reference/catalogs-visible#bdrstat_commit_scope", + "bdrstat_commit_scope_state": "/pgd/5.6/reference/catalogs-visible#bdrstat_commit_scope_state", + "bdrstat_raft_followers_state": "/pgd/5.6/reference/catalogs-visible#bdrstat_raft_followers_state", + "bdrstat_raft_state": "/pgd/5.6/reference/catalogs-visible#bdrstat_raft_state", + "bdrstat_receiver": "/pgd/5.6/reference/catalogs-visible#bdrstat_receiver", + "bdrstat_relation": "/pgd/5.6/reference/catalogs-visible#bdrstat_relation", + "bdrstat_routing_candidate_state": "/pgd/5.6/reference/catalogs-visible#bdrstat_routing_candidate_state", + "bdrstat_routing_state": "/pgd/5.6/reference/catalogs-visible#bdrstat_routing_state", + "bdrstat_subscription": "/pgd/5.6/reference/catalogs-visible#bdrstat_subscription", + "bdrstat_worker": "/pgd/5.6/reference/catalogs-visible#bdrstat_worker", + "bdrstat_writer": "/pgd/5.6/reference/catalogs-visible#bdrstat_writer", + "bdrsubscription": "/pgd/5.6/reference/catalogs-visible#bdrsubscription", + "bdrsubscription_summary": "/pgd/5.6/reference/catalogs-visible#bdrsubscription_summary", + "bdrtables": "/pgd/5.6/reference/catalogs-visible#bdrtables", + "bdrtaskmgr_work_queue": "/pgd/5.6/reference/catalogs-visible#bdrtaskmgr_work_queue", + "bdrtaskmgr_workitem_status": "/pgd/5.6/reference/catalogs-visible#bdrtaskmgr_workitem_status", + "bdrtaskmgr_local_work_queue": "/pgd/5.6/reference/catalogs-visible#bdrtaskmgr_local_work_queue", + "bdrtaskmgr_local_workitem_status": "/pgd/5.6/reference/catalogs-visible#bdrtaskmgr_local_workitem_status", + "bdrtrigger": "/pgd/5.6/reference/catalogs-visible#bdrtrigger", + "bdrtriggers": "/pgd/5.6/reference/catalogs-visible#bdrtriggers", + "bdrworkers": "/pgd/5.6/reference/catalogs-visible#bdrworkers", + "bdrwriters": "/pgd/5.6/reference/catalogs-visible#bdrwriters", + "bdrworker_tasks": "/pgd/5.6/reference/catalogs-visible#bdrworker_tasks", + "bdrbdr_version": "/pgd/5.6/reference/functions#bdrbdr_version", + "bdrbdr_version_num": "/pgd/5.6/reference/functions#bdrbdr_version_num", + "bdrget_relation_stats": "/pgd/5.6/reference/functions#bdrget_relation_stats", + "bdrget_subscription_stats": "/pgd/5.6/reference/functions#bdrget_subscription_stats", + "bdrlocal_node_id": "/pgd/5.6/reference/functions#bdrlocal_node_id", + "bdrlast_committed_lsn": "/pgd/5.6/reference/functions#bdrlast_committed_lsn", + "transaction_id": "/pgd/5.6/reference/functions#transaction_id", + "bdris_node_connected": "/pgd/5.6/reference/functions#bdris_node_connected", + "bdris_node_ready": "/pgd/5.6/reference/functions#bdris_node_ready", + "bdrconsensus_disable": "/pgd/5.6/reference/functions#bdrconsensus_disable", + "bdrconsensus_enable": "/pgd/5.6/reference/functions#bdrconsensus_enable", + "bdrconsensus_proto_version": "/pgd/5.6/reference/functions#bdrconsensus_proto_version", + "bdrconsensus_snapshot_export": "/pgd/5.6/reference/functions#bdrconsensus_snapshot_export", + "bdrconsensus_snapshot_import": "/pgd/5.6/reference/functions#bdrconsensus_snapshot_import", + "bdrconsensus_snapshot_verify": "/pgd/5.6/reference/functions#bdrconsensus_snapshot_verify", + "bdrget_consensus_status": "/pgd/5.6/reference/functions#bdrget_consensus_status", + "bdrget_raft_status": "/pgd/5.6/reference/functions#bdrget_raft_status", + "bdrraft_leadership_transfer": "/pgd/5.6/reference/functions#bdrraft_leadership_transfer", + "bdrwait_slot_confirm_lsn": "/pgd/5.6/reference/functions#bdrwait_slot_confirm_lsn", + "bdrwait_for_apply_queue": "/pgd/5.6/reference/functions#bdrwait_for_apply_queue", + "bdrget_node_sub_receive_lsn": "/pgd/5.6/reference/functions#bdrget_node_sub_receive_lsn", + "bdrget_node_sub_apply_lsn": "/pgd/5.6/reference/functions#bdrget_node_sub_apply_lsn", + "bdrreplicate_ddl_command": "/pgd/5.6/reference/functions#bdrreplicate_ddl_command", + "bdrrun_on_all_nodes": "/pgd/5.6/reference/functions#bdrrun_on_all_nodes", + "bdrrun_on_nodes": "/pgd/5.6/reference/functions#bdrrun_on_nodes", + "bdrrun_on_group": "/pgd/5.6/reference/functions#bdrrun_on_group", + "bdrglobal_lock_table": "/pgd/5.6/reference/functions#bdrglobal_lock_table", + "bdrwait_for_xid_progress": "/pgd/5.6/reference/functions#bdrwait_for_xid_progress", + "bdrlocal_group_slot_name": "/pgd/5.6/reference/functions#bdrlocal_group_slot_name", + "bdrnode_group_type": "/pgd/5.6/reference/functions#bdrnode_group_type", + "bdralter_node_kind": "/pgd/5.6/reference/functions#bdralter_node_kind", + "bdralter_subscription_skip_changes_upto": "/pgd/5.6/reference/functions#bdralter_subscription_skip_changes_upto", + "bdrglobal_advisory_lock": "/pgd/5.6/reference/functions#bdrglobal_advisory_lock", + "bdrglobal_advisory_unlock": "/pgd/5.6/reference/functions#bdrglobal_advisory_unlock", + "bdrmonitor_group_versions": "/pgd/5.6/reference/functions#bdrmonitor_group_versions", + "bdrmonitor_group_raft": "/pgd/5.6/reference/functions#bdrmonitor_group_raft", + "bdrmonitor_local_replslots": "/pgd/5.6/reference/functions#bdrmonitor_local_replslots", + "bdrwal_sender_stats": "/pgd/5.6/reference/functions#bdrwal_sender_stats", + "bdrget_decoding_worker_stat": "/pgd/5.6/reference/functions#bdrget_decoding_worker_stat", + "bdrlag_control": "/pgd/5.6/reference/functions#bdrlag_control", + "bdris_camo_partner_connected": "/pgd/5.6/reference/functions#bdris_camo_partner_connected", + "bdris_camo_partner_ready": "/pgd/5.6/reference/functions#bdris_camo_partner_ready", + "bdrget_configured_camo_partner": "/pgd/5.6/reference/functions#bdrget_configured_camo_partner", + "bdrwait_for_camo_partner_queue": "/pgd/5.6/reference/functions#bdrwait_for_camo_partner_queue", + "bdrcamo_transactions_resolved": "/pgd/5.6/reference/functions#bdrcamo_transactions_resolved", + "bdrlogical_transaction_status": "/pgd/5.6/reference/functions#bdrlogical_transaction_status", + "bdradd_commit_scope": "/pgd/5.6/reference/functions#bdradd_commit_scope", + "bdralter_commit_scope": "/pgd/5.6/reference/functions#bdralter_commit_scope", + "bdrremove_commit_scope": "/pgd/5.6/reference/functions#bdrremove_commit_scope", + "bdrdefault_conflict_detection": "/pgd/5.6/reference/pgd-settings#bdrdefault_conflict_detection", + "bdrdefault_sequence_kind": "/pgd/5.6/reference/pgd-settings#bdrdefault_sequence_kind", + "bdrdefault_replica_identity": "/pgd/5.6/reference/pgd-settings#bdrdefault_replica_identity", + "bdrrole_replication": "/pgd/5.6/reference/pgd-settings#bdrrole_replication", + "bdrddl_locking": "/pgd/5.6/reference/pgd-settings#bdrddl_locking", + "bdrtruncate_locking": "/pgd/5.6/reference/pgd-settings#bdrtruncate_locking", + "bdrglobal_lock_max_locks": "/pgd/5.6/reference/pgd-settings#bdrglobal_lock_max_locks", + "bdrglobal_lock_timeout": "/pgd/5.6/reference/pgd-settings#bdrglobal_lock_timeout", + "bdrglobal_lock_statement_timeout": "/pgd/5.6/reference/pgd-settings#bdrglobal_lock_statement_timeout", + "bdrglobal_lock_idle_timeout": "/pgd/5.6/reference/pgd-settings#bdrglobal_lock_idle_timeout", + "bdrpredictive_checks": "/pgd/5.6/reference/pgd-settings#bdrpredictive_checks", + "bdrreplay_progress_frequency": "/pgd/5.6/reference/pgd-settings#bdrreplay_progress_frequency", + "bdrstandby_slot_names": "/pgd/5.6/reference/pgd-settings#bdrstandby_slot_names", + "bdrwriters_per_subscription": "/pgd/5.6/reference/pgd-settings#bdrwriters_per_subscription", + "bdrmax_writers_per_subscription": "/pgd/5.6/reference/pgd-settings#bdrmax_writers_per_subscription", + "bdrxact_replication": "/pgd/5.6/reference/pgd-settings#bdrxact_replication", + "bdrpermit_unsafe_commands": "/pgd/5.6/reference/pgd-settings#bdrpermit_unsafe_commands", + "bdrbatch_inserts": "/pgd/5.6/reference/pgd-settings#bdrbatch_inserts", + "bdrmaximum_clock_skew": "/pgd/5.6/reference/pgd-settings#bdrmaximum_clock_skew", + "bdrmaximum_clock_skew_action": "/pgd/5.6/reference/pgd-settings#bdrmaximum_clock_skew_action", + "bdraccept_connections": "/pgd/5.6/reference/pgd-settings#bdraccept_connections", + "bdrstandby_slots_min_confirmed": "/pgd/5.6/reference/pgd-settings#bdrstandby_slots_min_confirmed", + "bdrwriter_input_queue_size": "/pgd/5.6/reference/pgd-settings#bdrwriter_input_queue_size", + "bdrwriter_output_queue_size": "/pgd/5.6/reference/pgd-settings#bdrwriter_output_queue_size", + "bdrmin_worker_backoff_delay": "/pgd/5.6/reference/pgd-settings#bdrmin_worker_backoff_delay", + "bdrcrdt_raw_value": "/pgd/5.6/reference/pgd-settings#bdrcrdt_raw_value", + "bdrcommit_scope": "/pgd/5.6/reference/pgd-settings#bdrcommit_scope", + "bdrcamo_local_mode_delay": "/pgd/5.6/reference/pgd-settings#bdrcamo_local_mode_delay", + "bdrcamo_enable_client_warnings": "/pgd/5.6/reference/pgd-settings#bdrcamo_enable_client_warnings", + "bdrdefault_streaming_mode": "/pgd/5.6/reference/pgd-settings#bdrdefault_streaming_mode", + "bdrlag_control_max_commit_delay": "/pgd/5.6/reference/pgd-settings#bdrlag_control_max_commit_delay", + "bdrlag_control_max_lag_size": "/pgd/5.6/reference/pgd-settings#bdrlag_control_max_lag_size", + "bdrlag_control_max_lag_time": "/pgd/5.6/reference/pgd-settings#bdrlag_control_max_lag_time", + "bdrlag_control_min_conforming_nodes": "/pgd/5.6/reference/pgd-settings#bdrlag_control_min_conforming_nodes", + "bdrlag_control_commit_delay_adjust": "/pgd/5.6/reference/pgd-settings#bdrlag_control_commit_delay_adjust", + "bdrlag_control_sample_interval": "/pgd/5.6/reference/pgd-settings#bdrlag_control_sample_interval", + "bdrlag_control_commit_delay_start": "/pgd/5.6/reference/pgd-settings#bdrlag_control_commit_delay_start", + "bdrtimestamp_snapshot_keep": "/pgd/5.6/reference/pgd-settings#bdrtimestamp_snapshot_keep", + "bdrdebug_level": "/pgd/5.6/reference/pgd-settings#bdrdebug_level", + "bdrtrace_level": "/pgd/5.6/reference/pgd-settings#bdrtrace_level", + "bdrtrack_subscription_apply": "/pgd/5.6/reference/pgd-settings#bdrtrack_subscription_apply", + "bdrtrack_relation_apply": "/pgd/5.6/reference/pgd-settings#bdrtrack_relation_apply", + "bdrtrack_apply_lock_timing": "/pgd/5.6/reference/pgd-settings#bdrtrack_apply_lock_timing", + "bdrenable_wal_decoder": "/pgd/5.6/reference/pgd-settings#bdrenable_wal_decoder", + "bdrreceive_lcr": "/pgd/5.6/reference/pgd-settings#bdrreceive_lcr", + "bdrlcr_cleanup_interval": "/pgd/5.6/reference/pgd-settings#bdrlcr_cleanup_interval", + "bdrglobal_connection_timeout": "/pgd/5.6/reference/pgd-settings#bdrglobal_connection_timeout", + "bdrglobal_keepalives": "/pgd/5.6/reference/pgd-settings#bdrglobal_keepalives", + "bdrglobal_keepalives_idle": "/pgd/5.6/reference/pgd-settings#bdrglobal_keepalives_idle", + "bdrglobal_keepalives_interval": "/pgd/5.6/reference/pgd-settings#bdrglobal_keepalives_interval", + "bdrglobal_keepalives_count": "/pgd/5.6/reference/pgd-settings#bdrglobal_keepalives_count", + "bdrglobal_tcp_user_timeout": "/pgd/5.6/reference/pgd-settings#bdrglobal_tcp_user_timeout", + "bdrraft_global_election_timeout": "/pgd/5.6/reference/pgd-settings#bdrraft_global_election_timeout", + "bdrraft_local_election_timeout": "/pgd/5.6/reference/pgd-settings#bdrraft_local_election_timeout", + "bdrraft_response_timeout": "/pgd/5.6/reference/pgd-settings#bdrraft_response_timeout", + "bdrraft_keep_min_entries": "/pgd/5.6/reference/pgd-settings#bdrraft_keep_min_entries", + "bdrraft_log_min_apply_duration": "/pgd/5.6/reference/pgd-settings#bdrraft_log_min_apply_duration", + "bdrraft_log_min_message_duration": "/pgd/5.6/reference/pgd-settings#bdrraft_log_min_message_duration", + "bdrraft_group_max_connections": "/pgd/5.6/reference/pgd-settings#bdrraft_group_max_connections", + "bdrbackwards_compatibility": "/pgd/5.6/reference/pgd-settings#bdrbackwards_compatibility", + "bdrtrack_replication_estimates": "/pgd/5.6/reference/pgd-settings#bdrtrack_replication_estimates", + "bdrlag_tracker_apply_rate_weight": "/pgd/5.6/reference/pgd-settings#bdrlag_tracker_apply_rate_weight", + "bdrenable_auto_sync_reconcile": "/pgd/5.6/reference/pgd-settings#bdrenable_auto_sync_reconcile", + "list-of-node-states": "/pgd/5.6/reference/nodes#list-of-node-states", + "node-management-commands": "/pgd/5.6/reference/nodes#node-management-commands", + "bdr_init_physical": "/pgd/5.6/reference/nodes#bdr_init_physical", + "bdralter_node_group_option": "/pgd/5.6/reference/nodes-management-interfaces#bdralter_node_group_option", + "bdralter_node_interface": "/pgd/5.6/reference/nodes-management-interfaces#bdralter_node_interface", + "bdralter_node_option": "/pgd/5.6/reference/nodes-management-interfaces#bdralter_node_option", + "bdralter_subscription_enable": "/pgd/5.6/reference/nodes-management-interfaces#bdralter_subscription_enable", + "bdralter_subscription_disable": "/pgd/5.6/reference/nodes-management-interfaces#bdralter_subscription_disable", + "bdrcreate_node": "/pgd/5.6/reference/nodes-management-interfaces#bdrcreate_node", + "bdrcreate_node_group": "/pgd/5.6/reference/nodes-management-interfaces#bdrcreate_node_group", + "bdrjoin_node_group": "/pgd/5.6/reference/nodes-management-interfaces#bdrjoin_node_group", + "bdrpart_node": "/pgd/5.6/reference/nodes-management-interfaces#bdrpart_node", + "bdrpromote_node": "/pgd/5.6/reference/nodes-management-interfaces#bdrpromote_node", + "bdrswitch_node_group": "/pgd/5.6/reference/nodes-management-interfaces#bdrswitch_node_group", + "bdrwait_for_join_completion": "/pgd/5.6/reference/nodes-management-interfaces#bdrwait_for_join_completion", + "bdralter_node_group_config": "/pgd/5.6/reference/nodes-management-interfaces#bdralter_node_group_config", + "bdrcreate_proxy": "/pgd/5.6/reference/routing#bdrcreate_proxy", + "bdralter_proxy_option": "/pgd/5.6/reference/routing#bdralter_proxy_option", + "bdrdrop_proxy": "/pgd/5.6/reference/routing#bdrdrop_proxy", + "bdrrouting_leadership_transfer": "/pgd/5.6/reference/routing#bdrrouting_leadership_transfer", + "cs.commit-scope-syntax": "/pgd/5.6/reference/commit-scopes#commit-scope-syntax", + "cs.commit-scope-groups": "/pgd/5.6/reference/commit-scopes#commit-scope-groups", + "cs.any": "/pgd/5.6/reference/commit-scopes#any", + "cs.any-not": "/pgd/5.6/reference/commit-scopes#any-not", + "cs.majority": "/pgd/5.6/reference/commit-scopes#majority", + "cs.majority-not": "/pgd/5.6/reference/commit-scopes#majority-not", + "cs.all": "/pgd/5.6/reference/commit-scopes#all", + "cs.all-not": "/pgd/5.6/reference/commit-scopes#all-not", + "cs.confirmation-level": "/pgd/5.6/reference/commit-scopes#confirmation-level", + "cs.on-received": "/pgd/5.6/reference/commit-scopes#on-received", + "cs.on-replicated": "/pgd/5.6/reference/commit-scopes#on-replicated", + "cs.on-durable": "/pgd/5.6/reference/commit-scopes#on-durable", + "cs.on-visible": "/pgd/5.6/reference/commit-scopes#on-visible", + "cs.commit-scope-kinds": "/pgd/5.6/reference/commit-scopes#commit-scope-kinds", + "cs.group-commit": "/pgd/5.6/reference/commit-scopes#group-commit", + "cs.group-commit-parameters": "/pgd/5.6/reference/commit-scopes#group-commit-parameters", + "cs.abort-on-parameters": "/pgd/5.6/reference/commit-scopes#abort-on-parameters", + "cs.transaction_tracking-settings": "/pgd/5.6/reference/commit-scopes#transaction_tracking-settings", + "cs.conflict_resolution-settings": "/pgd/5.6/reference/commit-scopes#conflict_resolution-settings", + "cs.commit_decision-settings": "/pgd/5.6/reference/commit-scopes#commit_decision-settings", + "cs.camo": "/pgd/5.6/reference/commit-scopes#camo", + "cs.degrade-on-parameters": "/pgd/5.6/reference/commit-scopes#degrade-on-parameters", + "cs.lag-control": "/pgd/5.6/reference/commit-scopes#lag-control", + "cs.lag-control-parameters": "/pgd/5.6/reference/commit-scopes#lag-control-parameters", + "cs.synchronous_commit": "/pgd/5.6/reference/commit-scopes#synchronous_commit", + "conflict-detection": "/pgd/5.6/reference/conflicts#conflict-detection", + "list-of-conflict-types": "/pgd/5.6/reference/conflicts#list-of-conflict-types", + "conflict-resolution": "/pgd/5.6/reference/conflicts#conflict-resolution", + "list-of-conflict-resolvers": "/pgd/5.6/reference/conflicts#list-of-conflict-resolvers", + "default-conflict-resolvers": "/pgd/5.6/reference/conflicts#default-conflict-resolvers", + "list-of-conflict-resolutions": "/pgd/5.6/reference/conflicts#list-of-conflict-resolutions", + "conflict-logging": "/pgd/5.6/reference/conflicts#conflict-logging", + "bdralter_table_conflict_detection": "/pgd/5.6/reference/conflict_functions#bdralter_table_conflict_detection", + "bdralter_node_set_conflict_resolver": "/pgd/5.6/reference/conflict_functions#bdralter_node_set_conflict_resolver", + "bdralter_node_set_log_config": "/pgd/5.6/reference/conflict_functions#bdralter_node_set_log_config", + "bdrcreate_replication_set": "/pgd/5.6/reference/repsets-management#bdrcreate_replication_set", + "bdralter_replication_set": "/pgd/5.6/reference/repsets-management#bdralter_replication_set", + "bdrdrop_replication_set": "/pgd/5.6/reference/repsets-management#bdrdrop_replication_set", + "bdralter_node_replication_sets": "/pgd/5.6/reference/repsets-management#bdralter_node_replication_sets", + "bdrreplication_set_add_table": "/pgd/5.6/reference/repsets-membership#bdrreplication_set_add_table", + "bdrreplication_set_remove_table": "/pgd/5.6/reference/repsets-membership#bdrreplication_set_remove_table", + "bdrreplication_set_add_ddl_filter": "/pgd/5.6/reference/repsets-ddl-filtering#bdrreplication_set_add_ddl_filter", + "bdrreplication_set_remove_ddl_filter": "/pgd/5.6/reference/repsets-ddl-filtering#bdrreplication_set_remove_ddl_filter", + "pgd_bench": "/pgd/5.6/reference/testingandtuning#pgd_bench", + "bdralter_sequence_set_kind": "/pgd/5.6/reference/sequences#bdralter_sequence_set_kind", + "bdrextract_timestamp_from_snowflakeid": "/pgd/5.6/reference/sequences#bdrextract_timestamp_from_snowflakeid", + "bdrextract_nodeid_from_snowflakeid": "/pgd/5.6/reference/sequences#bdrextract_nodeid_from_snowflakeid", + "bdrextract_localseqid_from_snowflakeid": "/pgd/5.6/reference/sequences#bdrextract_localseqid_from_snowflakeid", + "bdrtimestamp_to_snowflakeid": "/pgd/5.6/reference/sequences#bdrtimestamp_to_snowflakeid", + "bdrextract_timestamp_from_timeshard": "/pgd/5.6/reference/sequences#bdrextract_timestamp_from_timeshard", + "bdrextract_nodeid_from_timeshard": "/pgd/5.6/reference/sequences#bdrextract_nodeid_from_timeshard", + "bdrextract_localseqid_from_timeshard": "/pgd/5.6/reference/sequences#bdrextract_localseqid_from_timeshard", + "bdrtimestamp_to_timeshard": "/pgd/5.6/reference/sequences#bdrtimestamp_to_timeshard", + "bdrgen_ksuuid_v2": "/pgd/5.6/reference/sequences#bdrgen_ksuuid_v2", + "bdrksuuid_v2_cmp": "/pgd/5.6/reference/sequences#bdrksuuid_v2_cmp", + "bdrextract_timestamp_from_ksuuid_v2": "/pgd/5.6/reference/sequences#bdrextract_timestamp_from_ksuuid_v2", + "bdrgen_ksuuid": "/pgd/5.6/reference/sequences#bdrgen_ksuuid", + "bdruuid_v1_cmp": "/pgd/5.6/reference/sequences#bdruuid_v1_cmp", + "bdrextract_timestamp_from_ksuuid": "/pgd/5.6/reference/sequences#bdrextract_timestamp_from_ksuuid", + "bdrautopartition": "/pgd/5.6/reference/autopartition#bdrautopartition", + "bdrdrop_autopartition": "/pgd/5.6/reference/autopartition#bdrdrop_autopartition", + "bdrautopartition_wait_for_partitions": "/pgd/5.6/reference/autopartition#bdrautopartition_wait_for_partitions", + "bdrautopartition_wait_for_partitions_on_all_nodes": "/pgd/5.6/reference/autopartition#bdrautopartition_wait_for_partitions_on_all_nodes", + "bdrautopartition_find_partition": "/pgd/5.6/reference/autopartition#bdrautopartition_find_partition", + "bdrautopartition_enable": "/pgd/5.6/reference/autopartition#bdrautopartition_enable", + "bdrautopartition_disable": "/pgd/5.6/reference/autopartition#bdrautopartition_disable", + "internal-functions": "/pgd/5.6/reference/autopartition#internal-functions", + "bdrautopartition_create_partition": "/pgd/5.6/reference/autopartition#bdrautopartition_create_partition", + "bdrautopartition_drop_partition": "/pgd/5.6/reference/autopartition#bdrautopartition_drop_partition", + "bdrcreate_conflict_trigger": "/pgd/5.6/reference/streamtriggers/interfaces#bdrcreate_conflict_trigger", + "bdrcreate_transform_trigger": "/pgd/5.6/reference/streamtriggers/interfaces#bdrcreate_transform_trigger", + "bdrdrop_trigger": "/pgd/5.6/reference/streamtriggers/interfaces#bdrdrop_trigger", + "bdrtrigger_get_row": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrtrigger_get_row", + "bdrtrigger_get_committs": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrtrigger_get_committs", + "bdrtrigger_get_xid": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrtrigger_get_xid", + "bdrtrigger_get_type": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrtrigger_get_type", + "bdrtrigger_get_conflict_type": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrtrigger_get_conflict_type", + "bdrtrigger_get_origin_node_id": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrtrigger_get_origin_node_id", + "bdrri_fkey_on_del_trigger": "/pgd/5.6/reference/streamtriggers/rowfunctions#bdrri_fkey_on_del_trigger", + "tg_name": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_name", + "tg_when": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_when", + "tg_level": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_level", + "tg_op": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_op", + "tg_relid": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_relid", + "tg_table_name": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_table_name", + "tg_table_schema": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_table_schema", + "tg_nargs": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_nargs", + "tg_argv": "/pgd/5.6/reference/streamtriggers/rowvariables#tg_argv", + "bdrddl_epoch": "/pgd/5.6/reference/catalogs-internal#bdrddl_epoch", + "bdrevent_history": "/pgd/5.6/reference/catalogs-internal#bdrevent_history", + "bdrevent_summary": "/pgd/5.6/reference/catalogs-internal#bdrevent_summary", + "bdrnode_config": "/pgd/5.6/reference/catalogs-internal#bdrnode_config", + "bdrnode_group_config": "/pgd/5.6/reference/catalogs-internal#bdrnode_group_config", + "bdrnode_group_routing_config_summary": "/pgd/5.6/reference/catalogs-internal#bdrnode_group_routing_config_summary", + "bdrnode_group_routing_info": "/pgd/5.6/reference/catalogs-internal#bdrnode_group_routing_info", + "bdrnode_group_routing_summary": "/pgd/5.6/reference/catalogs-internal#bdrnode_group_routing_summary", + "bdrnode_routing_config_summary": "/pgd/5.6/reference/catalogs-internal#bdrnode_routing_config_summary", + "bdrproxy_config": "/pgd/5.6/reference/catalogs-internal#bdrproxy_config", + "bdrproxy_config_summary": "/pgd/5.6/reference/catalogs-internal#bdrproxy_config_summary", + "bdrsequence_kind": "/pgd/5.6/reference/catalogs-internal#bdrsequence_kind", + "bdrbdr_get_commit_decisions": "/pgd/5.6/reference/functions-internal#bdrbdr_get_commit_decisions", + "bdrbdr_track_commit_decision": "/pgd/5.6/reference/functions-internal#bdrbdr_track_commit_decision", + "bdrconsensus_kv_fetch": "/pgd/5.6/reference/functions-internal#bdrconsensus_kv_fetch", + "bdrconsensus_kv_store": "/pgd/5.6/reference/functions-internal#bdrconsensus_kv_store", + "bdrdecode_message_payload": "/pgd/5.6/reference/functions-internal#bdrdecode_message_payload", + "bdrdecode_message_response_payload": "/pgd/5.6/reference/functions-internal#bdrdecode_message_response_payload", + "bdrdifference_fix_origin_create": "/pgd/5.6/reference/functions-internal#bdrdifference_fix_origin_create", + "bdrdifference_fix_session_reset": "/pgd/5.6/reference/functions-internal#bdrdifference_fix_session_reset", + "bdrdifference_fix_session_setup": "/pgd/5.6/reference/functions-internal#bdrdifference_fix_session_setup", + "bdrdifference_fix_xact_set_avoid_conflict": "/pgd/5.6/reference/functions-internal#bdrdifference_fix_xact_set_avoid_conflict", + "bdrdrop_node": "/pgd/5.6/reference/functions-internal#bdrdrop_node", + "bdrget_global_locks": "/pgd/5.6/reference/functions-internal#bdrget_global_locks", + "bdrget_node_conflict_resolvers": "/pgd/5.6/reference/functions-internal#bdrget_node_conflict_resolvers", + "bdrget_slot_flush_timestamp": "/pgd/5.6/reference/functions-internal#bdrget_slot_flush_timestamp", + "bdrinternal_alter_sequence_set_kind": "/pgd/5.6/reference/functions-internal#bdrinternal_alter_sequence_set_kind", + "bdrinternal_replication_set_add_table": "/pgd/5.6/reference/functions-internal#bdrinternal_replication_set_add_table", + "bdrinternal_replication_set_remove_table": "/pgd/5.6/reference/functions-internal#bdrinternal_replication_set_remove_table", + "bdrinternal_submit_join_request": "/pgd/5.6/reference/functions-internal#bdrinternal_submit_join_request", + "bdrisolation_test_session_is_blocked": "/pgd/5.6/reference/functions-internal#bdrisolation_test_session_is_blocked", + "bdrlocal_node_info": "/pgd/5.6/reference/functions-internal#bdrlocal_node_info", + "bdrmsgb_connect": "/pgd/5.6/reference/functions-internal#bdrmsgb_connect", + "bdrmsgb_deliver_message": "/pgd/5.6/reference/functions-internal#bdrmsgb_deliver_message", + "bdrnode_catchup_state_name": "/pgd/5.6/reference/functions-internal#bdrnode_catchup_state_name", + "bdrnode_kind_name": "/pgd/5.6/reference/functions-internal#bdrnode_kind_name", + "bdrpeer_state_name": "/pgd/5.6/reference/functions-internal#bdrpeer_state_name", + "bdrpg_xact_origin": "/pgd/5.6/reference/functions-internal#bdrpg_xact_origin", + "bdrrequest_replay_progress_update": "/pgd/5.6/reference/functions-internal#bdrrequest_replay_progress_update", + "bdrreset_relation_stats": "/pgd/5.6/reference/functions-internal#bdrreset_relation_stats", + "bdrreset_subscription_stats": "/pgd/5.6/reference/functions-internal#bdrreset_subscription_stats", + "bdrresynchronize_table_from_node": "/pgd/5.6/reference/functions-internal#bdrresynchronize_table_from_node", + "bdrseq_currval": "/pgd/5.6/reference/functions-internal#bdrseq_currval", + "bdrseq_lastval": "/pgd/5.6/reference/functions-internal#bdrseq_lastval", + "bdrseq_nextval": "/pgd/5.6/reference/functions-internal#bdrseq_nextval", + "bdrshow_subscription_status": "/pgd/5.6/reference/functions-internal#bdrshow_subscription_status", + "bdrshow_workers": "/pgd/5.6/reference/functions-internal#bdrshow_workers", + "bdrshow_writers": "/pgd/5.6/reference/functions-internal#bdrshow_writers", + "bdrtaskmgr_set_leader": "/pgd/5.6/reference/functions-internal#bdrtaskmgr_set_leader", + "bdrtaskmgr_get_last_completed_workitem": "/pgd/5.6/reference/functions-internal#bdrtaskmgr_get_last_completed_workitem", + "bdrtaskmgr_work_queue_check_status": "/pgd/5.6/reference/functions-internal#bdrtaskmgr_work_queue_check_status", + "bdrcolumn_timestamps_create": "/pgd/5.6/reference/clcd#bdrcolumn_timestamps_create" } \ No newline at end of file diff --git a/product_docs/docs/pgd/5.6/reference/index.mdx b/product_docs/docs/pgd/5.6/reference/index.mdx index fd07ee180ce..408e8db8d6b 100644 --- a/product_docs/docs/pgd/5.6/reference/index.mdx +++ b/product_docs/docs/pgd/5.6/reference/index.mdx @@ -79,8 +79,17 @@ The reference section is a definitive listing of all functions, views, and comma * [`bdr.sequence_alloc`](catalogs-visible#bdrsequence_alloc) * [`bdr.sequences`](catalogs-visible#bdrsequences) * [`bdr.stat_activity`](catalogs-visible#bdrstat_activity) + * [`bdr.stat_commit_scope`](catalogs-visible#bdrstat_commit_scope) + * [`bdr.stat_commit_scope_state`](catalogs-visible#bdrstat_commit_scope_state) + * [`bdr.stat_raft_followers_state`](catalogs-visible#bdrstat_raft_followers_state) + * [`bdr.stat_raft_state`](catalogs-visible#bdrstat_raft_state) + * [`bdr.stat_receiver`](catalogs-visible#bdrstat_receiver) * [`bdr.stat_relation`](catalogs-visible#bdrstat_relation) + * [`bdr.stat_routing_candidate_state`](catalogs-visible#bdrstat_routing_candidate_state) + * [`bdr.stat_routing_state`](catalogs-visible#bdrstat_routing_state) * [`bdr.stat_subscription`](catalogs-visible#bdrstat_subscription) + * [`bdr.stat_worker`](catalogs-visible#bdrstat_worker) + * [`bdr.stat_writer`](catalogs-visible#bdrstat_writer) * [`bdr.subscription`](catalogs-visible#bdrsubscription) * [`bdr.subscription_summary`](catalogs-visible#bdrsubscription_summary) * [`bdr.tables`](catalogs-visible#bdrtables)