Struct SystemVars

Source
pub struct SystemVars {
    allow_unsafe: bool,
    vars: BTreeMap<&'static UncasedStr, SystemVar>,
    callbacks: BTreeMap<String, Vec<Arc<dyn Fn(&SystemVars) + Send + Sync>>>,
    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 SystemVars.

§callbacks: BTreeMap<String, Vec<Arc<dyn Fn(&SystemVars) + Send + Sync>>>

External components interested in when a SystemVar gets updated.

§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

Source

pub fn enable_all_feature_flags_by_default(&mut self)

Source

pub fn enable_for_item_parsing(&mut self)

Source

pub fn allow_real_time_recency(&self) -> bool

Source

pub fn enable_guard_subquery_tablefunc(&self) -> bool

Source

pub fn enable_binary_date_bin(&self) -> bool

Source

pub fn enable_date_bin_hopping(&self) -> bool

Source

pub fn enable_envelope_debezium_in_subscribe(&self) -> bool

Source

pub fn enable_envelope_materialize(&self) -> bool

Source

pub fn enable_explain_pushdown(&self) -> bool

Source

pub fn enable_index_options(&self) -> bool

Source

pub fn enable_list_length_max(&self) -> bool

Source

pub fn enable_list_n_layers(&self) -> bool

Source

pub fn enable_list_remove(&self) -> bool

Source

pub fn enable_logical_compaction_window(&self) -> bool

Source

pub fn enable_primary_key_not_enforced(&self) -> bool

Source

pub fn enable_collection_partition_by(&self) -> bool

Source

pub fn enable_multi_worker_storage_persist_sink(&self) -> bool

Source

pub fn enable_persist_streaming_snapshot_and_fetch(&self) -> bool

Source

pub fn enable_persist_streaming_compaction(&self) -> bool

Source

pub fn enable_raise_statement(&self) -> bool

Source

pub fn enable_repeat_row(&self) -> bool

Source

pub fn unsafe_enable_table_check_constraint(&self) -> bool

Source

pub fn unsafe_enable_table_foreign_key(&self) -> bool

Source

pub fn unsafe_enable_table_keys(&self) -> bool

Source

pub fn unsafe_enable_unorchestrated_cluster_replicas(&self) -> bool

Source

pub fn unsafe_enable_unstable_dependencies(&self) -> bool

Source

pub fn enable_within_timestamp_order_by_in_subscribe(&self) -> bool

Source

pub fn enable_cardinality_estimates(&self) -> bool

Source

pub fn enable_connection_validation_syntax(&self) -> bool

Source

pub fn enable_alter_set_cluster(&self) -> bool

Source

pub fn unsafe_enable_unsafe_functions(&self) -> bool

Source

pub fn enable_managed_cluster_availability_zones(&self) -> bool

Source

pub fn statement_logging_use_reproducible_rng(&self) -> bool

Source

pub fn enable_notices_for_index_already_exists(&self) -> bool

Source

pub fn enable_notices_for_index_too_wide_for_literal_constraints(&self) -> bool

Source

pub fn enable_notices_for_index_empty_key(&self) -> bool

Source

pub fn enable_alter_swap(&self) -> bool

Source

pub fn enable_new_outer_join_lowering(&self) -> bool

Source

pub fn enable_time_at_time_zone(&self) -> bool

Source

pub fn enable_load_generator_counter(&self) -> bool

Source

pub fn enable_load_generator_clock(&self) -> bool

Source

pub fn enable_load_generator_datums(&self) -> bool

Source

pub fn enable_load_generator_key_value(&self) -> bool

Source

pub fn enable_expressions_in_limit_syntax(&self) -> bool

Source

pub fn enable_mz_notices(&self) -> bool

Source

pub fn enable_eager_delta_joins(&self) -> bool

Source

pub fn enable_off_thread_optimization(&self) -> bool

Source

pub fn enable_refresh_every_mvs(&self) -> bool

Source

pub fn enable_cluster_schedule_refresh(&self) -> bool

Source

pub fn enable_reduce_mfp_fusion(&self) -> bool

Source

pub fn enable_worker_core_affinity(&self) -> bool

Source

pub fn enable_copy_to_expr(&self) -> bool

Source

pub fn enable_session_timelines(&self) -> bool

Source

pub fn enable_variadic_left_join_lowering(&self) -> bool

Source

pub fn enable_redacted_test_option(&self) -> bool

Source

pub fn enable_letrec_fixpoint_analysis(&self) -> bool

Source

pub fn enable_kafka_sink_headers(&self) -> bool

Source

pub fn enable_unlimited_retain_history(&self) -> bool

Source

pub fn enable_envelope_upsert_inline_errors(&self) -> bool

Source

pub fn enable_alter_table_add_column(&self) -> bool

Source

pub fn enable_zero_downtime_cluster_reconfiguration(&self) -> bool

Source

pub fn enable_aws_msk_iam_auth(&self) -> bool

Source

pub fn enable_continual_task_create(&self) -> bool

Source

pub fn enable_continual_task_transform(&self) -> bool

Source

pub fn enable_continual_task_retain(&self) -> bool

Source

pub fn enable_network_policies(&self) -> bool

Source

pub fn enable_create_table_from_source(&self) -> bool

Source

pub fn enable_copy_from_remote(&self) -> bool

Source

pub fn enable_join_prioritize_arranged(&self) -> bool

Source

pub fn enable_sql_server_source(&self) -> bool

Source

pub fn enable_projection_pushdown_after_relation_cse(&self) -> bool

Source

pub fn enable_less_reduce_in_eqprop(&self) -> bool

Source

pub fn enable_dequadratic_eqprop_map(&self) -> bool

Source

pub fn enable_eq_classes_withholding_errors(&self) -> bool

Source

pub fn enable_fast_path_plan_insights(&self) -> bool

Source

pub fn enable_with_ordinality_legacy_fallback(&self) -> bool

Source

pub fn enable_iceberg_sink(&self) -> bool

Source§

impl SystemVars

Source

pub fn new() -> Self

Source

pub fn dyncfgs(&self) -> &ConfigSet

Source

pub fn set_unsafe(self, allow_unsafe: bool) -> Self

Source

pub fn allow_unsafe(&self) -> bool

Source

fn expect_value<V: 'static>(&self, var: &VarDefinition) -> &V

Source

fn expect_config_value<V: ConfigType + 'static>(&self, name: &UncasedStr) -> &V

Source

pub fn reset_all(&mut self)

Reset all the values to their defaults (preserving defaults from `VarMut::set_default).

Source

pub fn iter(&self) -> impl Iterator<Item = &dyn Var>

Returns an iterator over the configuration parameters and their current values on disk.

Source

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.

Source

pub fn iter_session(&self) -> impl Iterator<Item = &dyn Var>

Returns an iterator over the configuration parameters that can be overriden per-Session.

Source

pub fn user_modifiable(&self, name: &str) -> bool

Returns whether or not this parameter can be modified by a superuser.

Source

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, while self.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:

  1. If name does not refer to a valid SystemVars field.
Source

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:

  1. If name does not refer to a valid SystemVars field.
  2. If values does not represent a valid SystemVars value for name.
Source

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:

  1. If name does not refer to a valid SystemVars field.
  2. If input does not represent a valid SystemVars value for name.
Source

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:

  1. If name does not refer to a valid SystemVars field.
  2. If input does not represent a valid SystemVars value for name.
Source

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.

Source

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:

  1. If name does not refer to a valid SystemVars field.
Source

pub fn defaults(&self) -> BTreeMap<String, String>

Returns a map from each system parameter’s name to its default value.

Source

pub fn register_callback( &mut self, var: &VarDefinition, callback: Arc<dyn Fn(&SystemVars) + Send + Sync>, )

Registers a closure that will get called when the value for the specified VarDefinition changes.

The callback is guaranteed to be called at least once.

Source

fn notify_callbacks(&self, name: &str)

Notify any external components interested in this variable.

Source

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.

Source

pub fn max_kafka_connections(&self) -> u32

Returns the value of the max_kafka_connections configuration parameter.

Source

pub fn max_postgres_connections(&self) -> u32

Returns the value of the max_postgres_connections configuration parameter.

Source

pub fn max_mysql_connections(&self) -> u32

Returns the value of the max_mysql_connections configuration parameter.

Source

pub fn max_sql_server_connections(&self) -> u32

Returns the value of the max_sql_server_connections configuration parameter.

Returns the value of the max_aws_privatelink_connections configuration parameter.

Source

pub fn max_tables(&self) -> u32

Returns the value of the max_tables configuration parameter.

Source

pub fn max_sources(&self) -> u32

Returns the value of the max_sources configuration parameter.

Source

pub fn max_sinks(&self) -> u32

Returns the value of the max_sinks configuration parameter.

Source

pub fn max_materialized_views(&self) -> u32

Returns the value of the max_materialized_views configuration parameter.

Source

pub fn max_clusters(&self) -> u32

Returns the value of the max_clusters configuration parameter.

Source

pub fn max_replicas_per_cluster(&self) -> u32

Returns the value of the max_replicas_per_cluster configuration parameter.

Source

pub fn max_credit_consumption_rate(&self) -> Numeric

Returns the value of the max_credit_consumption_rate configuration parameter.

Source

pub fn max_databases(&self) -> u32

Returns the value of the max_databases configuration parameter.

Source

pub fn max_schemas_per_database(&self) -> u32

Returns the value of the max_schemas_per_database configuration parameter.

Source

pub fn max_objects_per_schema(&self) -> u32

Returns the value of the max_objects_per_schema configuration parameter.

Source

pub fn max_secrets(&self) -> u32

Returns the value of the max_secrets configuration parameter.

Source

pub fn max_roles(&self) -> u32

Returns the value of the max_roles configuration parameter.

Source

pub fn max_continual_tasks(&self) -> u32

Returns the value of the max_continual_tasks configuration parameter.

Source

pub fn max_network_policies(&self) -> u32

Returns the value of the max_network_policies configuration parameter.

Source

pub fn max_rules_per_network_policy(&self) -> u32

Returns the value of the max_network_policies configuration parameter.

Source

pub fn max_result_size(&self) -> u64

Returns the value of the max_result_size configuration parameter.

Source

pub fn max_copy_from_size(&self) -> u32

Returns the value of the max_copy_from_size configuration parameter.

Source

pub fn allowed_cluster_replica_sizes(&self) -> Vec<String>

Returns the value of the allowed_cluster_replica_sizes configuration parameter.

Source

pub fn default_cluster_replication_factor(&self) -> u32

Returns the value of the default_cluster_replication_factor configuration parameter.

Source

pub fn upsert_rocksdb_compaction_style(&self) -> CompactionStyle

Source

pub fn upsert_rocksdb_optimize_compaction_memtable_budget(&self) -> usize

Source

pub fn upsert_rocksdb_level_compaction_dynamic_level_bytes(&self) -> bool

Source

pub fn upsert_rocksdb_universal_compaction_ratio(&self) -> i32

Source

pub fn upsert_rocksdb_parallelism(&self) -> Option<i32>

Source

pub fn upsert_rocksdb_compression_type(&self) -> CompressionType

Source

pub fn upsert_rocksdb_bottommost_compression_type(&self) -> CompressionType

Source

pub fn upsert_rocksdb_batch_size(&self) -> usize

Source

pub fn upsert_rocksdb_retry_duration(&self) -> Duration

Source

pub fn upsert_rocksdb_stats_log_interval_seconds(&self) -> u32

Source

pub fn upsert_rocksdb_stats_persist_interval_seconds(&self) -> u32

Source

pub fn upsert_rocksdb_point_lookup_block_cache_size_mb(&self) -> Option<u32>

Source

pub fn upsert_rocksdb_shrink_allocated_buffers_by_ratio(&self) -> usize

Source

pub fn upsert_rocksdb_write_buffer_manager_cluster_memory_fraction( &self, ) -> Option<Numeric>

Source

pub fn upsert_rocksdb_write_buffer_manager_memory_bytes(&self) -> Option<usize>

Source

pub fn upsert_rocksdb_write_buffer_manager_allow_stall(&self) -> bool

Source

pub fn persist_fast_path_limit(&self) -> usize

Source

pub fn pg_source_connect_timeout(&self) -> Duration

Returns the pg_source_connect_timeout configuration parameter.

Source

pub fn pg_source_tcp_keepalives_retries(&self) -> u32

Returns the pg_source_tcp_keepalives_retries configuration parameter.

Source

pub fn pg_source_tcp_keepalives_idle(&self) -> Duration

Returns the pg_source_tcp_keepalives_idle configuration parameter.

Source

pub fn pg_source_tcp_keepalives_interval(&self) -> Duration

Returns the pg_source_tcp_keepalives_interval configuration parameter.

Source

pub fn pg_source_tcp_user_timeout(&self) -> Duration

Returns the pg_source_tcp_user_timeout configuration parameter.

Source

pub fn pg_source_tcp_configure_server(&self) -> bool

Returns the pg_source_tcp_configure_server configuration parameter.

Source

pub fn pg_source_snapshot_statement_timeout(&self) -> Duration

Returns the pg_source_snapshot_statement_timeout configuration parameter.

Source

pub fn pg_source_wal_sender_timeout(&self) -> Option<Duration>

Returns the pg_source_wal_sender_timeout configuration parameter.

Source

pub fn pg_source_snapshot_collect_strict_count(&self) -> bool

Returns the pg_source_snapshot_collect_strict_count configuration parameter.

Source

pub fn mysql_source_tcp_keepalive(&self) -> Duration

Returns the mysql_source_tcp_keepalive configuration parameter.

Source

pub fn mysql_source_snapshot_max_execution_time(&self) -> Duration

Returns the mysql_source_snapshot_max_execution_time configuration parameter.

Source

pub fn mysql_source_snapshot_lock_wait_timeout(&self) -> Duration

Returns the mysql_source_snapshot_lock_wait_timeout configuration parameter.

Source

pub fn mysql_source_connect_timeout(&self) -> Duration

Returns the mysql_source_connect_timeout configuration parameter.

Source

pub fn ssh_check_interval(&self) -> Duration

Returns the ssh_check_interval configuration parameter.

Source

pub fn ssh_connect_timeout(&self) -> Duration

Returns the ssh_connect_timeout configuration parameter.

Source

pub fn ssh_keepalives_idle(&self) -> Duration

Returns the ssh_keepalives_idle configuration parameter.

Source

pub fn kafka_socket_keepalive(&self) -> bool

Returns the kafka_socket_keepalive configuration parameter.

Source

pub fn kafka_socket_timeout(&self) -> Option<Duration>

Returns the kafka_socket_timeout configuration parameter.

Source

pub fn kafka_transaction_timeout(&self) -> Duration

Returns the kafka_transaction_timeout configuration parameter.

Source

pub fn kafka_socket_connection_setup_timeout(&self) -> Duration

Returns the kafka_socket_connection_setup_timeout configuration parameter.

Source

pub fn kafka_fetch_metadata_timeout(&self) -> Duration

Returns the kafka_fetch_metadata_timeout configuration parameter.

Source

pub fn kafka_progress_record_fetch_timeout(&self) -> Option<Duration>

Returns the kafka_progress_record_fetch_timeout configuration parameter.

Source

pub fn crdb_connect_timeout(&self) -> Duration

Returns the crdb_connect_timeout configuration parameter.

Source

pub fn crdb_tcp_user_timeout(&self) -> Duration

Returns the crdb_tcp_user_timeout configuration parameter.

Source

pub fn storage_dataflow_max_inflight_bytes(&self) -> Option<usize>

Returns the storage_dataflow_max_inflight_bytes configuration parameter.

Source

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.

Source

pub fn storage_shrink_upsert_unused_buffers_by_ratio(&self) -> usize

Returns the storage_shrink_upsert_unused_buffers_by_ratio configuration parameter.

Source

pub fn storage_dataflow_max_inflight_bytes_disk_only(&self) -> bool

Returns the storage_dataflow_max_inflight_bytes_disk_only configuration parameter.

Source

pub fn storage_statistics_interval(&self) -> Duration

Returns the storage_statistics_interval configuration parameter.

Source

pub fn storage_statistics_collection_interval(&self) -> Duration

Returns the storage_statistics_collection_interval configuration parameter.

Source

pub fn storage_record_source_sink_namespaced_errors(&self) -> bool

Returns the storage_record_source_sink_namespaced_errors configuration parameter.

Source

pub fn persist_stats_filter_enabled(&self) -> bool

Returns the persist_stats_filter_enabled configuration parameter.

Source

pub fn dyncfg_updates(&self) -> ConfigUpdates

Source

pub fn metrics_retention(&self) -> Duration

Returns the metrics_retention configuration parameter.

Source

pub fn unsafe_mock_audit_event_timestamp(&self) -> Option<Timestamp>

Returns the unsafe_mock_audit_event_timestamp configuration parameter.

Source

pub fn enable_rbac_checks(&self) -> bool

Returns the enable_rbac_checks configuration parameter.

Source

pub fn max_connections(&self) -> u32

Returns the max_connections configuration parameter.

Source

pub fn default_network_policy_name(&self) -> String

Source

pub fn superuser_reserved_connections(&self) -> u32

Returns the superuser_reserved_connections configuration parameter.

Source

pub fn keep_n_source_status_history_entries(&self) -> usize

Source

pub fn keep_n_sink_status_history_entries(&self) -> usize

Source

pub fn replica_status_history_retention_window(&self) -> Duration

Source

pub fn enable_storage_shard_finalization(&self) -> bool

Returns the enable_storage_shard_finalization configuration parameter.

Source

pub fn enable_consolidate_after_union_negate(&self) -> bool

Source

pub fn enable_reduce_reduction(&self) -> bool

Source

pub fn enable_default_connection_validation(&self) -> bool

Returns the enable_default_connection_validation configuration parameter.

Source

pub fn min_timestamp_interval(&self) -> Duration

Returns the min_timestamp_interval configuration parameter.

Source

pub fn max_timestamp_interval(&self) -> Duration

Returns the max_timestamp_interval configuration parameter.

Source

pub fn logging_filter(&self) -> CloneableEnvFilter

Source

pub fn opentelemetry_filter(&self) -> CloneableEnvFilter

Source

pub fn logging_filter_defaults(&self) -> Vec<SerializableDirective>

Source

pub fn opentelemetry_filter_defaults(&self) -> Vec<SerializableDirective>

Source

pub fn sentry_filters(&self) -> Vec<SerializableDirective>

Source

pub fn webhooks_secrets_caching_ttl_secs(&self) -> usize

Source

pub fn coord_slow_message_warn_threshold(&self) -> Duration

Source

pub fn grpc_client_http2_keep_alive_interval(&self) -> Duration

Source

pub fn grpc_client_http2_keep_alive_timeout(&self) -> Duration

Source

pub fn grpc_connect_timeout(&self) -> Duration

Source

pub fn cluster_multi_process_replica_az_affinity_weight(&self) -> Option<i32>

Source

pub fn cluster_soften_replication_anti_affinity(&self) -> bool

Source

pub fn cluster_soften_replication_anti_affinity_weight(&self) -> i32

Source

pub fn cluster_enable_topology_spread(&self) -> bool

Source

pub fn cluster_topology_spread_ignore_non_singular_scale(&self) -> bool

Source

pub fn cluster_topology_spread_max_skew(&self) -> i32

Source

pub fn cluster_topology_spread_set_min_domains(&self) -> Option<i32>

Source

pub fn cluster_topology_spread_soft(&self) -> bool

Source

pub fn cluster_soften_az_affinity(&self) -> bool

Source

pub fn cluster_soften_az_affinity_weight(&self) -> i32

Source

pub fn cluster_alter_check_ready_interval(&self) -> Duration

Source

pub fn cluster_check_scheduling_policies_interval(&self) -> Duration

Source

pub fn cluster_security_context_enabled(&self) -> bool

Source

pub fn cluster_refresh_mv_compaction_estimate(&self) -> Duration

Returns the privatelink_status_update_quota_per_minute configuration parameter.

Source

pub fn statement_logging_target_data_rate(&self) -> Option<usize>

Source

pub fn statement_logging_max_data_credit(&self) -> Option<usize>

Source

pub fn statement_logging_max_sample_rate(&self) -> Numeric

Returns the statement_logging_max_sample_rate configuration parameter.

Source

pub fn statement_logging_default_sample_rate(&self) -> Numeric

Returns the statement_logging_default_sample_rate configuration parameter.

Source

pub fn enable_internal_statement_logging(&self) -> bool

Returns the enable_internal_statement_logging configuration parameter.

Source

pub fn optimizer_stats_timeout(&self) -> Duration

Returns the optimizer_stats_timeout configuration parameter.

Source

pub fn optimizer_oneshot_stats_timeout(&self) -> Duration

Returns the optimizer_oneshot_stats_timeout configuration parameter.

Source

pub fn webhook_concurrent_request_limit(&self) -> usize

Returns the webhook_concurrent_request_limit configuration parameter.

Source

pub fn pg_timestamp_oracle_connection_pool_max_size(&self) -> usize

Returns the pg_timestamp_oracle_connection_pool_max_size configuration parameter.

Source

pub fn pg_timestamp_oracle_connection_pool_max_wait(&self) -> Option<Duration>

Returns the pg_timestamp_oracle_connection_pool_max_wait configuration parameter.

Source

pub fn pg_timestamp_oracle_connection_pool_ttl(&self) -> Duration

Returns the pg_timestamp_oracle_connection_pool_ttl configuration parameter.

Source

pub fn pg_timestamp_oracle_connection_pool_ttl_stagger(&self) -> Duration

Returns the pg_timestamp_oracle_connection_pool_ttl_stagger configuration parameter.

Source

pub fn user_storage_managed_collections_batch_duration(&self) -> Duration

Returns the user_storage_managed_collections_batch_duration configuration parameter.

Source

pub fn force_source_table_syntax(&self) -> bool

Source

pub fn optimizer_e2e_latency_warning_threshold(&self) -> Duration

Source

pub fn is_controller_config_var(&self, name: &str) -> bool

Returns whether the named variable is a controller configuration parameter.

Source

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).

Source

pub fn is_metrics_config_var(&self, name: &str) -> bool

Returns whether the named variable is a metrics configuration parameter

Source

pub fn is_storage_config_var(&self, name: &str) -> bool

Returns whether the named variable is a storage configuration parameter.

Source

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

Source§

fn clone(&self) -> SystemVars

Returns a duplicate of the value. Read more
1.0.0 · Source§

fn clone_from(&mut self, source: &Self)

Performs copy-assignment from source. Read more
Source§

impl Debug for SystemVars

Source§

fn fmt(&self, __f: &mut Formatter<'_>) -> Result

Formats the value using the given formatter. Read more
Source§

impl Default for SystemVars

Source§

fn default() -> Self

Returns the “default value” for a type. Read more
Source§

impl From<&SystemVars> for Config

Source§

fn from(vars: &SystemVars) -> Self

Converts to this type from the input type.
Source§

impl From<&SystemVars> for OptimizerFeatures

Source§

fn from(vars: &SystemVars) -> Self

Converts to this type from the input type.

Auto Trait Implementations§

Blanket Implementations§

Source§

impl<T> Any for T
where T: 'static + ?Sized,

Source§

fn type_id(&self) -> TypeId

Gets the TypeId of self. Read more
Source§

impl<T> AsAny for T
where T: Any,

Source§

fn as_any(&self) -> &(dyn Any + 'static)

Source§

impl<T> AsAny for T
where T: Any,

Source§

fn as_any(&self) -> &(dyn Any + 'static)

Source§

fn as_any_mut(&mut self) -> &mut (dyn Any + 'static)

Source§

fn type_name(&self) -> &'static str

Gets the type name of self
Source§

impl<T> Borrow<T> for T
where T: ?Sized,

Source§

fn borrow(&self) -> &T

Immutably borrows from an owned value. Read more
Source§

impl<T> BorrowMut<T> for T
where T: ?Sized,

Source§

fn borrow_mut(&mut self) -> &mut T

Mutably borrows from an owned value. Read more
Source§

impl<T, U> CastInto<U> for T
where U: CastFrom<T>,

Source§

fn cast_into(self) -> U

Performs the cast.
Source§

impl<T> CloneToUninit for T
where T: Clone,

Source§

unsafe fn clone_to_uninit(&self, dest: *mut u8)

🔬This is a nightly-only experimental API. (clone_to_uninit)
Performs copy-assignment from self to dest. Read more
Source§

impl<T> Conv for T

Source§

fn conv<T>(self) -> T
where Self: Into<T>,

Converts self into T using Into<T>. Read more
Source§

impl<T> Downcast for T
where T: AsAny + ?Sized,

Source§

fn is<T>(&self) -> bool
where T: AsAny,

Returns true if the boxed type is the same as T. Read more
Source§

fn downcast_ref<T>(&self) -> Option<&T>
where T: AsAny,

Forward to the method defined on the type Any.
Source§

fn downcast_mut<T>(&mut self) -> Option<&mut T>
where T: AsAny,

Forward to the method defined on the type Any.
Source§

impl<T> DynClone for T
where T: Clone,

Source§

impl<T> FmtForward for T

Source§

fn fmt_binary(self) -> FmtBinary<Self>
where Self: Binary,

Causes self to use its Binary implementation when Debug-formatted.
Source§

fn fmt_display(self) -> FmtDisplay<Self>
where Self: Display,

Causes self to use its Display implementation when Debug-formatted.
Source§

fn fmt_lower_exp(self) -> FmtLowerExp<Self>
where Self: LowerExp,

Causes self to use its LowerExp implementation when Debug-formatted.
Source§

fn fmt_lower_hex(self) -> FmtLowerHex<Self>
where Self: LowerHex,

Causes self to use its LowerHex implementation when Debug-formatted.
Source§

fn fmt_octal(self) -> FmtOctal<Self>
where Self: Octal,

Causes self to use its Octal implementation when Debug-formatted.
Source§

fn fmt_pointer(self) -> FmtPointer<Self>
where Self: Pointer,

Causes self to use its Pointer implementation when Debug-formatted.
Source§

fn fmt_upper_exp(self) -> FmtUpperExp<Self>
where Self: UpperExp,

Causes self to use its UpperExp implementation when Debug-formatted.
Source§

fn fmt_upper_hex(self) -> FmtUpperHex<Self>
where Self: UpperHex,

Causes self to use its UpperHex implementation when Debug-formatted.
Source§

fn fmt_list(self) -> FmtList<Self>
where &'a Self: for<'a> IntoIterator,

Formats each item in a sequence. Read more
Source§

impl<T> From<T> for T

Source§

fn from(t: T) -> T

Returns the argument unchanged.

Source§

impl<T> FromRef<T> for T
where T: Clone,

Source§

fn from_ref(input: &T) -> T

Converts to this type from a reference to the input type.
Source§

impl<T> FutureExt for T

Source§

fn with_context(self, otel_cx: Context) -> WithContext<Self>

Attaches the provided Context to this type, returning a WithContext wrapper. Read more
Source§

fn with_current_context(self) -> WithContext<Self>

Attaches the current Context to this type, returning a WithContext wrapper. Read more
Source§

impl<T> Instrument for T

Source§

fn instrument(self, span: Span) -> Instrumented<Self>

Instruments this type with the provided Span, returning an Instrumented wrapper. Read more
Source§

fn in_current_span(self) -> Instrumented<Self>

Instruments this type with the current Span, returning an Instrumented wrapper. Read more
Source§

impl<T, U> Into<U> for T
where U: From<T>,

Source§

fn into(self) -> U

Calls U::from(self).

That is, this conversion is whatever the implementation of From<T> for U chooses to do.

Source§

impl<T> IntoEither for T

Source§

fn into_either(self, into_left: bool) -> Either<Self, Self>

Converts self into a Left variant of Either<Self, Self> if into_left is true. Converts self into a Right variant of Either<Self, Self> otherwise. Read more
Source§

fn into_either_with<F>(self, into_left: F) -> Either<Self, Self>
where F: FnOnce(&Self) -> bool,

Converts self into a Left variant of Either<Self, Self> if into_left(&self) returns true. Converts self into a Right variant of Either<Self, Self> otherwise. Read more
Source§

impl<T> IntoRequest<T> for T

Source§

fn into_request(self) -> Request<T>

Wrap the input message T in a tonic::Request
Source§

impl<Unshared, Shared> IntoShared<Shared> for Unshared
where Shared: FromUnshared<Unshared>,

Source§

fn into_shared(self) -> Shared

Creates a shared type from an unshared type.
Source§

impl<T, U> OverrideFrom<Option<&T>> for U
where U: OverrideFrom<T>,

Source§

fn override_from(self, layer: &Option<&T>) -> U

Override the configuration represented by Self with values from the given layer.
Source§

impl<T> Paint for T
where T: ?Sized,

Source§

fn fg(&self, value: Color) -> Painted<&T>

Returns a styled value derived from self with the foreground set to value.

This method should be used rarely. Instead, prefer to use color-specific builder methods like red() and green(), which have the same functionality but are pithier.

§Example

Set foreground color to white using fg():

use yansi::{Paint, Color};

painted.fg(Color::White);

Set foreground color to white using white().

use yansi::Paint;

painted.white();
Source§

fn primary(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Primary].

§Example
println!("{}", value.primary());
Source§

fn fixed(&self, color: u8) -> Painted<&T>

Returns self with the fg() set to [Color :: Fixed].

§Example
println!("{}", value.fixed(color));
Source§

fn rgb(&self, r: u8, g: u8, b: u8) -> Painted<&T>

Returns self with the fg() set to [Color :: Rgb].

§Example
println!("{}", value.rgb(r, g, b));
Source§

fn black(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Black].

§Example
println!("{}", value.black());
Source§

fn red(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Red].

§Example
println!("{}", value.red());
Source§

fn green(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Green].

§Example
println!("{}", value.green());
Source§

fn yellow(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Yellow].

§Example
println!("{}", value.yellow());
Source§

fn blue(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Blue].

§Example
println!("{}", value.blue());
Source§

fn magenta(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Magenta].

§Example
println!("{}", value.magenta());
Source§

fn cyan(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: Cyan].

§Example
println!("{}", value.cyan());
Source§

fn white(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: White].

§Example
println!("{}", value.white());
Source§

fn bright_black(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightBlack].

§Example
println!("{}", value.bright_black());
Source§

fn bright_red(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightRed].

§Example
println!("{}", value.bright_red());
Source§

fn bright_green(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightGreen].

§Example
println!("{}", value.bright_green());
Source§

fn bright_yellow(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightYellow].

§Example
println!("{}", value.bright_yellow());
Source§

fn bright_blue(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightBlue].

§Example
println!("{}", value.bright_blue());
Source§

fn bright_magenta(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightMagenta].

§Example
println!("{}", value.bright_magenta());
Source§

fn bright_cyan(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightCyan].

§Example
println!("{}", value.bright_cyan());
Source§

fn bright_white(&self) -> Painted<&T>

Returns self with the fg() set to [Color :: BrightWhite].

§Example
println!("{}", value.bright_white());
Source§

fn bg(&self, value: Color) -> Painted<&T>

Returns a styled value derived from self with the background set to value.

This method should be used rarely. Instead, prefer to use color-specific builder methods like on_red() and on_green(), which have the same functionality but are pithier.

§Example

Set background color to red using fg():

use yansi::{Paint, Color};

painted.bg(Color::Red);

Set background color to red using on_red().

use yansi::Paint;

painted.on_red();
Source§

fn on_primary(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Primary].

§Example
println!("{}", value.on_primary());
Source§

fn on_fixed(&self, color: u8) -> Painted<&T>

Returns self with the bg() set to [Color :: Fixed].

§Example
println!("{}", value.on_fixed(color));
Source§

fn on_rgb(&self, r: u8, g: u8, b: u8) -> Painted<&T>

Returns self with the bg() set to [Color :: Rgb].

§Example
println!("{}", value.on_rgb(r, g, b));
Source§

fn on_black(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Black].

§Example
println!("{}", value.on_black());
Source§

fn on_red(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Red].

§Example
println!("{}", value.on_red());
Source§

fn on_green(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Green].

§Example
println!("{}", value.on_green());
Source§

fn on_yellow(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Yellow].

§Example
println!("{}", value.on_yellow());
Source§

fn on_blue(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Blue].

§Example
println!("{}", value.on_blue());
Source§

fn on_magenta(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Magenta].

§Example
println!("{}", value.on_magenta());
Source§

fn on_cyan(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: Cyan].

§Example
println!("{}", value.on_cyan());
Source§

fn on_white(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: White].

§Example
println!("{}", value.on_white());
Source§

fn on_bright_black(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightBlack].

§Example
println!("{}", value.on_bright_black());
Source§

fn on_bright_red(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightRed].

§Example
println!("{}", value.on_bright_red());
Source§

fn on_bright_green(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightGreen].

§Example
println!("{}", value.on_bright_green());
Source§

fn on_bright_yellow(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightYellow].

§Example
println!("{}", value.on_bright_yellow());
Source§

fn on_bright_blue(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightBlue].

§Example
println!("{}", value.on_bright_blue());
Source§

fn on_bright_magenta(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightMagenta].

§Example
println!("{}", value.on_bright_magenta());
Source§

fn on_bright_cyan(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightCyan].

§Example
println!("{}", value.on_bright_cyan());
Source§

fn on_bright_white(&self) -> Painted<&T>

Returns self with the bg() set to [Color :: BrightWhite].

§Example
println!("{}", value.on_bright_white());
Source§

fn attr(&self, value: Attribute) -> Painted<&T>

Enables the styling Attribute value.

This method should be used rarely. Instead, prefer to use attribute-specific builder methods like bold() and underline(), which have the same functionality but are pithier.

§Example

Make text bold using attr():

use yansi::{Paint, Attribute};

painted.attr(Attribute::Bold);

Make text bold using using bold().

use yansi::Paint;

painted.bold();
Source§

fn bold(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Bold].

§Example
println!("{}", value.bold());
Source§

fn dim(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Dim].

§Example
println!("{}", value.dim());
Source§

fn italic(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Italic].

§Example
println!("{}", value.italic());
Source§

fn underline(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Underline].

§Example
println!("{}", value.underline());

Returns self with the attr() set to [Attribute :: Blink].

§Example
println!("{}", value.blink());

Returns self with the attr() set to [Attribute :: RapidBlink].

§Example
println!("{}", value.rapid_blink());
Source§

fn invert(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Invert].

§Example
println!("{}", value.invert());
Source§

fn conceal(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Conceal].

§Example
println!("{}", value.conceal());
Source§

fn strike(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute :: Strike].

§Example
println!("{}", value.strike());
Source§

fn quirk(&self, value: Quirk) -> Painted<&T>

Enables the yansi Quirk value.

This method should be used rarely. Instead, prefer to use quirk-specific builder methods like mask() and wrap(), which have the same functionality but are pithier.

§Example

Enable wrapping using .quirk():

use yansi::{Paint, Quirk};

painted.quirk(Quirk::Wrap);

Enable wrapping using wrap().

use yansi::Paint;

painted.wrap();
Source§

fn mask(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk :: Mask].

§Example
println!("{}", value.mask());
Source§

fn wrap(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk :: Wrap].

§Example
println!("{}", value.wrap());
Source§

fn linger(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk :: Linger].

§Example
println!("{}", value.linger());
Source§

fn clear(&self) -> Painted<&T>

👎Deprecated since 1.0.1: renamed to resetting() due to conflicts with Vec::clear(). The clear() method will be removed in a future release.

Returns self with the quirk() set to [Quirk :: Clear].

§Example
println!("{}", value.clear());
Source§

fn resetting(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk :: Resetting].

§Example
println!("{}", value.resetting());
Source§

fn bright(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk :: Bright].

§Example
println!("{}", value.bright());
Source§

fn on_bright(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk :: OnBright].

§Example
println!("{}", value.on_bright());
Source§

fn whenever(&self, value: Condition) -> Painted<&T>

Conditionally enable styling based on whether the Condition value applies. Replaces any previous condition.

See the crate level docs for more details.

§Example

Enable styling painted only when both stdout and stderr are TTYs:

use yansi::{Paint, Condition};

painted.red().on_yellow().whenever(Condition::STDOUTERR_ARE_TTY);
Source§

fn new(self) -> Painted<Self>
where Self: Sized,

Create a new Painted with a default Style. Read more
Source§

fn paint<S>(&self, style: S) -> Painted<&Self>
where S: Into<Style>,

Apply a style wholesale to self. Any previous style is replaced. Read more
Source§

impl<T> Pipe for T
where T: ?Sized,

Source§

fn pipe<R>(self, func: impl FnOnce(Self) -> R) -> R
where Self: Sized,

Pipes by value. This is generally the method you want to use. Read more
Source§

fn pipe_ref<'a, R>(&'a self, func: impl FnOnce(&'a Self) -> R) -> R
where R: 'a,

Borrows self and passes that borrow into the pipe function. Read more
Source§

fn pipe_ref_mut<'a, R>(&'a mut self, func: impl FnOnce(&'a mut Self) -> R) -> R
where R: 'a,

Mutably borrows self and passes that borrow into the pipe function. Read more
Source§

fn pipe_borrow<'a, B, R>(&'a self, func: impl FnOnce(&'a B) -> R) -> R
where Self: Borrow<B>, B: 'a + ?Sized, R: 'a,

Borrows self, then passes self.borrow() into the pipe function. Read more
Source§

fn pipe_borrow_mut<'a, B, R>( &'a mut self, func: impl FnOnce(&'a mut B) -> R, ) -> R
where Self: BorrowMut<B>, B: 'a + ?Sized, R: 'a,

Mutably borrows self, then passes self.borrow_mut() into the pipe function. Read more
Source§

fn pipe_as_ref<'a, U, R>(&'a self, func: impl FnOnce(&'a U) -> R) -> R
where Self: AsRef<U>, U: 'a + ?Sized, R: 'a,

Borrows 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
where Self: AsMut<U>, U: 'a + ?Sized, R: 'a,

Mutably borrows 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
where Self: Deref<Target = T>, T: 'a + ?Sized, R: 'a,

Borrows self, then passes self.deref() into the pipe function.
Source§

fn pipe_deref_mut<'a, T, R>( &'a mut self, func: impl FnOnce(&'a mut T) -> R, ) -> R
where Self: DerefMut<Target = T> + Deref, T: 'a + ?Sized, R: 'a,

Mutably borrows self, then passes self.deref_mut() into the pipe function.
Source§

impl<T> Pointable for T

Source§

const ALIGN: usize

The alignment of pointer.
Source§

type Init = T

The type for initializers.
Source§

unsafe fn init(init: <T as Pointable>::Init) -> usize

Initializes a with the given initializer. Read more
Source§

unsafe fn deref<'a>(ptr: usize) -> &'a T

Dereferences the given pointer. Read more
Source§

unsafe fn deref_mut<'a>(ptr: usize) -> &'a mut T

Mutably dereferences the given pointer. Read more
Source§

unsafe fn drop(ptr: usize)

Drops the object pointed to by the given pointer. Read more
Source§

impl<T> PolicyExt for T
where T: ?Sized,

Source§

fn and<P, B, E>(self, other: P) -> And<T, P>
where T: Policy<B, E>, P: Policy<B, E>,

Create a new Policy that returns Action::Follow only if self and other return Action::Follow. Read more
Source§

fn or<P, B, E>(self, other: P) -> Or<T, P>
where T: Policy<B, E>, P: Policy<B, E>,

Create a new Policy that returns Action::Follow if either self or other returns Action::Follow. Read more
Source§

impl<P, R> ProtoType<R> for P
where R: RustType<P>,

Source§

impl<T> Same for T

Source§

type Output = T

Should always be Self
Source§

impl<'a, S, T> Semigroup<&'a S> for T
where T: Semigroup<S>,

Source§

fn plus_equals(&mut self, rhs: &&'a S)

The method of std::ops::AddAssign, for types that do not implement AddAssign.
Source§

impl<T> ServiceExt for T

Source§

fn map_response_body<F>(self, f: F) -> MapResponseBody<Self, F>
where Self: Sized,

Apply a transformation to the response body. Read more
Source§

fn decompression(self) -> Decompression<Self>
where Self: Sized,

Decompress response bodies. Read more
Source§

fn trace_for_http(self) -> Trace<Self, SharedClassifier<ServerErrorsAsFailures>>
where Self: Sized,

High level tracing that classifies responses using HTTP status codes. Read more
Source§

fn trace_for_grpc(self) -> Trace<Self, SharedClassifier<GrpcErrorsAsFailures>>
where Self: Sized,

High level tracing that classifies responses using gRPC headers. Read more
Source§

fn follow_redirects(self) -> FollowRedirect<Self>
where Self: Sized,

Follow redirect resposes using the Standard policy. Read more
Source§

impl<T> Tap for T

Source§

fn tap(self, func: impl FnOnce(&Self)) -> Self

Immutable access to a value. Read more
Source§

fn tap_mut(self, func: impl FnOnce(&mut Self)) -> Self

Mutable access to a value. Read more
Source§

fn tap_borrow<B>(self, func: impl FnOnce(&B)) -> Self
where Self: Borrow<B>, B: ?Sized,

Immutable access to the Borrow<B> of a value. Read more
Source§

fn tap_borrow_mut<B>(self, func: impl FnOnce(&mut B)) -> Self
where Self: BorrowMut<B>, B: ?Sized,

Mutable access to the BorrowMut<B> of a value. Read more
Source§

fn tap_ref<R>(self, func: impl FnOnce(&R)) -> Self
where Self: AsRef<R>, R: ?Sized,

Immutable access to the AsRef<R> view of a value. Read more
Source§

fn tap_ref_mut<R>(self, func: impl FnOnce(&mut R)) -> Self
where Self: AsMut<R>, R: ?Sized,

Mutable access to the AsMut<R> view of a value. Read more
Source§

fn tap_deref<T>(self, func: impl FnOnce(&T)) -> Self
where Self: Deref<Target = T>, T: ?Sized,

Immutable access to the Deref::Target of a value. Read more
Source§

fn tap_deref_mut<T>(self, func: impl FnOnce(&mut T)) -> Self
where Self: DerefMut<Target = T> + Deref, T: ?Sized,

Mutable access to the Deref::Target of a value. Read more
Source§

fn tap_dbg(self, func: impl FnOnce(&Self)) -> Self

Calls .tap() only in debug builds, and is erased in release builds.
Source§

fn tap_mut_dbg(self, func: impl FnOnce(&mut Self)) -> Self

Calls .tap_mut() only in debug builds, and is erased in release builds.
Source§

fn tap_borrow_dbg<B>(self, func: impl FnOnce(&B)) -> Self
where Self: Borrow<B>, B: ?Sized,

Calls .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
where Self: BorrowMut<B>, B: ?Sized,

Calls .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
where Self: AsRef<R>, R: ?Sized,

Calls .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
where Self: AsMut<R>, R: ?Sized,

Calls .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
where Self: Deref<Target = T>, T: ?Sized,

Calls .tap_deref() only in debug builds, and is erased in release builds.
Source§

fn tap_deref_mut_dbg<T>(self, func: impl FnOnce(&mut T)) -> Self
where Self: DerefMut<Target = T> + Deref, T: ?Sized,

Calls .tap_deref_mut() only in debug builds, and is erased in release builds.
Source§

impl<T> ToOwned for T
where T: Clone,

Source§

type Owned = T

The resulting type after obtaining ownership.
Source§

fn to_owned(&self) -> T

Creates owned data from borrowed data, usually by cloning. Read more
Source§

fn clone_into(&self, target: &mut T)

Uses borrowed data to replace owned data, usually by cloning. Read more
Source§

impl<T> TryConv for T

Source§

fn try_conv<T>(self) -> Result<T, Self::Error>
where Self: TryInto<T>,

Attempts to convert self into T using TryInto<T>. Read more
Source§

impl<T, U> TryFrom<U> for T
where U: Into<T>,

Source§

type Error = Infallible

The type returned in the event of a conversion error.
Source§

fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>

Performs the conversion.
Source§

impl<T, U> TryInto<U> for T
where U: TryFrom<T>,

Source§

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.
Source§

fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>

Performs the conversion.
Source§

impl<V, T> VZip<V> for T
where V: MultiLane<T>,

Source§

fn vzip(self) -> V

Source§

impl<T> WithSubscriber for T

Source§

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self>
where S: Into<Dispatch>,

Attaches the provided Subscriber to this type, returning a WithDispatch wrapper. Read more
Source§

fn with_current_subscriber(self) -> WithDispatch<Self>

Attaches the current default Subscriber to this type, returning a WithDispatch wrapper. Read more
Source§

impl<T> Data for T
where T: Clone + 'static,

Source§

impl<T> MaybeSend for T
where T: Send,