pub struct NameResolver<'a> {
    catalog: &'a dyn SessionCatalog,
    ctes: BTreeMap<String, LocalId>,
    continual_task: Option<(PartialItemName, LocalId)>,
    status: Result<(), PlanError>,
    ids: BTreeMap<CatalogItemId, BTreeSet<GlobalId>>,
}Fields§
§catalog: &'a dyn SessionCatalog§ctes: BTreeMap<String, LocalId>§continual_task: Option<(PartialItemName, LocalId)>§status: Result<(), PlanError>§ids: BTreeMap<CatalogItemId, BTreeSet<GlobalId>>Implementations§
Source§impl<'a> NameResolver<'a>
 
impl<'a> NameResolver<'a>
fn new(catalog: &'a dyn SessionCatalog) -> NameResolver<'a>
fn resolve_data_type( &mut self, data_type: RawDataType, ) -> Result<ResolvedDataType, PlanError>
fn resolve_item_name( &mut self, item_name: RawItemName, config: ItemResolutionConfig, ) -> ResolvedItemName
fn resolve_item_name_name( &mut self, raw_name: UnresolvedItemName, config: ItemResolutionConfig, ) -> ResolvedItemName
fn resolve_item_name_id( &mut self, id: String, raw_name: UnresolvedItemName, version: Option<Version>, ) -> ResolvedItemName
Trait Implementations§
Source§impl<'a> Debug for NameResolver<'a>
 
impl<'a> Debug for NameResolver<'a>
Source§impl<'a> Fold<Raw, Aug> for NameResolver<'a>
 
impl<'a> Fold<Raw, Aug> for NameResolver<'a>
fn fold_nested_statement( &mut self, stmt: <Raw as AstInfo>::NestedStatement, ) -> <Aug as AstInfo>::NestedStatement
fn fold_query(&mut self, q: Query<Raw>) -> Query<Aug>
fn fold_create_continual_task_statement( &mut self, stmt: CreateContinualTaskStatement<Raw>, ) -> CreateContinualTaskStatement<Aug>
fn fold_cte_id( &mut self, _id: <Raw as AstInfo>::CteId, ) -> <Aug as AstInfo>::CteId
fn fold_item_name( &mut self, item_name: <Raw as AstInfo>::ItemName, ) -> <Aug as AstInfo>::ItemName
fn fold_column_name(&mut self, column_name: ColumnName<Raw>) -> ColumnName<Aug>
fn fold_column_reference( &mut self, _node: <Raw as AstInfo>::ColumnReference, ) -> <Aug as AstInfo>::ColumnReference
fn fold_data_type( &mut self, data_type: <Raw as AstInfo>::DataType, ) -> <Aug as AstInfo>::DataType
fn fold_schema_name( &mut self, name: <Raw as AstInfo>::SchemaName, ) -> <Aug as AstInfo>::SchemaName
fn fold_database_name( &mut self, database_name: <Raw as AstInfo>::DatabaseName, ) -> <Aug as AstInfo>::DatabaseName
fn fold_cluster_name( &mut self, cluster_name: <Raw as AstInfo>::ClusterName, ) -> <Aug as AstInfo>::ClusterName
fn fold_with_option_value( &mut self, node: WithOptionValue<Raw>, ) -> WithOptionValue<Aug>
fn fold_role_name( &mut self, name: <Raw as AstInfo>::RoleName, ) -> <Aug as AstInfo>::RoleName
fn fold_network_policy_name( &mut self, name: <Raw as AstInfo>::NetworkPolicyName, ) -> <Aug as AstInfo>::NetworkPolicyName
fn fold_object_name( &mut self, name: <Raw as AstInfo>::ObjectName, ) -> <Aug as AstInfo>::ObjectName
fn fold_function(&mut self, node: Function<Raw>) -> Function<Aug>
fn fold_table_factor(&mut self, node: TableFactor<Raw>) -> TableFactor<Aug>
fn fold_grant_target_specification( &mut self, node: GrantTargetSpecification<Raw>, ) -> GrantTargetSpecification<Aug>
fn fold_doc_on_identifier( &mut self, node: DocOnIdentifier<Raw>, ) -> DocOnIdentifier<Aug>
fn fold_expr(&mut self, node: Expr<Raw>) -> Expr<Aug>
fn fold_abbreviated_grant_or_revoke_statement( &mut self, node: AbbreviatedGrantOrRevokeStatement<T>, ) -> AbbreviatedGrantOrRevokeStatement<T2>
fn fold_abbreviated_grant_statement( &mut self, node: AbbreviatedGrantStatement<T>, ) -> AbbreviatedGrantStatement<T2>
fn fold_abbreviated_revoke_statement( &mut self, node: AbbreviatedRevokeStatement<T>, ) -> AbbreviatedRevokeStatement<T2>
fn fold_alter_cluster_action( &mut self, node: AlterClusterAction<T>, ) -> AlterClusterAction<T2>
fn fold_alter_cluster_statement( &mut self, node: AlterClusterStatement<T>, ) -> AlterClusterStatement<T2>
fn fold_alter_connection_action( &mut self, node: AlterConnectionAction<T>, ) -> AlterConnectionAction<T2>
fn fold_alter_connection_option( &mut self, node: AlterConnectionOption<T>, ) -> AlterConnectionOption<T2>
fn fold_alter_connection_option_name( &mut self, node: AlterConnectionOptionName, ) -> AlterConnectionOptionName
fn fold_alter_connection_statement( &mut self, node: AlterConnectionStatement<T>, ) -> AlterConnectionStatement<T2>
fn fold_alter_default_privileges_statement( &mut self, node: AlterDefaultPrivilegesStatement<T>, ) -> AlterDefaultPrivilegesStatement<T2>
fn fold_alter_index_action( &mut self, node: AlterIndexAction<T>, ) -> AlterIndexAction<T2>
fn fold_alter_index_statement( &mut self, node: AlterIndexStatement<T>, ) -> AlterIndexStatement<T2>
fn fold_alter_network_policy_statement( &mut self, node: AlterNetworkPolicyStatement<T>, ) -> AlterNetworkPolicyStatement<T2>
fn fold_alter_object_rename_statement( &mut self, node: AlterObjectRenameStatement, ) -> AlterObjectRenameStatement
fn fold_alter_object_swap_statement( &mut self, node: AlterObjectSwapStatement, ) -> AlterObjectSwapStatement
fn fold_alter_owner_statement( &mut self, node: AlterOwnerStatement<T>, ) -> AlterOwnerStatement<T2>
fn fold_alter_retain_history_statement( &mut self, node: AlterRetainHistoryStatement<T>, ) -> AlterRetainHistoryStatement<T2>
fn fold_alter_role_option(&mut self, node: AlterRoleOption) -> AlterRoleOption
fn fold_alter_role_statement( &mut self, node: AlterRoleStatement<T>, ) -> AlterRoleStatement<T2>
fn fold_alter_secret_statement( &mut self, node: AlterSecretStatement<T>, ) -> AlterSecretStatement<T2>
fn fold_alter_set_cluster_statement( &mut self, node: AlterSetClusterStatement<T>, ) -> AlterSetClusterStatement<T2>
fn fold_alter_sink_action( &mut self, node: AlterSinkAction<T>, ) -> AlterSinkAction<T2>
fn fold_alter_sink_statement( &mut self, node: AlterSinkStatement<T>, ) -> AlterSinkStatement<T2>
fn fold_alter_source_action( &mut self, node: AlterSourceAction<T>, ) -> AlterSourceAction<T2>
fn fold_alter_source_add_subsource_option( &mut self, node: AlterSourceAddSubsourceOption<T>, ) -> AlterSourceAddSubsourceOption<T2>
fn fold_alter_source_add_subsource_option_name( &mut self, node: AlterSourceAddSubsourceOptionName, ) -> AlterSourceAddSubsourceOptionName
fn fold_alter_source_statement( &mut self, node: AlterSourceStatement<T>, ) -> AlterSourceStatement<T2>
fn fold_alter_system_reset_all_statement( &mut self, node: AlterSystemResetAllStatement, ) -> AlterSystemResetAllStatement
fn fold_alter_system_reset_statement( &mut self, node: AlterSystemResetStatement, ) -> AlterSystemResetStatement
fn fold_alter_system_set_statement( &mut self, node: AlterSystemSetStatement, ) -> AlterSystemSetStatement
fn fold_alter_table_add_column_statement( &mut self, node: AlterTableAddColumnStatement<T>, ) -> AlterTableAddColumnStatement<T2>
fn fold_as_of(&mut self, node: AsOf<T>) -> AsOf<T2>
fn fold_assignment(&mut self, node: Assignment<T>) -> Assignment<T2>
fn fold_avro_doc_on(&mut self, node: AvroDocOn<T>) -> AvroDocOn<T2>
fn fold_avro_schema(&mut self, node: AvroSchema<T>) -> AvroSchema<T2>
fn fold_avro_schema_option( &mut self, node: AvroSchemaOption<T>, ) -> AvroSchemaOption<T2>
fn fold_avro_schema_option_name( &mut self, node: AvroSchemaOptionName, ) -> AvroSchemaOptionName
fn fold_catalog_name(&mut self, node: CatalogName) -> CatalogName
fn fold_close_statement(&mut self, node: CloseStatement) -> CloseStatement
fn fold_cluster_alter_option( &mut self, node: ClusterAlterOption<T>, ) -> ClusterAlterOption<T2>
fn fold_cluster_alter_option_name( &mut self, node: ClusterAlterOptionName, ) -> ClusterAlterOptionName
fn fold_cluster_alter_option_value( &mut self, node: ClusterAlterOptionValue<T>, ) -> ClusterAlterOptionValue<T2>
fn fold_cluster_alter_until_ready_option( &mut self, node: ClusterAlterUntilReadyOption<T>, ) -> ClusterAlterUntilReadyOption<T2>
fn fold_cluster_alter_until_ready_option_name( &mut self, node: ClusterAlterUntilReadyOptionName, ) -> ClusterAlterUntilReadyOptionName
fn fold_cluster_feature( &mut self, node: ClusterFeature<T>, ) -> ClusterFeature<T2>
fn fold_cluster_feature_name( &mut self, node: ClusterFeatureName, ) -> ClusterFeatureName
fn fold_cluster_option(&mut self, node: ClusterOption<T>) -> ClusterOption<T2>
fn fold_cluster_option_name( &mut self, node: ClusterOptionName, ) -> ClusterOptionName
fn fold_cluster_schedule_option_value( &mut self, node: ClusterScheduleOptionValue, ) -> ClusterScheduleOptionValue
fn fold_column_def(&mut self, node: ColumnDef<T>) -> ColumnDef<T2>
fn fold_column_option(&mut self, node: ColumnOption<T>) -> ColumnOption<T2>
fn fold_column_option_def( &mut self, node: ColumnOptionDef<T>, ) -> ColumnOptionDef<T2>
fn fold_column_versioned(&mut self, node: ColumnVersioned) -> ColumnVersioned
fn fold_comment_object_type( &mut self, node: CommentObjectType<T>, ) -> CommentObjectType<T2>
fn fold_comment_statement( &mut self, node: CommentStatement<T>, ) -> CommentStatement<T2>
fn fold_commit_statement(&mut self, node: CommitStatement) -> CommitStatement
fn fold_connection_default_aws_privatelink( &mut self, node: ConnectionDefaultAwsPrivatelink<T>, ) -> ConnectionDefaultAwsPrivatelink<T2>
fn fold_connection_option( &mut self, node: ConnectionOption<T>, ) -> ConnectionOption<T2>
fn fold_connection_option_name( &mut self, node: ConnectionOptionName, ) -> ConnectionOptionName
fn fold_continual_task_option( &mut self, node: ContinualTaskOption<T>, ) -> ContinualTaskOption<T2>
fn fold_continual_task_option_name( &mut self, node: ContinualTaskOptionName, ) -> ContinualTaskOptionName
fn fold_continual_task_stmt( &mut self, node: ContinualTaskStmt<T>, ) -> ContinualTaskStmt<T2>
fn fold_copy_direction(&mut self, node: CopyDirection) -> CopyDirection
fn fold_copy_option(&mut self, node: CopyOption<T>) -> CopyOption<T2>
fn fold_copy_option_name(&mut self, node: CopyOptionName) -> CopyOptionName
fn fold_copy_relation(&mut self, node: CopyRelation<T>) -> CopyRelation<T2>
fn fold_copy_statement(&mut self, node: CopyStatement<T>) -> CopyStatement<T2>
fn fold_copy_target(&mut self, node: CopyTarget<T>) -> CopyTarget<T2>
fn fold_create_cluster_replica_statement( &mut self, node: CreateClusterReplicaStatement<T>, ) -> CreateClusterReplicaStatement<T2>
fn fold_create_cluster_statement( &mut self, node: CreateClusterStatement<T>, ) -> CreateClusterStatement<T2>
fn fold_create_connection_option( &mut self, node: CreateConnectionOption<T>, ) -> CreateConnectionOption<T2>
fn fold_create_connection_option_name( &mut self, node: CreateConnectionOptionName, ) -> CreateConnectionOptionName
fn fold_create_connection_statement( &mut self, node: CreateConnectionStatement<T>, ) -> CreateConnectionStatement<T2>
fn fold_create_connection_type( &mut self, node: CreateConnectionType, ) -> CreateConnectionType
fn fold_create_continual_task_sugar( &mut self, node: CreateContinualTaskSugar<T>, ) -> CreateContinualTaskSugar<T2>
fn fold_create_database_statement( &mut self, node: CreateDatabaseStatement, ) -> CreateDatabaseStatement
fn fold_create_index_statement( &mut self, node: CreateIndexStatement<T>, ) -> CreateIndexStatement<T2>
fn fold_create_materialized_view_statement( &mut self, node: CreateMaterializedViewStatement<T>, ) -> CreateMaterializedViewStatement<T2>
fn fold_create_network_policy_statement( &mut self, node: CreateNetworkPolicyStatement<T>, ) -> CreateNetworkPolicyStatement<T2>
fn fold_create_role_statement( &mut self, node: CreateRoleStatement, ) -> CreateRoleStatement
fn fold_create_schema_statement( &mut self, node: CreateSchemaStatement, ) -> CreateSchemaStatement
fn fold_create_secret_statement( &mut self, node: CreateSecretStatement<T>, ) -> CreateSecretStatement<T2>
fn fold_create_sink_connection( &mut self, node: CreateSinkConnection<T>, ) -> CreateSinkConnection<T2>
fn fold_create_sink_option( &mut self, node: CreateSinkOption<T>, ) -> CreateSinkOption<T2>
fn fold_create_sink_option_name( &mut self, node: CreateSinkOptionName, ) -> CreateSinkOptionName
fn fold_create_sink_statement( &mut self, node: CreateSinkStatement<T>, ) -> CreateSinkStatement<T2>
fn fold_create_source_connection( &mut self, node: CreateSourceConnection<T>, ) -> CreateSourceConnection<T2>
fn fold_create_source_option( &mut self, node: CreateSourceOption<T>, ) -> CreateSourceOption<T2>
fn fold_create_source_option_name( &mut self, node: CreateSourceOptionName, ) -> CreateSourceOptionName
fn fold_create_source_statement( &mut self, node: CreateSourceStatement<T>, ) -> CreateSourceStatement<T2>
fn fold_create_subsource_option( &mut self, node: CreateSubsourceOption<T>, ) -> CreateSubsourceOption<T2>
fn fold_create_subsource_option_name( &mut self, node: CreateSubsourceOptionName, ) -> CreateSubsourceOptionName
fn fold_create_subsource_statement( &mut self, node: CreateSubsourceStatement<T>, ) -> CreateSubsourceStatement<T2>
fn fold_create_table_from_source_statement( &mut self, node: CreateTableFromSourceStatement<T>, ) -> CreateTableFromSourceStatement<T2>
fn fold_create_table_statement( &mut self, node: CreateTableStatement<T>, ) -> CreateTableStatement<T2>
fn fold_create_type_as(&mut self, node: CreateTypeAs<T>) -> CreateTypeAs<T2>
fn fold_create_type_list_option( &mut self, node: CreateTypeListOption<T>, ) -> CreateTypeListOption<T2>
fn fold_create_type_list_option_name( &mut self, node: CreateTypeListOptionName, ) -> CreateTypeListOptionName
fn fold_create_type_map_option( &mut self, node: CreateTypeMapOption<T>, ) -> CreateTypeMapOption<T2>
fn fold_create_type_map_option_name( &mut self, node: CreateTypeMapOptionName, ) -> CreateTypeMapOptionName
fn fold_create_type_statement( &mut self, node: CreateTypeStatement<T>, ) -> CreateTypeStatement<T2>
fn fold_create_view_statement( &mut self, node: CreateViewStatement<T>, ) -> CreateViewStatement<T2>
fn fold_create_webhook_source_body( &mut self, node: CreateWebhookSourceBody, ) -> CreateWebhookSourceBody
fn fold_create_webhook_source_check( &mut self, node: CreateWebhookSourceCheck<T>, ) -> CreateWebhookSourceCheck<T2>
fn fold_create_webhook_source_check_options( &mut self, node: CreateWebhookSourceCheckOptions<T>, ) -> CreateWebhookSourceCheckOptions<T2>
fn fold_create_webhook_source_filter_header( &mut self, node: CreateWebhookSourceFilterHeader, ) -> CreateWebhookSourceFilterHeader
fn fold_create_webhook_source_header( &mut self, node: CreateWebhookSourceHeader, ) -> CreateWebhookSourceHeader
fn fold_create_webhook_source_include_headers( &mut self, node: CreateWebhookSourceIncludeHeaders, ) -> CreateWebhookSourceIncludeHeaders
fn fold_create_webhook_source_map_header( &mut self, node: CreateWebhookSourceMapHeader, ) -> CreateWebhookSourceMapHeader
fn fold_create_webhook_source_secret( &mut self, node: CreateWebhookSourceSecret<T>, ) -> CreateWebhookSourceSecret<T2>
fn fold_create_webhook_source_statement( &mut self, node: CreateWebhookSourceStatement<T>, ) -> CreateWebhookSourceStatement<T2>
fn fold_csr_config_option( &mut self, node: CsrConfigOption<T>, ) -> CsrConfigOption<T2>
fn fold_csr_config_option_name( &mut self, node: CsrConfigOptionName<T>, ) -> CsrConfigOptionName<T2>
fn fold_csr_connection(&mut self, node: CsrConnection<T>) -> CsrConnection<T2>
fn fold_csr_connection_avro( &mut self, node: CsrConnectionAvro<T>, ) -> CsrConnectionAvro<T2>
fn fold_csr_connection_protobuf( &mut self, node: CsrConnectionProtobuf<T>, ) -> CsrConnectionProtobuf<T2>
fn fold_csr_seed_avro(&mut self, node: CsrSeedAvro) -> CsrSeedAvro
fn fold_csr_seed_protobuf(&mut self, node: CsrSeedProtobuf) -> CsrSeedProtobuf
fn fold_csr_seed_protobuf_schema( &mut self, node: CsrSeedProtobufSchema, ) -> CsrSeedProtobufSchema
fn fold_csv_columns(&mut self, node: CsvColumns) -> CsvColumns
fn fold_cte(&mut self, node: Cte<T>) -> Cte<T2>
fn fold_cte_block(&mut self, node: CteBlock<T>) -> CteBlock<T2>
fn fold_cte_mut_rec(&mut self, node: CteMutRec<T>) -> CteMutRec<T2>
fn fold_cte_mut_rec_column_def( &mut self, node: CteMutRecColumnDef<T>, ) -> CteMutRecColumnDef<T2>
fn fold_date_time_field(&mut self, node: DateTimeField) -> DateTimeField
fn fold_deallocate_statement( &mut self, node: DeallocateStatement, ) -> DeallocateStatement
fn fold_declare_statement( &mut self, node: DeclareStatement<T>, ) -> DeclareStatement<T2>
fn fold_deferred_item_name( &mut self, node: DeferredItemName<T>, ) -> DeferredItemName<T2>
fn fold_delete_statement( &mut self, node: DeleteStatement<T>, ) -> DeleteStatement<T2>
fn fold_discard_statement(&mut self, node: DiscardStatement) -> DiscardStatement
fn fold_discard_target(&mut self, node: DiscardTarget) -> DiscardTarget
fn fold_distinct(&mut self, node: Distinct<T>) -> Distinct<T2>
fn fold_doc_on_schema(&mut self, node: DocOnSchema) -> DocOnSchema
fn fold_drop_objects_statement( &mut self, node: DropObjectsStatement, ) -> DropObjectsStatement
fn fold_drop_owned_statement( &mut self, node: DropOwnedStatement<T>, ) -> DropOwnedStatement<T2>
fn fold_execute_statement( &mut self, node: ExecuteStatement<T>, ) -> ExecuteStatement<T2>
fn fold_explain_analyze_computation_property( &mut self, node: ExplainAnalyzeComputationProperty, ) -> ExplainAnalyzeComputationProperty
fn fold_explain_analyze_property( &mut self, node: ExplainAnalyzeProperty, ) -> ExplainAnalyzeProperty
fn fold_explain_analyze_statement( &mut self, node: ExplainAnalyzeStatement<T>, ) -> ExplainAnalyzeStatement<T2>
fn fold_explain_format(&mut self, node: ExplainFormat) -> ExplainFormat
fn fold_explain_plan_option( &mut self, node: ExplainPlanOption<T>, ) -> ExplainPlanOption<T2>
fn fold_explain_plan_option_name( &mut self, node: ExplainPlanOptionName, ) -> ExplainPlanOptionName
fn fold_explain_plan_statement( &mut self, node: ExplainPlanStatement<T>, ) -> ExplainPlanStatement<T2>
fn fold_explain_pushdown_statement( &mut self, node: ExplainPushdownStatement<T>, ) -> ExplainPushdownStatement<T2>
fn fold_explain_sink_schema_for( &mut self, node: ExplainSinkSchemaFor, ) -> ExplainSinkSchemaFor
fn fold_explain_sink_schema_statement( &mut self, node: ExplainSinkSchemaStatement<T>, ) -> ExplainSinkSchemaStatement<T2>
fn fold_explain_stage(&mut self, node: ExplainStage) -> ExplainStage
fn fold_explain_timestamp_statement( &mut self, node: ExplainTimestampStatement<T>, ) -> ExplainTimestampStatement<T2>
fn fold_explainee(&mut self, node: Explainee<T>) -> Explainee<T2>
fn fold_external_reference_export( &mut self, node: ExternalReferenceExport, ) -> ExternalReferenceExport
fn fold_external_references( &mut self, node: ExternalReferences, ) -> ExternalReferences
fn fold_fetch_direction(&mut self, node: FetchDirection) -> FetchDirection
fn fold_fetch_option(&mut self, node: FetchOption<T>) -> FetchOption<T2>
fn fold_fetch_option_name(&mut self, node: FetchOptionName) -> FetchOptionName
fn fold_fetch_statement( &mut self, node: FetchStatement<T>, ) -> FetchStatement<T2>
fn fold_format(&mut self, node: Format<T>) -> Format<T2>
fn fold_format_specifier( &mut self, node: FormatSpecifier<T>, ) -> FormatSpecifier<T2>
fn fold_function_args(&mut self, node: FunctionArgs<T>) -> FunctionArgs<T2>
fn fold_grant_privileges_statement( &mut self, node: GrantPrivilegesStatement<T>, ) -> GrantPrivilegesStatement<T2>
fn fold_grant_role_statement( &mut self, node: GrantRoleStatement<T>, ) -> GrantRoleStatement<T2>
fn fold_grant_target_all_specification( &mut self, node: GrantTargetAllSpecification<T>, ) -> GrantTargetAllSpecification<T2>
fn fold_grant_target_specification_inner( &mut self, node: GrantTargetSpecificationInner<T>, ) -> GrantTargetSpecificationInner<T2>
fn fold_homogenizing_function( &mut self, node: HomogenizingFunction, ) -> HomogenizingFunction
fn fold_iceberg_sink_config_option( &mut self, node: IcebergSinkConfigOption<T>, ) -> IcebergSinkConfigOption<T2>
fn fold_iceberg_sink_config_option_name( &mut self, node: IcebergSinkConfigOptionName, ) -> IcebergSinkConfigOptionName
fn fold_ident(&mut self, node: Ident) -> Ident
fn fold_ident_error(&mut self, node: IdentError) -> IdentError
fn fold_if_exists_behavior( &mut self, node: IfExistsBehavior, ) -> IfExistsBehavior
fn fold_index_option(&mut self, node: IndexOption<T>) -> IndexOption<T2>
fn fold_index_option_name(&mut self, node: IndexOptionName) -> IndexOptionName
fn fold_insert_source(&mut self, node: InsertSource<T>) -> InsertSource<T2>
fn fold_insert_statement( &mut self, node: InsertStatement<T>, ) -> InsertStatement<T2>
fn fold_inspect_shard_statement( &mut self, node: InspectShardStatement, ) -> InspectShardStatement
fn fold_interval_value(&mut self, node: IntervalValue) -> IntervalValue
fn fold_is_expr_construct( &mut self, node: IsExprConstruct<T>, ) -> IsExprConstruct<T2>
fn fold_join(&mut self, node: Join<T>) -> Join<T2>
fn fold_join_constraint( &mut self, node: JoinConstraint<T>, ) -> JoinConstraint<T2>
fn fold_join_operator(&mut self, node: JoinOperator<T>) -> JoinOperator<T2>
fn fold_kafka_broker(&mut self, node: KafkaBroker<T>) -> KafkaBroker<T2>
fn fold_kafka_broker_aws_privatelink( &mut self, node: KafkaBrokerAwsPrivatelink<T>, ) -> KafkaBrokerAwsPrivatelink<T2>
fn fold_kafka_broker_aws_privatelink_option( &mut self, node: KafkaBrokerAwsPrivatelinkOption<T>, ) -> KafkaBrokerAwsPrivatelinkOption<T2>
fn fold_kafka_broker_aws_privatelink_option_name( &mut self, node: KafkaBrokerAwsPrivatelinkOptionName, ) -> KafkaBrokerAwsPrivatelinkOptionName
fn fold_kafka_broker_tunnel( &mut self, node: KafkaBrokerTunnel<T>, ) -> KafkaBrokerTunnel<T2>
fn fold_kafka_sink_config_option( &mut self, node: KafkaSinkConfigOption<T>, ) -> KafkaSinkConfigOption<T2>
fn fold_kafka_sink_config_option_name( &mut self, node: KafkaSinkConfigOptionName, ) -> KafkaSinkConfigOptionName
fn fold_kafka_source_config_option( &mut self, node: KafkaSourceConfigOption<T>, ) -> KafkaSourceConfigOption<T2>
fn fold_kafka_source_config_option_name( &mut self, node: KafkaSourceConfigOptionName, ) -> KafkaSourceConfigOptionName
fn fold_key_constraint(&mut self, node: KeyConstraint) -> KeyConstraint
fn fold_limit(&mut self, node: Limit<T>) -> Limit<T2>
fn fold_load_generator(&mut self, node: LoadGenerator) -> LoadGenerator
fn fold_load_generator_option( &mut self, node: LoadGeneratorOption<T>, ) -> LoadGeneratorOption<T2>
fn fold_load_generator_option_name( &mut self, node: LoadGeneratorOptionName, ) -> LoadGeneratorOptionName
fn fold_map_entry(&mut self, node: MapEntry<T>) -> MapEntry<T2>
fn fold_materialized_view_option( &mut self, node: MaterializedViewOption<T>, ) -> MaterializedViewOption<T2>
fn fold_materialized_view_option_name( &mut self, node: MaterializedViewOptionName, ) -> MaterializedViewOptionName
fn fold_mut_rec_block(&mut self, node: MutRecBlock<T>) -> MutRecBlock<T2>
fn fold_mut_rec_block_option( &mut self, node: MutRecBlockOption<T>, ) -> MutRecBlockOption<T2>
fn fold_mut_rec_block_option_name( &mut self, node: MutRecBlockOptionName, ) -> MutRecBlockOptionName
fn fold_my_sql_config_option( &mut self, node: MySqlConfigOption<T>, ) -> MySqlConfigOption<T2>
fn fold_my_sql_config_option_name( &mut self, node: MySqlConfigOptionName, ) -> MySqlConfigOptionName
fn fold_named_plan(&mut self, node: NamedPlan) -> NamedPlan
fn fold_network_policy_option( &mut self, node: NetworkPolicyOption<T>, ) -> NetworkPolicyOption<T2>
fn fold_network_policy_option_name( &mut self, node: NetworkPolicyOptionName, ) -> NetworkPolicyOptionName
fn fold_network_policy_rule_definition( &mut self, node: NetworkPolicyRuleDefinition<T>, ) -> NetworkPolicyRuleDefinition<T2>
fn fold_network_policy_rule_option( &mut self, node: NetworkPolicyRuleOption<T>, ) -> NetworkPolicyRuleOption<T2>
fn fold_network_policy_rule_option_name( &mut self, node: NetworkPolicyRuleOptionName, ) -> NetworkPolicyRuleOptionName
fn fold_notice_severity(&mut self, node: NoticeSeverity) -> NoticeSeverity
fn fold_object_type(&mut self, node: ObjectType) -> ObjectType
fn fold_op(&mut self, node: Op) -> Op
fn fold_order_by_expr(&mut self, node: OrderByExpr<T>) -> OrderByExpr<T2>
fn fold_pg_config_option( &mut self, node: PgConfigOption<T>, ) -> PgConfigOption<T2>
fn fold_pg_config_option_name( &mut self, node: PgConfigOptionName, ) -> PgConfigOptionName
fn fold_prepare_statement( &mut self, node: PrepareStatement<T>, ) -> PrepareStatement<T2>
fn fold_privilege(&mut self, node: Privilege) -> Privilege
fn fold_privilege_specification( &mut self, node: PrivilegeSpecification, ) -> PrivilegeSpecification
fn fold_protobuf_schema( &mut self, node: ProtobufSchema<T>, ) -> ProtobufSchema<T2>
fn fold_qualified_replica(&mut self, node: QualifiedReplica) -> QualifiedReplica
fn fold_raise_statement(&mut self, node: RaiseStatement) -> RaiseStatement
fn fold_reader_schema_selection_strategy( &mut self, node: ReaderSchemaSelectionStrategy, ) -> ReaderSchemaSelectionStrategy
fn fold_reassign_owned_statement( &mut self, node: ReassignOwnedStatement<T>, ) -> ReassignOwnedStatement<T2>
fn fold_refresh_at_option_value( &mut self, node: RefreshAtOptionValue<T>, ) -> RefreshAtOptionValue<T2>
fn fold_refresh_every_option_value( &mut self, node: RefreshEveryOptionValue<T>, ) -> RefreshEveryOptionValue<T2>
fn fold_refresh_option_value( &mut self, node: RefreshOptionValue<T>, ) -> RefreshOptionValue<T2>
fn fold_replica_definition( &mut self, node: ReplicaDefinition<T>, ) -> ReplicaDefinition<T2>
fn fold_replica_option(&mut self, node: ReplicaOption<T>) -> ReplicaOption<T2>
fn fold_replica_option_name( &mut self, node: ReplicaOptionName, ) -> ReplicaOptionName
fn fold_reset_variable_statement( &mut self, node: ResetVariableStatement, ) -> ResetVariableStatement
fn fold_revoke_privileges_statement( &mut self, node: RevokePrivilegesStatement<T>, ) -> RevokePrivilegesStatement<T2>
fn fold_revoke_role_statement( &mut self, node: RevokeRoleStatement<T>, ) -> RevokeRoleStatement<T2>
fn fold_role_attribute(&mut self, node: RoleAttribute) -> RoleAttribute
fn fold_rollback_statement( &mut self, node: RollbackStatement, ) -> RollbackStatement
fn fold_schema(&mut self, node: Schema) -> Schema
fn fold_select(&mut self, node: Select<T>) -> Select<T2>
fn fold_select_item(&mut self, node: SelectItem<T>) -> SelectItem<T2>
fn fold_select_option(&mut self, node: SelectOption<T>) -> SelectOption<T2>
fn fold_select_option_name( &mut self, node: SelectOptionName, ) -> SelectOptionName
fn fold_select_statement( &mut self, node: SelectStatement<T>, ) -> SelectStatement<T2>
fn fold_set_expr(&mut self, node: SetExpr<T>) -> SetExpr<T2>
fn fold_set_operator(&mut self, node: SetOperator) -> SetOperator
fn fold_set_role_var(&mut self, node: SetRoleVar) -> SetRoleVar
fn fold_set_transaction_statement( &mut self, node: SetTransactionStatement, ) -> SetTransactionStatement
fn fold_set_variable_statement( &mut self, node: SetVariableStatement, ) -> SetVariableStatement
fn fold_set_variable_to(&mut self, node: SetVariableTo) -> SetVariableTo
fn fold_set_variable_value( &mut self, node: SetVariableValue, ) -> SetVariableValue
fn fold_show_columns_statement( &mut self, node: ShowColumnsStatement<T>, ) -> ShowColumnsStatement<T2>
fn fold_show_create_cluster_statement( &mut self, node: ShowCreateClusterStatement<T>, ) -> ShowCreateClusterStatement<T2>
fn fold_show_create_connection_statement( &mut self, node: ShowCreateConnectionStatement<T>, ) -> ShowCreateConnectionStatement<T2>
fn fold_show_create_index_statement( &mut self, node: ShowCreateIndexStatement<T>, ) -> ShowCreateIndexStatement<T2>
fn fold_show_create_materialized_view_statement( &mut self, node: ShowCreateMaterializedViewStatement<T>, ) -> ShowCreateMaterializedViewStatement<T2>
fn fold_show_create_sink_statement( &mut self, node: ShowCreateSinkStatement<T>, ) -> ShowCreateSinkStatement<T2>
fn fold_show_create_source_statement( &mut self, node: ShowCreateSourceStatement<T>, ) -> ShowCreateSourceStatement<T2>
fn fold_show_create_table_statement( &mut self, node: ShowCreateTableStatement<T>, ) -> ShowCreateTableStatement<T2>
fn fold_show_create_type_statement( &mut self, node: ShowCreateTypeStatement<T>, ) -> ShowCreateTypeStatement<T2>
fn fold_show_create_view_statement( &mut self, node: ShowCreateViewStatement<T>, ) -> ShowCreateViewStatement<T2>
fn fold_show_object_type( &mut self, node: ShowObjectType<T>, ) -> ShowObjectType<T2>
fn fold_show_objects_statement( &mut self, node: ShowObjectsStatement<T>, ) -> ShowObjectsStatement<T2>
fn fold_show_statement(&mut self, node: ShowStatement<T>) -> ShowStatement<T2>
fn fold_show_statement_filter( &mut self, node: ShowStatementFilter<T>, ) -> ShowStatementFilter<T2>
fn fold_show_variable_statement( &mut self, node: ShowVariableStatement, ) -> ShowVariableStatement
fn fold_sink_envelope(&mut self, node: SinkEnvelope) -> SinkEnvelope
fn fold_sink_key(&mut self, node: SinkKey) -> SinkKey
fn fold_source_envelope(&mut self, node: SourceEnvelope) -> SourceEnvelope
fn fold_source_error_policy( &mut self, node: SourceErrorPolicy, ) -> SourceErrorPolicy
fn fold_source_include_metadata( &mut self, node: SourceIncludeMetadata, ) -> SourceIncludeMetadata
fn fold_sql_server_config_option( &mut self, node: SqlServerConfigOption<T>, ) -> SqlServerConfigOption<T2>
fn fold_sql_server_config_option_name( &mut self, node: SqlServerConfigOptionName, ) -> SqlServerConfigOptionName
fn fold_start_transaction_statement( &mut self, node: StartTransactionStatement, ) -> StartTransactionStatement
fn fold_statement(&mut self, node: Statement<T>) -> Statement<T2>
fn fold_subscribe_option( &mut self, node: SubscribeOption<T>, ) -> SubscribeOption<T2>
fn fold_subscribe_option_name( &mut self, node: SubscribeOptionName, ) -> SubscribeOptionName
fn fold_subscribe_output( &mut self, node: SubscribeOutput<T>, ) -> SubscribeOutput<T2>
fn fold_subscribe_relation( &mut self, node: SubscribeRelation<T>, ) -> SubscribeRelation<T2>
fn fold_subscribe_statement( &mut self, node: SubscribeStatement<T>, ) -> SubscribeStatement<T2>
fn fold_subscript_position( &mut self, node: SubscriptPosition<T>, ) -> SubscriptPosition<T2>
fn fold_system_object_type( &mut self, node: SystemObjectType, ) -> SystemObjectType
fn fold_table_alias(&mut self, node: TableAlias) -> TableAlias
fn fold_table_constraint( &mut self, node: TableConstraint<T>, ) -> TableConstraint<T2>
fn fold_table_from_source_columns( &mut self, node: TableFromSourceColumns<T>, ) -> TableFromSourceColumns<T2>
fn fold_table_from_source_option( &mut self, node: TableFromSourceOption<T>, ) -> TableFromSourceOption<T2>
fn fold_table_from_source_option_name( &mut self, node: TableFromSourceOptionName, ) -> TableFromSourceOptionName
fn fold_table_option(&mut self, node: TableOption<T>) -> TableOption<T2>
fn fold_table_option_name(&mut self, node: TableOptionName) -> TableOptionName
fn fold_table_with_joins( &mut self, node: TableWithJoins<T>, ) -> TableWithJoins<T2>
fn fold_target_role_specification( &mut self, node: TargetRoleSpecification<T>, ) -> TargetRoleSpecification<T2>
fn fold_transaction_access_mode( &mut self, node: TransactionAccessMode, ) -> TransactionAccessMode
fn fold_transaction_isolation_level( &mut self, node: TransactionIsolationLevel, ) -> TransactionIsolationLevel
fn fold_transaction_mode(&mut self, node: TransactionMode) -> TransactionMode
fn fold_unresolved_database_name( &mut self, node: UnresolvedDatabaseName, ) -> UnresolvedDatabaseName
fn fold_unresolved_item_name( &mut self, node: UnresolvedItemName, ) -> UnresolvedItemName
fn fold_unresolved_object_name( &mut self, node: UnresolvedObjectName, ) -> UnresolvedObjectName
fn fold_unresolved_schema_name( &mut self, node: UnresolvedSchemaName, ) -> UnresolvedSchemaName
fn fold_update_statement( &mut self, node: UpdateStatement<T>, ) -> UpdateStatement<T2>
fn fold_validate_connection_statement( &mut self, node: ValidateConnectionStatement<T>, ) -> ValidateConnectionStatement<T2>
fn fold_value(&mut self, node: Value) -> Value
fn fold_value_error(&mut self, node: ValueError) -> ValueError
fn fold_values(&mut self, node: Values<T>) -> Values<T2>
fn fold_version(&mut self, node: Version) -> Version
fn fold_view_definition( &mut self, node: ViewDefinition<T>, ) -> ViewDefinition<T2>
fn fold_window_frame(&mut self, node: WindowFrame) -> WindowFrame
fn fold_window_frame_bound( &mut self, node: WindowFrameBound, ) -> WindowFrameBound
fn fold_window_frame_units( &mut self, node: WindowFrameUnits, ) -> WindowFrameUnits
fn fold_window_spec(&mut self, node: WindowSpec<T>) -> WindowSpec<T2>
Auto Trait Implementations§
impl<'a> Freeze for NameResolver<'a>
impl<'a> !RefUnwindSafe for NameResolver<'a>
impl<'a> Send for NameResolver<'a>
impl<'a> Sync for NameResolver<'a>
impl<'a> Unpin for NameResolver<'a>
impl<'a> !UnwindSafe for NameResolver<'a>
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> Downcast for T
 
impl<T> Downcast for T
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> IntoEither for T
 
impl<T> IntoEither for T
Source§fn into_either(self, into_left: bool) -> Either<Self, Self>
 
fn into_either(self, into_left: bool) -> Either<Self, Self>
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 moreSource§fn into_either_with<F>(self, into_left: F) -> Either<Self, Self>
 
fn into_either_with<F>(self, into_left: F) -> Either<Self, Self>
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 moreSource§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::RequestSource§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> Paint for Twhere
    T: ?Sized,
 
impl<T> Paint for Twhere
    T: ?Sized,
Source§fn fg(&self, value: Color) -> Painted<&T>
 
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 bright_black(&self) -> Painted<&T>
 
fn bright_black(&self) -> Painted<&T>
Source§fn bright_red(&self) -> Painted<&T>
 
fn bright_red(&self) -> Painted<&T>
Source§fn bright_green(&self) -> Painted<&T>
 
fn bright_green(&self) -> Painted<&T>
Source§fn bright_yellow(&self) -> Painted<&T>
 
fn bright_yellow(&self) -> Painted<&T>
Source§fn bright_blue(&self) -> Painted<&T>
 
fn bright_blue(&self) -> Painted<&T>
Source§fn bright_magenta(&self) -> Painted<&T>
 
fn bright_magenta(&self) -> Painted<&T>
Source§fn bright_cyan(&self) -> Painted<&T>
 
fn bright_cyan(&self) -> Painted<&T>
Source§fn bright_white(&self) -> Painted<&T>
 
fn bright_white(&self) -> Painted<&T>
Source§fn bg(&self, value: Color) -> Painted<&T>
 
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>
 
fn on_primary(&self) -> Painted<&T>
Source§fn on_magenta(&self) -> Painted<&T>
 
fn on_magenta(&self) -> Painted<&T>
Source§fn on_bright_black(&self) -> Painted<&T>
 
fn on_bright_black(&self) -> Painted<&T>
Source§fn on_bright_red(&self) -> Painted<&T>
 
fn on_bright_red(&self) -> Painted<&T>
Source§fn on_bright_green(&self) -> Painted<&T>
 
fn on_bright_green(&self) -> Painted<&T>
Source§fn on_bright_yellow(&self) -> Painted<&T>
 
fn on_bright_yellow(&self) -> Painted<&T>
Source§fn on_bright_blue(&self) -> Painted<&T>
 
fn on_bright_blue(&self) -> Painted<&T>
Source§fn on_bright_magenta(&self) -> Painted<&T>
 
fn on_bright_magenta(&self) -> Painted<&T>
Source§fn on_bright_cyan(&self) -> Painted<&T>
 
fn on_bright_cyan(&self) -> Painted<&T>
Source§fn on_bright_white(&self) -> Painted<&T>
 
fn on_bright_white(&self) -> Painted<&T>
Source§fn attr(&self, value: Attribute) -> Painted<&T>
 
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 rapid_blink(&self) -> Painted<&T>
 
fn rapid_blink(&self) -> Painted<&T>
Source§fn quirk(&self, value: Quirk) -> Painted<&T>
 
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 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.
fn clear(&self) -> Painted<&T>
resetting() due to conflicts with Vec::clear().
The clear() method will be removed in a future release.Source§fn whenever(&self, value: Condition) -> Painted<&T>
 
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§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> PolicyExt for Twhere
    T: ?Sized,
 
impl<T> PolicyExt for Twhere
    T: ?Sized,
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> ServiceExt for T
 
impl<T> ServiceExt for T
Source§fn map_response_body<F>(self, f: F) -> MapResponseBody<Self, F>where
    Self: Sized,
 
fn map_response_body<F>(self, f: F) -> MapResponseBody<Self, F>where
    Self: Sized,
Source§fn decompression(self) -> Decompression<Self>where
    Self: Sized,
 
fn decompression(self) -> Decompression<Self>where
    Self: Sized,
Source§fn trace_for_http(self) -> Trace<Self, SharedClassifier<ServerErrorsAsFailures>>where
    Self: Sized,
 
fn trace_for_http(self) -> Trace<Self, SharedClassifier<ServerErrorsAsFailures>>where
    Self: Sized,
Source§fn trace_for_grpc(self) -> Trace<Self, SharedClassifier<GrpcErrorsAsFailures>>where
    Self: Sized,
 
fn trace_for_grpc(self) -> Trace<Self, SharedClassifier<GrpcErrorsAsFailures>>where
    Self: Sized,
Source§fn follow_redirects(self) -> FollowRedirect<Self>where
    Self: Sized,
 
fn follow_redirects(self) -> FollowRedirect<Self>where
    Self: Sized,
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.