Struct mz_sql::session::vars::SystemVars
source · pub struct SystemVars {
allow_unsafe: bool,
vars: BTreeMap<&'static UncasedStr, SystemVar>,
active_connection_count: Arc<Mutex<ConnectionCounter>>,
dyncfgs: ConfigSet,
}
Expand description
On disk variables.
See the crate::session::vars
module documentation for more details on the
Materialize configuration model.
Fields§
§allow_unsafe: bool
Allows “unsafe” parameters to be set.
vars: BTreeMap<&'static UncasedStr, SystemVar>
Set of all SystemVar
s.
active_connection_count: Arc<Mutex<ConnectionCounter>>
§dyncfgs: ConfigSet
NB: This is intentionally disconnected from the one that is plumbed around to persist and the controllers. This is so we can explicitly control and reason about when changes to config values are propagated to the rest of the system.
Implementations§
source§impl SystemVars
impl SystemVars
pub fn enable_all_feature_flags_by_default(&mut self)
pub fn enable_for_item_parsing(&mut self)
pub fn allow_real_time_recency(&self) -> bool
pub fn enable_binary_date_bin(&self) -> bool
pub fn enable_create_sink_denylist_with_options(&self) -> bool
pub fn enable_create_source_denylist_with_options(&self) -> bool
pub fn enable_date_bin_hopping(&self) -> bool
pub fn enable_envelope_debezium_in_subscribe(&self) -> bool
pub fn enable_envelope_materialize(&self) -> bool
pub fn enable_explain_pushdown(&self) -> bool
pub fn enable_index_options(&self) -> bool
pub fn enable_list_length_max(&self) -> bool
pub fn enable_list_n_layers(&self) -> bool
pub fn enable_list_remove(&self) -> bool
pub fn enable_logical_compaction_window(&self) -> bool
pub fn enable_primary_key_not_enforced(&self) -> bool
pub fn enable_collection_partition_by(&self) -> bool
pub fn enable_multi_worker_storage_persist_sink(&self) -> bool
pub fn enable_persist_streaming_snapshot_and_fetch(&self) -> bool
pub fn enable_persist_streaming_compaction(&self) -> bool
pub fn enable_raise_statement(&self) -> bool
pub fn enable_repeat_row(&self) -> bool
pub fn enable_table_check_constraint(&self) -> bool
pub fn enable_table_foreign_key(&self) -> bool
pub fn enable_table_keys(&self) -> bool
pub fn enable_unorchestrated_cluster_replicas(&self) -> bool
pub fn enable_unstable_dependencies(&self) -> bool
pub fn enable_disk_cluster_replicas(&self) -> bool
pub fn enable_within_timestamp_order_by_in_subscribe(&self) -> bool
pub fn enable_cardinality_estimates(&self) -> bool
pub fn enable_connection_validation_syntax(&self) -> bool
pub fn enable_alter_set_cluster(&self) -> bool
pub fn enable_unsafe_functions(&self) -> bool
pub fn enable_managed_cluster_availability_zones(&self) -> bool
pub fn statement_logging_use_reproducible_rng(&self) -> bool
pub fn enable_notices_for_index_already_exists(&self) -> bool
pub fn enable_notices_for_index_too_wide_for_literal_constraints(&self) -> bool
pub fn enable_notices_for_index_empty_key(&self) -> bool
pub fn enable_comment(&self) -> bool
pub fn enable_alter_swap(&self) -> bool
pub fn enable_new_outer_join_lowering(&self) -> bool
pub fn enable_time_at_time_zone(&self) -> bool
pub fn enable_load_generator_key_value(&self) -> bool
pub fn enable_expressions_in_limit_syntax(&self) -> bool
pub fn enable_mz_notices(&self) -> bool
pub fn enable_eager_delta_joins(&self) -> bool
pub fn enable_off_thread_optimization(&self) -> bool
pub fn enable_refresh_every_mvs(&self) -> bool
pub fn enable_cluster_schedule_refresh(&self) -> bool
pub fn enable_reduce_mfp_fusion(&self) -> bool
pub fn enable_worker_core_affinity(&self) -> bool
pub fn enable_copy_to_expr(&self) -> bool
pub fn enable_session_timelines(&self) -> bool
pub fn enable_variadic_left_join_lowering(&self) -> bool
pub fn enable_redacted_test_option(&self) -> bool
pub fn enable_letrec_fixpoint_analysis(&self) -> bool
pub fn enable_kafka_sink_headers(&self) -> bool
pub fn enable_kafka_sink_partition_by(&self) -> bool
pub fn enable_unlimited_retain_history(&self) -> bool
pub fn enable_envelope_upsert_inline_errors(&self) -> bool
pub fn enable_alter_table_add_column(&self) -> bool
pub fn enable_graceful_cluster_reconfiguration(&self) -> bool
pub fn enable_aws_msk_iam_auth(&self) -> bool
pub fn enable_clock_load_generator(&self) -> bool
pub fn enable_yugabyte_connection(&self) -> bool
pub fn enable_value_window_function_fusion(&self) -> bool
pub fn enable_window_aggregation_fusion(&self) -> bool
pub fn enable_reduce_unnest_list_fusion(&self) -> bool
pub fn enable_continual_task_create(&self) -> bool
pub fn enable_continual_task_transform(&self) -> bool
pub fn enable_continual_task_retain(&self) -> bool
pub fn enable_network_policies(&self) -> bool
source§impl SystemVars
impl SystemVars
sourceconst SESSION_VARS: LazyLock<BTreeMap<&'static UncasedStr, &'static VarDefinition>> = _
const SESSION_VARS: LazyLock<BTreeMap<&'static UncasedStr, &'static VarDefinition>> = _
Set of SystemVar
s that can also get set at a per-Session level.
TODO(parkmycar): Instead of a separate list, make this a field on VarDefinition.
pub fn new(active_connection_count: Arc<Mutex<ConnectionCounter>>) -> Self
pub fn dyncfgs(&self) -> &ConfigSet
pub fn set_unsafe(self, allow_unsafe: bool) -> Self
pub fn allow_unsafe(&self) -> bool
fn expect_value<V: 'static>(&self, var: &VarDefinition) -> &V
fn expect_config_value<V: ConfigType + 'static>(&self, name: &UncasedStr) -> &V
sourcepub fn reset_all(&mut self)
pub fn reset_all(&mut self)
Reset all the values to their defaults (preserving defaults from `VarMut::set_default).
sourcepub fn iter(&self) -> impl Iterator<Item = &dyn Var>
pub fn iter(&self) -> impl Iterator<Item = &dyn Var>
Returns an iterator over the configuration parameters and their current values on disk.
sourcepub fn iter_synced(&self) -> impl Iterator<Item = &dyn Var>
pub fn iter_synced(&self) -> impl Iterator<Item = &dyn Var>
Returns an iterator over the configuration parameters and their current
values on disk. Compared to SystemVars::iter
, this should omit vars
that shouldn’t be synced by SystemParameterFrontend.
sourcepub fn iter_session(&self) -> impl Iterator<Item = &dyn Var>
pub fn iter_session(&self) -> impl Iterator<Item = &dyn Var>
Returns an iterator over the configuration parameters that can be overriden per-Session.
sourcepub fn user_modifiable(&self, name: &str) -> bool
pub fn user_modifiable(&self, name: &str) -> bool
Returns whether or not this parameter can be modified by a superuser.
sourcepub fn get(&self, name: &str) -> Result<&dyn Var, VarError>
pub fn get(&self, name: &str) -> Result<&dyn Var, VarError>
Returns a Var
representing the configuration parameter with the
specified name.
Configuration parameters are matched case insensitively. If no such
configuration parameter exists, get
returns an error.
Note that:
-
If
name
is known at compile time, you should instead use the named accessor to access the variable with its true Rust type. For example,self.get("max_tables").value()
returns the string"25"
or the current value, whileself.max_tables()
returns an i32. -
This function does not check that the access variable should be visible because of other settings or users. Before or after accessing this method, you should call
Var::visible
.
§Errors
The call will return an error:
- If
name
does not refer to a validSystemVars
field.
sourcepub fn is_default(
&self,
name: &str,
input: VarInput<'_>,
) -> Result<bool, VarError>
pub fn is_default( &self, name: &str, input: VarInput<'_>, ) -> Result<bool, VarError>
Check if the given values
is the default value for the Var
identified by name
.
Note that this function does not check that the access variable should
be visible because of other settings or users. Before or after accessing
this method, you should call Var::visible
.
§Errors
The call will return an error:
- If
name
does not refer to a validSystemVars
field. - If
values
does not represent a validSystemVars
value forname
.
sourcepub fn set(&mut self, name: &str, input: VarInput<'_>) -> Result<bool, VarError>
pub fn set(&mut self, name: &str, input: VarInput<'_>) -> Result<bool, VarError>
Sets the configuration parameter named name
to the value represented
by input
.
Like with SystemVars::get
, configuration parameters are matched case
insensitively. If input
is not valid, as determined by the underlying
configuration parameter, or if the named configuration parameter does
not exist, an error is returned.
Return a bool
value indicating whether the Var
identified by
name
was modified by this call (it won’t be if it already had the
given input
).
Note that this function does not check that the access variable should
be visible because of other settings or users. Before or after accessing
this method, you should call Var::visible
.
§Errors
The call will return an error:
- If
name
does not refer to a validSystemVars
field. - If
input
does not represent a validSystemVars
value forname
.
sourcepub fn parse(
&self,
name: &str,
input: VarInput<'_>,
) -> Result<Box<dyn Value>, VarError>
pub fn parse( &self, name: &str, input: VarInput<'_>, ) -> Result<Box<dyn Value>, VarError>
Parses the configuration parameter value represented by input
named
name
.
Like with SystemVars::get
, configuration parameters are matched case
insensitively. If input
is not valid, as determined by the underlying
configuration parameter, or if the named configuration parameter does
not exist, an error is returned.
Return a Box<dyn Value>
that is the result of parsing input
.
Note that this function does not check that the access variable should
be visible because of other settings or users. Before or after accessing
this method, you should call Var::visible
.
§Errors
The call will return an error:
- If
name
does not refer to a validSystemVars
field. - If
input
does not represent a validSystemVars
value forname
.
sourcepub fn set_default(
&mut self,
name: &str,
input: VarInput<'_>,
) -> Result<(), VarError>
pub fn set_default( &mut self, name: &str, input: VarInput<'_>, ) -> Result<(), VarError>
Set the default for this variable. This is the value this
variable will be be reset
to. If no default is set, the static default in the
variable definition is used instead.
Note that this function does not check that the access variable should
be visible because of other settings or users. Before or after accessing
this method, you should call Var::visible
.
sourcepub fn reset(&mut self, name: &str) -> Result<bool, VarError>
pub fn reset(&mut self, name: &str) -> Result<bool, VarError>
Sets the configuration parameter named name
to its default value.
Like with SystemVars::get
, configuration parameters are matched case
insensitively. If the named configuration parameter does not exist, an
error is returned.
Return a bool
value indicating whether the Var
identified by
name
was modified by this call (it won’t be if was already reset).
Note that this function does not check that the access variable should
be visible because of other settings or users. Before or after accessing
this method, you should call Var::visible
.
§Errors
The call will return an error:
- If
name
does not refer to a validSystemVars
field.
sourcepub fn defaults(&self) -> BTreeMap<String, String>
pub fn defaults(&self) -> BTreeMap<String, String>
Returns a map from each system parameter’s name to its default value.
sourcefn propagate_var_change(&self, name: &str)
fn propagate_var_change(&self, name: &str)
Propagate a change to the parameter named name
to our state.
sourcefn refresh_internal_state(&self)
fn refresh_internal_state(&self)
Make sure that the internal state matches the SystemVars. Generally
only needed when initializing, set
, set_default
, and reset
are responsible for keeping the internal state in sync with
the affected SystemVars.
sourcepub fn default_cluster(&self) -> String
pub fn default_cluster(&self) -> String
Returns the system default for the CLUSTER
session variable. To know the active cluster
for the current session, you must check the SessionVars
.
sourcepub fn max_kafka_connections(&self) -> u32
pub fn max_kafka_connections(&self) -> u32
Returns the value of the max_kafka_connections
configuration parameter.
sourcepub fn max_postgres_connections(&self) -> u32
pub fn max_postgres_connections(&self) -> u32
Returns the value of the max_postgres_connections
configuration parameter.
sourcepub fn max_mysql_connections(&self) -> u32
pub fn max_mysql_connections(&self) -> u32
Returns the value of the max_mysql_connections
configuration parameter.
sourcepub fn max_aws_privatelink_connections(&self) -> u32
pub fn max_aws_privatelink_connections(&self) -> u32
Returns the value of the max_aws_privatelink_connections
configuration parameter.
sourcepub fn max_tables(&self) -> u32
pub fn max_tables(&self) -> u32
Returns the value of the max_tables
configuration parameter.
sourcepub fn max_sources(&self) -> u32
pub fn max_sources(&self) -> u32
Returns the value of the max_sources
configuration parameter.
sourcepub fn max_materialized_views(&self) -> u32
pub fn max_materialized_views(&self) -> u32
Returns the value of the max_materialized_views
configuration parameter.
sourcepub fn max_clusters(&self) -> u32
pub fn max_clusters(&self) -> u32
Returns the value of the max_clusters
configuration parameter.
sourcepub fn max_replicas_per_cluster(&self) -> u32
pub fn max_replicas_per_cluster(&self) -> u32
Returns the value of the max_replicas_per_cluster
configuration parameter.
sourcepub fn max_credit_consumption_rate(&self) -> Numeric
pub fn max_credit_consumption_rate(&self) -> Numeric
Returns the value of the max_credit_consumption_rate
configuration parameter.
sourcepub fn max_databases(&self) -> u32
pub fn max_databases(&self) -> u32
Returns the value of the max_databases
configuration parameter.
sourcepub fn max_schemas_per_database(&self) -> u32
pub fn max_schemas_per_database(&self) -> u32
Returns the value of the max_schemas_per_database
configuration parameter.
sourcepub fn max_objects_per_schema(&self) -> u32
pub fn max_objects_per_schema(&self) -> u32
Returns the value of the max_objects_per_schema
configuration parameter.
sourcepub fn max_secrets(&self) -> u32
pub fn max_secrets(&self) -> u32
Returns the value of the max_secrets
configuration parameter.
sourcepub fn max_continual_tasks(&self) -> u32
pub fn max_continual_tasks(&self) -> u32
Returns the value of the max_continual_tasks
configuration parameter.
sourcepub fn max_network_policies(&self) -> u32
pub fn max_network_policies(&self) -> u32
Returns the value of the max_network_policies
configuration parameter.
sourcepub fn max_rules_per_network_policy(&self) -> u32
pub fn max_rules_per_network_policy(&self) -> u32
Returns the value of the max_network_policies
configuration parameter.
sourcepub fn max_result_size(&self) -> u64
pub fn max_result_size(&self) -> u64
Returns the value of the max_result_size
configuration parameter.
sourcepub fn max_copy_from_size(&self) -> u32
pub fn max_copy_from_size(&self) -> u32
Returns the value of the max_copy_from_size
configuration parameter.
sourcepub fn allowed_cluster_replica_sizes(&self) -> Vec<String>
pub fn allowed_cluster_replica_sizes(&self) -> Vec<String>
Returns the value of the allowed_cluster_replica_sizes
configuration parameter.
sourcepub fn disk_cluster_replicas_default(&self) -> bool
pub fn disk_cluster_replicas_default(&self) -> bool
Returns the disk_cluster_replicas_default
configuration parameter.
pub fn upsert_rocksdb_auto_spill_to_disk(&self) -> bool
pub fn upsert_rocksdb_auto_spill_threshold_bytes(&self) -> usize
pub fn upsert_rocksdb_compaction_style(&self) -> CompactionStyle
pub fn upsert_rocksdb_optimize_compaction_memtable_budget(&self) -> usize
pub fn upsert_rocksdb_level_compaction_dynamic_level_bytes(&self) -> bool
pub fn upsert_rocksdb_universal_compaction_ratio(&self) -> i32
pub fn upsert_rocksdb_parallelism(&self) -> Option<i32>
pub fn upsert_rocksdb_compression_type(&self) -> CompressionType
pub fn upsert_rocksdb_bottommost_compression_type(&self) -> CompressionType
pub fn upsert_rocksdb_batch_size(&self) -> usize
pub fn upsert_rocksdb_retry_duration(&self) -> Duration
pub fn upsert_rocksdb_stats_log_interval_seconds(&self) -> u32
pub fn upsert_rocksdb_stats_persist_interval_seconds(&self) -> u32
pub fn upsert_rocksdb_point_lookup_block_cache_size_mb(&self) -> Option<u32>
pub fn upsert_rocksdb_shrink_allocated_buffers_by_ratio(&self) -> usize
pub fn upsert_rocksdb_write_buffer_manager_cluster_memory_fraction( &self, ) -> Option<Numeric>
pub fn upsert_rocksdb_write_buffer_manager_memory_bytes(&self) -> Option<usize>
pub fn upsert_rocksdb_write_buffer_manager_allow_stall(&self) -> bool
pub fn persist_fast_path_limit(&self) -> usize
sourcepub fn pg_source_connect_timeout(&self) -> Duration
pub fn pg_source_connect_timeout(&self) -> Duration
Returns the pg_source_connect_timeout
configuration parameter.
sourcepub fn pg_source_tcp_keepalives_retries(&self) -> u32
pub fn pg_source_tcp_keepalives_retries(&self) -> u32
Returns the pg_source_tcp_keepalives_retries
configuration parameter.
sourcepub fn pg_source_tcp_keepalives_idle(&self) -> Duration
pub fn pg_source_tcp_keepalives_idle(&self) -> Duration
Returns the pg_source_tcp_keepalives_idle
configuration parameter.
sourcepub fn pg_source_tcp_keepalives_interval(&self) -> Duration
pub fn pg_source_tcp_keepalives_interval(&self) -> Duration
Returns the pg_source_tcp_keepalives_interval
configuration parameter.
sourcepub fn pg_source_tcp_user_timeout(&self) -> Duration
pub fn pg_source_tcp_user_timeout(&self) -> Duration
Returns the pg_source_tcp_user_timeout
configuration parameter.
sourcepub fn pg_source_tcp_configure_server(&self) -> bool
pub fn pg_source_tcp_configure_server(&self) -> bool
Returns the pg_source_tcp_configure_server
configuration parameter.
sourcepub fn pg_source_snapshot_statement_timeout(&self) -> Duration
pub fn pg_source_snapshot_statement_timeout(&self) -> Duration
Returns the pg_source_snapshot_statement_timeout
configuration parameter.
sourcepub fn pg_source_wal_sender_timeout(&self) -> Option<Duration>
pub fn pg_source_wal_sender_timeout(&self) -> Option<Duration>
Returns the pg_source_wal_sender_timeout
configuration parameter.
sourcepub fn pg_source_snapshot_collect_strict_count(&self) -> bool
pub fn pg_source_snapshot_collect_strict_count(&self) -> bool
Returns the pg_source_snapshot_collect_strict_count
configuration parameter.
sourcepub fn pg_source_snapshot_fallback_to_strict_count(&self) -> bool
pub fn pg_source_snapshot_fallback_to_strict_count(&self) -> bool
Returns the pg_source_snapshot_fallback_to_strict_count
configuration parameter.
sourcepub fn pg_source_snapshot_wait_for_count(&self) -> bool
pub fn pg_source_snapshot_wait_for_count(&self) -> bool
Returns the pg_source_snapshot_collect_strict_count
configuration parameter.
sourcepub fn mysql_source_tcp_keepalive(&self) -> Duration
pub fn mysql_source_tcp_keepalive(&self) -> Duration
Returns the mysql_source_tcp_keepalive
configuration parameter.
sourcepub fn mysql_source_snapshot_max_execution_time(&self) -> Duration
pub fn mysql_source_snapshot_max_execution_time(&self) -> Duration
Returns the mysql_source_snapshot_max_execution_time
configuration parameter.
sourcepub fn mysql_source_snapshot_lock_wait_timeout(&self) -> Duration
pub fn mysql_source_snapshot_lock_wait_timeout(&self) -> Duration
Returns the mysql_source_snapshot_lock_wait_timeout
configuration parameter.
sourcepub fn ssh_check_interval(&self) -> Duration
pub fn ssh_check_interval(&self) -> Duration
Returns the ssh_check_interval
configuration parameter.
sourcepub fn ssh_connect_timeout(&self) -> Duration
pub fn ssh_connect_timeout(&self) -> Duration
Returns the ssh_connect_timeout
configuration parameter.
sourcepub fn ssh_keepalives_idle(&self) -> Duration
pub fn ssh_keepalives_idle(&self) -> Duration
Returns the ssh_keepalives_idle
configuration parameter.
sourcepub fn kafka_socket_keepalive(&self) -> bool
pub fn kafka_socket_keepalive(&self) -> bool
Returns the kafka_socket_keepalive
configuration parameter.
sourcepub fn kafka_socket_timeout(&self) -> Option<Duration>
pub fn kafka_socket_timeout(&self) -> Option<Duration>
Returns the kafka_socket_timeout
configuration parameter.
sourcepub fn kafka_transaction_timeout(&self) -> Duration
pub fn kafka_transaction_timeout(&self) -> Duration
Returns the kafka_transaction_timeout
configuration parameter.
sourcepub fn kafka_socket_connection_setup_timeout(&self) -> Duration
pub fn kafka_socket_connection_setup_timeout(&self) -> Duration
Returns the kafka_socket_connection_setup_timeout
configuration parameter.
sourcepub fn kafka_fetch_metadata_timeout(&self) -> Duration
pub fn kafka_fetch_metadata_timeout(&self) -> Duration
Returns the kafka_fetch_metadata_timeout
configuration parameter.
sourcepub fn kafka_progress_record_fetch_timeout(&self) -> Option<Duration>
pub fn kafka_progress_record_fetch_timeout(&self) -> Option<Duration>
Returns the kafka_progress_record_fetch_timeout
configuration parameter.
sourcepub fn kafka_default_metadata_fetch_interval(&self) -> Duration
pub fn kafka_default_metadata_fetch_interval(&self) -> Duration
Returns the kafka_default_metadata_fetch_interval
configuration parameter.
sourcepub fn crdb_connect_timeout(&self) -> Duration
pub fn crdb_connect_timeout(&self) -> Duration
Returns the crdb_connect_timeout
configuration parameter.
sourcepub fn crdb_tcp_user_timeout(&self) -> Duration
pub fn crdb_tcp_user_timeout(&self) -> Duration
Returns the crdb_tcp_user_timeout
configuration parameter.
sourcepub fn storage_dataflow_max_inflight_bytes(&self) -> Option<usize>
pub fn storage_dataflow_max_inflight_bytes(&self) -> Option<usize>
Returns the storage_dataflow_max_inflight_bytes
configuration parameter.
sourcepub fn storage_dataflow_max_inflight_bytes_to_cluster_size_fraction(
&self,
) -> Option<Numeric>
pub fn storage_dataflow_max_inflight_bytes_to_cluster_size_fraction( &self, ) -> Option<Numeric>
Returns the storage_dataflow_max_inflight_bytes_to_cluster_size_fraction
configuration parameter.
sourcepub fn storage_shrink_upsert_unused_buffers_by_ratio(&self) -> usize
pub fn storage_shrink_upsert_unused_buffers_by_ratio(&self) -> usize
Returns the storage_shrink_upsert_unused_buffers_by_ratio
configuration parameter.
sourcepub fn storage_dataflow_max_inflight_bytes_disk_only(&self) -> bool
pub fn storage_dataflow_max_inflight_bytes_disk_only(&self) -> bool
Returns the storage_dataflow_max_inflight_bytes_disk_only
configuration parameter.
sourcepub fn storage_statistics_interval(&self) -> Duration
pub fn storage_statistics_interval(&self) -> Duration
Returns the storage_statistics_interval
configuration parameter.
sourcepub fn storage_statistics_collection_interval(&self) -> Duration
pub fn storage_statistics_collection_interval(&self) -> Duration
Returns the storage_statistics_collection_interval
configuration parameter.
sourcepub fn storage_record_source_sink_namespaced_errors(&self) -> bool
pub fn storage_record_source_sink_namespaced_errors(&self) -> bool
Returns the storage_record_source_sink_namespaced_errors
configuration parameter.
sourcepub fn persist_stats_filter_enabled(&self) -> bool
pub fn persist_stats_filter_enabled(&self) -> bool
Returns the persist_stats_filter_enabled
configuration parameter.
pub fn dyncfg_updates(&self) -> ConfigUpdates
sourcepub fn metrics_retention(&self) -> Duration
pub fn metrics_retention(&self) -> Duration
Returns the metrics_retention
configuration parameter.
sourcepub fn unsafe_mock_audit_event_timestamp(&self) -> Option<Timestamp>
pub fn unsafe_mock_audit_event_timestamp(&self) -> Option<Timestamp>
Returns the unsafe_mock_audit_event_timestamp
configuration parameter.
sourcepub fn enable_rbac_checks(&self) -> bool
pub fn enable_rbac_checks(&self) -> bool
Returns the enable_rbac_checks
configuration parameter.
sourcepub fn max_connections(&self) -> u32
pub fn max_connections(&self) -> u32
Returns the max_connections
configuration parameter.
pub fn default_network_policy_name(&self) -> String
sourcepub fn superuser_reserved_connections(&self) -> u32
pub fn superuser_reserved_connections(&self) -> u32
Returns the superuser_reserved_connections
configuration parameter.
pub fn keep_n_source_status_history_entries(&self) -> usize
pub fn keep_n_sink_status_history_entries(&self) -> usize
pub fn keep_n_privatelink_status_history_entries(&self) -> usize
pub fn replica_status_history_retention_window(&self) -> Duration
sourcepub fn arrangement_exert_proportionality(&self) -> u32
pub fn arrangement_exert_proportionality(&self) -> u32
Returns the arrangement_exert_proportionality
configuration parameter.
sourcepub fn enable_storage_shard_finalization(&self) -> bool
pub fn enable_storage_shard_finalization(&self) -> bool
Returns the enable_storage_shard_finalization
configuration parameter.
pub fn enable_consolidate_after_union_negate(&self) -> bool
sourcepub fn enable_default_connection_validation(&self) -> bool
pub fn enable_default_connection_validation(&self) -> bool
Returns the enable_default_connection_validation
configuration parameter.
sourcepub fn min_timestamp_interval(&self) -> Duration
pub fn min_timestamp_interval(&self) -> Duration
Returns the min_timestamp_interval
configuration parameter.
sourcepub fn max_timestamp_interval(&self) -> Duration
pub fn max_timestamp_interval(&self) -> Duration
Returns the max_timestamp_interval
configuration parameter.
pub fn logging_filter(&self) -> CloneableEnvFilter
pub fn opentelemetry_filter(&self) -> CloneableEnvFilter
pub fn logging_filter_defaults(&self) -> Vec<SerializableDirective>
pub fn opentelemetry_filter_defaults(&self) -> Vec<SerializableDirective>
pub fn sentry_filters(&self) -> Vec<SerializableDirective>
pub fn webhooks_secrets_caching_ttl_secs(&self) -> usize
pub fn coord_slow_message_warn_threshold(&self) -> Duration
pub fn grpc_client_http2_keep_alive_interval(&self) -> Duration
pub fn grpc_client_http2_keep_alive_timeout(&self) -> Duration
pub fn grpc_connect_timeout(&self) -> Duration
pub fn cluster_multi_process_replica_az_affinity_weight(&self) -> Option<i32>
pub fn cluster_soften_replication_anti_affinity(&self) -> bool
pub fn cluster_soften_replication_anti_affinity_weight(&self) -> i32
pub fn cluster_enable_topology_spread(&self) -> bool
pub fn cluster_topology_spread_ignore_non_singular_scale(&self) -> bool
pub fn cluster_topology_spread_max_skew(&self) -> i32
pub fn cluster_topology_spread_soft(&self) -> bool
pub fn cluster_soften_az_affinity(&self) -> bool
pub fn cluster_soften_az_affinity_weight(&self) -> i32
pub fn cluster_always_use_disk(&self) -> bool
pub fn cluster_alter_check_ready_interval(&self) -> Duration
pub fn cluster_check_scheduling_policies_interval(&self) -> Duration
pub fn cluster_security_context_enabled(&self) -> bool
pub fn cluster_refresh_mv_compaction_estimate(&self) -> Duration
sourcepub fn privatelink_status_update_quota_per_minute(&self) -> u32
pub fn privatelink_status_update_quota_per_minute(&self) -> u32
Returns the privatelink_status_update_quota_per_minute
configuration parameter.
pub fn statement_logging_target_data_rate(&self) -> Option<usize>
pub fn statement_logging_max_data_credit(&self) -> Option<usize>
sourcepub fn statement_logging_max_sample_rate(&self) -> Numeric
pub fn statement_logging_max_sample_rate(&self) -> Numeric
Returns the statement_logging_max_sample_rate
configuration parameter.
sourcepub fn statement_logging_default_sample_rate(&self) -> Numeric
pub fn statement_logging_default_sample_rate(&self) -> Numeric
Returns the statement_logging_default_sample_rate
configuration parameter.
sourcepub fn optimizer_stats_timeout(&self) -> Duration
pub fn optimizer_stats_timeout(&self) -> Duration
Returns the optimizer_stats_timeout
configuration parameter.
sourcepub fn optimizer_oneshot_stats_timeout(&self) -> Duration
pub fn optimizer_oneshot_stats_timeout(&self) -> Duration
Returns the optimizer_oneshot_stats_timeout
configuration parameter.
sourcepub fn webhook_concurrent_request_limit(&self) -> usize
pub fn webhook_concurrent_request_limit(&self) -> usize
Returns the webhook_concurrent_request_limit
configuration parameter.
sourcepub fn pg_timestamp_oracle_connection_pool_max_size(&self) -> usize
pub fn pg_timestamp_oracle_connection_pool_max_size(&self) -> usize
Returns the pg_timestamp_oracle_connection_pool_max_size
configuration parameter.
sourcepub fn pg_timestamp_oracle_connection_pool_max_wait(&self) -> Option<Duration>
pub fn pg_timestamp_oracle_connection_pool_max_wait(&self) -> Option<Duration>
Returns the pg_timestamp_oracle_connection_pool_max_wait
configuration parameter.
sourcepub fn pg_timestamp_oracle_connection_pool_ttl(&self) -> Duration
pub fn pg_timestamp_oracle_connection_pool_ttl(&self) -> Duration
Returns the pg_timestamp_oracle_connection_pool_ttl
configuration parameter.
sourcepub fn pg_timestamp_oracle_connection_pool_ttl_stagger(&self) -> Duration
pub fn pg_timestamp_oracle_connection_pool_ttl_stagger(&self) -> Duration
Returns the pg_timestamp_oracle_connection_pool_ttl_stagger
configuration parameter.
sourcepub fn user_storage_managed_collections_batch_duration(&self) -> Duration
pub fn user_storage_managed_collections_batch_duration(&self) -> Duration
Returns the user_storage_managed_collections_batch_duration
configuration parameter.
pub fn enable_create_table_from_source(&self) -> bool
pub fn force_source_table_syntax(&self) -> bool
sourcepub fn is_compute_config_var(&self, name: &str) -> bool
pub fn is_compute_config_var(&self, name: &str) -> bool
Returns whether the named variable is a compute configuration parameter
(things that go in ComputeParameters
and are sent to replicas via UpdateConfiguration
commands).
sourcepub fn is_storage_config_var(&self, name: &str) -> bool
pub fn is_storage_config_var(&self, name: &str) -> bool
Returns whether the named variable is a storage configuration parameter.
sourcefn is_dyncfg_var(&self, name: &str) -> bool
fn is_dyncfg_var(&self, name: &str) -> bool
Returns whether the named variable is a dyncfg configuration parameter.
Trait Implementations§
source§impl Clone for SystemVars
impl Clone for SystemVars
source§fn clone(&self) -> SystemVars
fn clone(&self) -> SystemVars
1.0.0 · source§fn clone_from(&mut self, source: &Self)
fn clone_from(&mut self, source: &Self)
source
. Read moresource§impl Debug for SystemVars
impl Debug for SystemVars
source§impl Default for SystemVars
impl Default for SystemVars
source§impl From<&SystemVars> for Config
impl From<&SystemVars> for Config
source§fn from(vars: &SystemVars) -> Self
fn from(vars: &SystemVars) -> Self
source§impl From<&SystemVars> for OptimizerFeatures
impl From<&SystemVars> for OptimizerFeatures
source§fn from(vars: &SystemVars) -> Self
fn from(vars: &SystemVars) -> Self
Auto Trait Implementations§
impl Freeze for SystemVars
impl !RefUnwindSafe for SystemVars
impl Send for SystemVars
impl Sync for SystemVars
impl Unpin for SystemVars
impl !UnwindSafe for SystemVars
Blanket Implementations§
source§impl<T> BorrowMut<T> for Twhere
T: ?Sized,
impl<T> BorrowMut<T> for Twhere
T: ?Sized,
source§fn borrow_mut(&mut self) -> &mut T
fn borrow_mut(&mut self) -> &mut T
source§impl<T> CloneToUninit for Twhere
T: Clone,
impl<T> CloneToUninit for Twhere
T: Clone,
source§default unsafe fn clone_to_uninit(&self, dst: *mut T)
default unsafe fn clone_to_uninit(&self, dst: *mut T)
clone_to_uninit
)source§impl<T> FmtForward for T
impl<T> FmtForward for T
source§fn fmt_binary(self) -> FmtBinary<Self>where
Self: Binary,
fn fmt_binary(self) -> FmtBinary<Self>where
Self: Binary,
self
to use its Binary
implementation when Debug
-formatted.source§fn fmt_display(self) -> FmtDisplay<Self>where
Self: Display,
fn fmt_display(self) -> FmtDisplay<Self>where
Self: Display,
self
to use its Display
implementation when
Debug
-formatted.source§fn fmt_lower_exp(self) -> FmtLowerExp<Self>where
Self: LowerExp,
fn fmt_lower_exp(self) -> FmtLowerExp<Self>where
Self: LowerExp,
self
to use its LowerExp
implementation when
Debug
-formatted.source§fn fmt_lower_hex(self) -> FmtLowerHex<Self>where
Self: LowerHex,
fn fmt_lower_hex(self) -> FmtLowerHex<Self>where
Self: LowerHex,
self
to use its LowerHex
implementation when
Debug
-formatted.source§fn fmt_octal(self) -> FmtOctal<Self>where
Self: Octal,
fn fmt_octal(self) -> FmtOctal<Self>where
Self: Octal,
self
to use its Octal
implementation when Debug
-formatted.source§fn fmt_pointer(self) -> FmtPointer<Self>where
Self: Pointer,
fn fmt_pointer(self) -> FmtPointer<Self>where
Self: Pointer,
self
to use its Pointer
implementation when
Debug
-formatted.source§fn fmt_upper_exp(self) -> FmtUpperExp<Self>where
Self: UpperExp,
fn fmt_upper_exp(self) -> FmtUpperExp<Self>where
Self: UpperExp,
self
to use its UpperExp
implementation when
Debug
-formatted.source§fn fmt_upper_hex(self) -> FmtUpperHex<Self>where
Self: UpperHex,
fn fmt_upper_hex(self) -> FmtUpperHex<Self>where
Self: UpperHex,
self
to use its UpperHex
implementation when
Debug
-formatted.source§impl<T> FutureExt for T
impl<T> FutureExt for T
source§fn with_context(self, otel_cx: Context) -> WithContext<Self>
fn with_context(self, otel_cx: Context) -> WithContext<Self>
source§fn with_current_context(self) -> WithContext<Self>
fn with_current_context(self) -> WithContext<Self>
source§impl<T> Instrument for T
impl<T> Instrument for T
source§fn instrument(self, span: Span) -> Instrumented<Self>
fn instrument(self, span: Span) -> Instrumented<Self>
source§fn in_current_span(self) -> Instrumented<Self>
fn in_current_span(self) -> Instrumented<Self>
source§impl<T> IntoRequest<T> for T
impl<T> IntoRequest<T> for T
source§fn into_request(self) -> Request<T>
fn into_request(self) -> Request<T>
T
in a tonic::Request
source§impl<T, U> OverrideFrom<Option<&T>> for Uwhere
U: OverrideFrom<T>,
impl<T, U> OverrideFrom<Option<&T>> for Uwhere
U: OverrideFrom<T>,
source§impl<T> Pipe for Twhere
T: ?Sized,
impl<T> Pipe for Twhere
T: ?Sized,
source§fn pipe<R>(self, func: impl FnOnce(Self) -> R) -> Rwhere
Self: Sized,
fn pipe<R>(self, func: impl FnOnce(Self) -> R) -> Rwhere
Self: Sized,
source§fn pipe_ref<'a, R>(&'a self, func: impl FnOnce(&'a Self) -> R) -> Rwhere
R: 'a,
fn pipe_ref<'a, R>(&'a self, func: impl FnOnce(&'a Self) -> R) -> Rwhere
R: 'a,
self
and passes that borrow into the pipe function. Read moresource§fn pipe_ref_mut<'a, R>(&'a mut self, func: impl FnOnce(&'a mut Self) -> R) -> Rwhere
R: 'a,
fn pipe_ref_mut<'a, R>(&'a mut self, func: impl FnOnce(&'a mut Self) -> R) -> Rwhere
R: 'a,
self
and passes that borrow into the pipe function. Read moresource§fn pipe_borrow<'a, B, R>(&'a self, func: impl FnOnce(&'a B) -> R) -> R
fn pipe_borrow<'a, B, R>(&'a self, func: impl FnOnce(&'a B) -> R) -> R
source§fn pipe_borrow_mut<'a, B, R>(
&'a mut self,
func: impl FnOnce(&'a mut B) -> R,
) -> R
fn pipe_borrow_mut<'a, B, R>( &'a mut self, func: impl FnOnce(&'a mut B) -> R, ) -> R
source§fn pipe_as_ref<'a, U, R>(&'a self, func: impl FnOnce(&'a U) -> R) -> R
fn pipe_as_ref<'a, U, R>(&'a self, func: impl FnOnce(&'a U) -> R) -> R
self
, then passes self.as_ref()
into the pipe function.source§fn pipe_as_mut<'a, U, R>(&'a mut self, func: impl FnOnce(&'a mut U) -> R) -> R
fn pipe_as_mut<'a, U, R>(&'a mut self, func: impl FnOnce(&'a mut U) -> R) -> R
self
, then passes self.as_mut()
into the pipe
function.source§fn pipe_deref<'a, T, R>(&'a self, func: impl FnOnce(&'a T) -> R) -> R
fn pipe_deref<'a, T, R>(&'a self, func: impl FnOnce(&'a T) -> R) -> R
self
, then passes self.deref()
into the pipe function.source§impl<T> Pointable for T
impl<T> Pointable for T
source§impl<T> ProgressEventTimestamp for T
impl<T> ProgressEventTimestamp for T
source§impl<P, R> ProtoType<R> for Pwhere
R: RustType<P>,
impl<P, R> ProtoType<R> for Pwhere
R: RustType<P>,
source§fn into_rust(self) -> Result<R, TryFromProtoError>
fn into_rust(self) -> Result<R, TryFromProtoError>
RustType::from_proto
.source§fn from_rust(rust: &R) -> P
fn from_rust(rust: &R) -> P
RustType::into_proto
.source§impl<'a, S, T> Semigroup<&'a S> for Twhere
T: Semigroup<S>,
impl<'a, S, T> Semigroup<&'a S> for Twhere
T: Semigroup<S>,
source§fn plus_equals(&mut self, rhs: &&'a S)
fn plus_equals(&mut self, rhs: &&'a S)
std::ops::AddAssign
, for types that do not implement AddAssign
.source§impl<T> Tap for T
impl<T> Tap for T
source§fn tap_borrow<B>(self, func: impl FnOnce(&B)) -> Self
fn tap_borrow<B>(self, func: impl FnOnce(&B)) -> Self
Borrow<B>
of a value. Read moresource§fn tap_borrow_mut<B>(self, func: impl FnOnce(&mut B)) -> Self
fn tap_borrow_mut<B>(self, func: impl FnOnce(&mut B)) -> Self
BorrowMut<B>
of a value. Read moresource§fn tap_ref<R>(self, func: impl FnOnce(&R)) -> Self
fn tap_ref<R>(self, func: impl FnOnce(&R)) -> Self
AsRef<R>
view of a value. Read moresource§fn tap_ref_mut<R>(self, func: impl FnOnce(&mut R)) -> Self
fn tap_ref_mut<R>(self, func: impl FnOnce(&mut R)) -> Self
AsMut<R>
view of a value. Read moresource§fn tap_deref<T>(self, func: impl FnOnce(&T)) -> Self
fn tap_deref<T>(self, func: impl FnOnce(&T)) -> Self
Deref::Target
of a value. Read moresource§fn tap_deref_mut<T>(self, func: impl FnOnce(&mut T)) -> Self
fn tap_deref_mut<T>(self, func: impl FnOnce(&mut T)) -> Self
Deref::Target
of a value. Read moresource§fn tap_dbg(self, func: impl FnOnce(&Self)) -> Self
fn tap_dbg(self, func: impl FnOnce(&Self)) -> Self
.tap()
only in debug builds, and is erased in release builds.source§fn tap_mut_dbg(self, func: impl FnOnce(&mut Self)) -> Self
fn tap_mut_dbg(self, func: impl FnOnce(&mut Self)) -> Self
.tap_mut()
only in debug builds, and is erased in release
builds.source§fn tap_borrow_dbg<B>(self, func: impl FnOnce(&B)) -> Self
fn tap_borrow_dbg<B>(self, func: impl FnOnce(&B)) -> Self
.tap_borrow()
only in debug builds, and is erased in release
builds.source§fn tap_borrow_mut_dbg<B>(self, func: impl FnOnce(&mut B)) -> Self
fn tap_borrow_mut_dbg<B>(self, func: impl FnOnce(&mut B)) -> Self
.tap_borrow_mut()
only in debug builds, and is erased in release
builds.source§fn tap_ref_dbg<R>(self, func: impl FnOnce(&R)) -> Self
fn tap_ref_dbg<R>(self, func: impl FnOnce(&R)) -> Self
.tap_ref()
only in debug builds, and is erased in release
builds.source§fn tap_ref_mut_dbg<R>(self, func: impl FnOnce(&mut R)) -> Self
fn tap_ref_mut_dbg<R>(self, func: impl FnOnce(&mut R)) -> Self
.tap_ref_mut()
only in debug builds, and is erased in release
builds.source§fn tap_deref_dbg<T>(self, func: impl FnOnce(&T)) -> Self
fn tap_deref_dbg<T>(self, func: impl FnOnce(&T)) -> Self
.tap_deref()
only in debug builds, and is erased in release
builds.