Struct mz_sql::session::vars::SystemVars

source ·
pub struct SystemVars { /* private fields */ }
Expand description

On disk variables.

See the crate::session::vars module documentation for more details on the Materialize configuration model.

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_binary_date_bin(&self) -> bool

source

pub fn enable_create_sink_denylist_with_options(&self) -> bool

source

pub fn enable_create_source_denylist_with_options(&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_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 enable_table_check_constraint(&self) -> bool

source

pub fn enable_table_foreign_key(&self) -> bool

source

pub fn enable_table_keys(&self) -> bool

source

pub fn enable_unorchestrated_cluster_replicas(&self) -> bool

source

pub fn enable_unstable_dependencies(&self) -> bool

source

pub fn enable_disk_cluster_replicas(&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 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_comment(&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_aws_connection(&self) -> bool

source

pub fn enable_mysql_source(&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 wait_catalog_consolidation_on_startup(&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§

impl SystemVars

source

pub fn new(active_connection_count: Arc<Mutex<ConnectionCounter>>) -> 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

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

Like with SystemVars::get, configuration parameters are matched case insensitively. If value 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 value).

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

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_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 disk_cluster_replicas_default(&self) -> bool

Returns the disk_cluster_replicas_default configuration parameter.

source

pub fn upsert_rocksdb_auto_spill_to_disk(&self) -> bool

source

pub fn upsert_rocksdb_auto_spill_threshold_bytes(&self) -> usize

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 persist_txn_tables(&self) -> PersistTxnTablesImpl

source

pub fn pg_source_connect_timeout(&self) -> Duration

Returns the pg_source_connect_timeout configuration parameter.

source

pub fn pg_source_keepalives_retries(&self) -> u32

Returns the pg_source_keepalives_retries configuration parameter.

source

pub fn pg_source_keepalives_idle(&self) -> Duration

Returns the pg_source_keepalives_idle configuration parameter.

source

pub fn pg_source_keepalives_interval(&self) -> Duration

Returns the pg_source_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_snapshot_statement_timeout(&self) -> Duration

Returns the pg_source_snapshot_statement_timeout configuration parameter.

source

pub fn pg_source_wal_sender_timeout(&self) -> 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 pg_source_snapshot_fallback_to_strict_count(&self) -> bool

Returns the pg_source_snapshot_fallback_to_strict_count configuration parameter.

source

pub fn pg_source_snapshot_wait_for_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 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) -> 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) -> Duration

Returns the kafka_progress_record_fetch_timeout configuration parameter.

source

pub fn kafka_default_metadata_fetch_interval(&self) -> Duration

Returns the kafka_default_metadata_fetch_interval 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 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 arrangement_exert_proportionality(&self) -> u32

Returns the arrangement_exert_proportionality configuration parameter.

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_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_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_always_use_disk(&self) -> bool

source

pub fn cluster_check_scheduling_policies_interval(&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 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 enable_dependency_read_hold_asserts(&self) -> bool

source

pub fn user_storage_managed_collections_batch_duration(&self) -> Duration

Returns the user_storage_managed_collections_batch_duration 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_storage_config_var(&self, name: &str) -> bool

Returns whether the named variable is a storage configuration parameter.

Trait Implementations§

source§

impl Clone for SystemVars

source§

fn clone(&self) -> SystemVars

Returns a copy 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> 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> Conv for T

source§

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

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

impl<R, O, T> CopyOnto<ConsecutiveOffsetPairs<R, O>> for T
where R: Region<Index = (usize, usize)>, O: OffsetContainer<usize>, T: CopyOnto<R>,

source§

fn copy_onto( self, target: &mut ConsecutiveOffsetPairs<R, O> ) -> <ConsecutiveOffsetPairs<R, O> as Region>::Index

Copy self into the target container, returning an index that allows to look up the corresponding read item.
source§

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

source§

fn __clone_box(&self, _: Private) -> *mut ()

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

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> ProgressEventTimestamp for T
where T: Data + Debug + Any,

source§

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

Upcasts this ProgressEventTimestamp to Any. Read more
source§

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

Returns the name of the concrete type of this object. Read more
source§

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

source§

impl<R, T> PushInto<FlatStack<R>> for T
where R: Region + Clone + 'static, T: CopyOnto<R>,

source§

fn push_into(self, target: &mut FlatStack<R>)

Push self into the target container.
source§

impl<T> PushInto<Vec<T>> for T

source§

fn push_into(self, target: &mut Vec<T>)

Push self into the target container.
source§

impl<T> Same for T

§

type Output = T

Should always be Self
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,

§

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>,

§

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>,

§

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,