RegionWorkerLoop

Struct RegionWorkerLoop 

Source
struct RegionWorkerLoop<S> {
Show 34 fields id: u32, config: Arc<MitoConfig>, regions: Arc<RegionMap>, dropping_regions: Arc<RegionMap>, opening_regions: Arc<OpeningRegions>, catchup_regions: Arc<CatchupRegions>, sender: Sender<WorkerRequestWithTime>, receiver: Receiver<WorkerRequestWithTime>, wal: Wal<S>, object_store_manager: ObjectStoreManagerRef, running: Arc<AtomicBool>, memtable_builder_provider: MemtableBuilderProvider, purge_scheduler: SchedulerRef, write_buffer_manager: WriteBufferManagerRef, index_build_scheduler: IndexBuildScheduler, flush_scheduler: FlushScheduler, compaction_scheduler: CompactionScheduler, stalled_requests: StalledRequests, listener: WorkerListener, cache_manager: CacheManagerRef, puffin_manager_factory: PuffinManagerFactory, intermediate_manager: IntermediateManager, time_provider: Arc<dyn TimeProvider>, last_periodical_check_millis: i64, flush_sender: Sender<()>, flush_receiver: Receiver<()>, stalling_count: IntGauge, region_count: IntGauge, request_wait_time: Histogram, region_edit_queues: HashMap<RegionId, RegionEditQueue>, schema_metadata_manager: SchemaMetadataManagerRef, file_ref_manager: FileReferenceManagerRef, partition_expr_fetcher: PartitionExprFetcherRef, flush_semaphore: Arc<Semaphore>,
}
Expand description

Background worker loop to handle requests.

Fields§

§id: u32

Id of the worker.

§config: Arc<MitoConfig>

Engine config.

§regions: Arc<RegionMap>

Regions bound to the worker.

§dropping_regions: Arc<RegionMap>

Regions that are not yet fully dropped.

§opening_regions: Arc<OpeningRegions>

Regions that are opening.

§catchup_regions: Arc<CatchupRegions>

Regions that are catching up.

§sender: Sender<WorkerRequestWithTime>

Request sender.

§receiver: Receiver<WorkerRequestWithTime>

Request receiver.

§wal: Wal<S>

WAL of the engine.

§object_store_manager: ObjectStoreManagerRef

Manages object stores for manifest and SSTs.

§running: Arc<AtomicBool>

Whether the worker thread is still running.

§memtable_builder_provider: MemtableBuilderProvider

Memtable builder provider for each region.

§purge_scheduler: SchedulerRef

Background purge job scheduler.

§write_buffer_manager: WriteBufferManagerRef

Engine write buffer manager.

§index_build_scheduler: IndexBuildScheduler

Scheduler for index build task.

§flush_scheduler: FlushScheduler

Schedules background flush requests.

§compaction_scheduler: CompactionScheduler

Scheduler for compaction tasks.

§stalled_requests: StalledRequests

Stalled write requests.

§listener: WorkerListener

Event listener for tests.

§cache_manager: CacheManagerRef

Cache.

§puffin_manager_factory: PuffinManagerFactory

Puffin manager factory for index.

§intermediate_manager: IntermediateManager

Intermediate manager for inverted index.

§time_provider: Arc<dyn TimeProvider>

Provider to get current time.

§last_periodical_check_millis: i64

Last time to check regions periodically.

§flush_sender: Sender<()>

Watch channel sender to notify workers to handle stalled requests.

§flush_receiver: Receiver<()>

Watch channel receiver to wait for background flush job.

§stalling_count: IntGauge

Gauge of stalling request count.

§region_count: IntGauge

Gauge of regions in the worker.

§request_wait_time: Histogram

Histogram of request wait time for this worker.

§region_edit_queues: HashMap<RegionId, RegionEditQueue>

Queues for region edit requests.

§schema_metadata_manager: SchemaMetadataManagerRef

Database level metadata manager.

§file_ref_manager: FileReferenceManagerRef

Datanode level file references manager.

§partition_expr_fetcher: PartitionExprFetcherRef

Partition expr fetcher used to backfill partition expr on open for compatibility.

§flush_semaphore: Arc<Semaphore>

Semaphore to control flush concurrency.

Implementations§

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_alter_request( &mut self, region_id: RegionId, request: RegionAlterRequest, sender: OptionOutputTx, )

Source

fn handle_alter_region_with_empty_memtable( &mut self, region: MitoRegionRef, version: Arc<Version>, request: RegionAlterRequest, sender: OptionOutputTx, )

Handles region metadata and format changes when the region memtable is empty.

Source

fn handle_alter_region_options_fast( &mut self, region: &MitoRegionRef, version: Arc<Version>, options: Vec<SetRegionOption>, ) -> Result<Option<Arc<Version>>, MetadataError>

Handles requests that changes region options, like TTL. It only affects memory state since changes are persisted in the DatanodeTableValue in metasrv.

If the options require empty memtable, it only does validation.

Returns a new version with the updated options if it needs further alteration.

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_bulk_insert_batch( &mut self, region_metadata: RegionMetadataRef, request: RegionBulkInsertsRequest, pending_bulk_request: &mut Vec<SenderBulkRequest>, sender: OptionOutputTx, )

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_catchup_request( &mut self, region_id: RegionId, request: RegionCatchupRequest, entry_receiver: Option<WalEntryReceiver>, sender: OptionOutputTx, )

Source

pub(crate) async fn reopen_region( &mut self, region: &Arc<MitoRegion>, ) -> Result<Arc<MitoRegion>>

Reopens a region.

Source

async fn reopen_region_if_needed( &mut self, region: Arc<MitoRegion>, ) -> Result<Arc<MitoRegion>>

Source§

impl<S> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_close_request( &mut self, region_id: RegionId, ) -> Result<AffectedRows>

Source§

impl<S> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_compaction_request( &mut self, region_id: RegionId, req: RegionCompactRequest, sender: OptionOutputTx, )

Handles compaction request submitted to region worker.

Source

pub(crate) async fn handle_compaction_finished( &mut self, region_id: RegionId, request: CompactionFinished, )

Handles compaction finished, update region version and manifest, deleted compacted files.

Source

pub(crate) async fn handle_compaction_failure(&mut self, req: CompactionFailed)

When compaction fails, we simply log the error.

Source

pub(crate) async fn schedule_compaction(&mut self, region: &MitoRegionRef)

Schedule compaction for the region if necessary.

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_create_request( &mut self, region_id: RegionId, request: RegionCreateRequest, ) -> Result<AffectedRows>

Source§

impl<S> RegionWorkerLoop<S>
where S: LogStore,

Source

pub(crate) async fn handle_drop_request( &mut self, region_id: RegionId, ) -> Result<AffectedRows>

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_enter_staging_request( &mut self, region_id: RegionId, partition_expr: String, sender: OptionOutputTx, )

Source

async fn enter_staging( region: &MitoRegionRef, partition_expr: String, ) -> Result<()>

Source

fn handle_enter_staging( &self, region: MitoRegionRef, partition_expr: String, sender: OptionOutputTx, )

Source

pub(crate) async fn handle_enter_staging_result( &mut self, enter_staging_result: EnterStagingResult, )

Handles enter staging result.

Source

fn update_region_staging_partition_expr( region: &MitoRegionRef, partition_expr: String, )

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_flush_failed( &mut self, region_id: RegionId, request: FlushFailed, )

On region flush job failed.

Source

pub(crate) fn maybe_flush_worker(&mut self)

Checks whether the engine reaches flush threshold. If so, finds regions in this worker to flush.

Source

fn flush_regions_on_engine_full(&mut self) -> Result<()>

Finds some regions to flush to reduce write buffer usage.

Source

pub(crate) fn new_flush_task( &self, region: &MitoRegionRef, reason: FlushReason, row_group_size: Option<usize>, engine_config: Arc<MitoConfig>, is_staging: bool, ) -> RegionFlushTask

Creates a flush task with specific reason for the region.

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) fn handle_flush_request( &mut self, region_id: RegionId, request: RegionFlushRequest, sender: OptionOutputTx, )

Handles manual flush request.

Source

pub(crate) fn flush_periodically(&mut self) -> Result<()>

Flushes regions periodically.

Source

pub(crate) async fn handle_flush_finished( &mut self, region_id: RegionId, request: FlushFinished, )

On region flush job finished.

Source

pub(crate) fn update_topic_latest_entry_id(&mut self, region: &MitoRegionRef)

Updates the latest entry id since flush of the region. This is only used for remote WAL pruning.

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_manifest_region_change_result( &mut self, change_result: RegionChangeResult, )

Handles region change result.

Source

pub(crate) async fn handle_region_sync(&mut self, request: RegionSyncRequest)

Handles region sync request.

Updates the manifest to at least the given version. Note: The installed version may be greater than the given version.

Source§

impl<S> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_region_edit(&mut self, request: RegionEditRequest)

Handles region edit request.

Source

pub(crate) async fn handle_region_edit_result( &mut self, edit_result: RegionEditResult, )

Handles region edit result.

Source

pub(crate) fn handle_manifest_truncate_action( &self, region: MitoRegionRef, truncate: RegionTruncate, sender: OptionOutputTx, )

Writes truncate action to the manifest and then applies it to the region in background.

Source

pub(crate) fn handle_manifest_region_change( &self, region: MitoRegionRef, change: RegionChange, need_index: bool, new_options: Option<RegionOptions>, sender: OptionOutputTx, )

Writes region change action to the manifest and then applies it to the region in background.

Source

fn update_region_version( version_control: &Arc<VersionControl>, new_meta: RegionMetadataRef, new_options: Option<RegionOptions>, memtable_builder_provider: &MemtableBuilderProvider, )

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

async fn check_and_cleanup_region( &self, region_id: RegionId, request: &RegionOpenRequest, ) -> Result<()>

Source

pub(crate) async fn handle_open_request( &mut self, region_id: RegionId, request: RegionOpenRequest, wal_entry_receiver: Option<WalEntryReceiver>, sender: OptionOutputTx, )

Source§

impl<S> RegionWorkerLoop<S>

Source

pub(crate) fn new_index_build_task( &self, region: &MitoRegionRef, file: FileHandle, build_type: IndexBuildType, result_sender: ResultMpscSender, ) -> IndexBuildTask

Source

pub(crate) async fn handle_build_index_request( &mut self, region_id: RegionId, _req: RegionBuildIndexRequest, sender: OptionOutputTx, )

Handles manual build index requests.

Source

pub(crate) async fn handle_rebuild_index( &mut self, request: BuildIndexRequest, sender: OptionOutputTx, )

Source

pub(crate) async fn handle_index_build_finished( &mut self, region_id: RegionId, request: IndexBuildFinished, )

Source

pub(crate) async fn handle_index_build_failed( &mut self, region_id: RegionId, request: IndexBuildFailed, )

Source

pub(crate) async fn handle_index_build_stopped( &mut self, region_id: RegionId, request: IndexBuildStopped, )

Source§

impl<S> RegionWorkerLoop<S>

Source

pub(crate) fn handle_remap_manifests_request( &mut self, request: RemapManifestsRequest, )

Source

async fn fetch_and_remap_manifests( region: MitoRegionRef, region_metadata_loader: RegionMetadataLoader, input_regions: Vec<RegionId>, new_partition_exprs: HashMap<RegionId, PartitionExpr>, region_mapping: HashMap<RegionId, Vec<RegionId>>, ) -> Result<HashMap<RegionId, RegionManifest>>

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_truncate_request( &mut self, region_id: RegionId, req: RegionTruncateRequest, sender: OptionOutputTx, )

Source

pub(crate) async fn handle_truncate_result( &mut self, truncate_result: TruncateResult, )

Handles truncate result.

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

pub(crate) async fn handle_write_requests( &mut self, write_requests: &mut Vec<SenderWriteRequest>, bulk_requests: &mut Vec<SenderBulkRequest>, allow_stall: bool, )

Takes and handles all write requests.

Source

pub(crate) async fn handle_stalled_requests(&mut self)

Handles all stalled write requests.

Source

pub(crate) fn reject_stalled_requests(&mut self)

Rejects all stalled requests.

Source

pub(crate) fn reject_region_stalled_requests(&mut self, region_id: &RegionId)

Rejects a specific region’s stalled requests.

Source

pub(crate) async fn handle_region_stalled_requests( &mut self, region_id: &RegionId, )

Handles a specific region’s stalled requests.

Source§

impl<S> RegionWorkerLoop<S>

Source

fn prepare_region_write_ctx( &mut self, write_requests: &mut Vec<SenderWriteRequest>, bulk_requests: &mut Vec<SenderBulkRequest>, ) -> HashMap<RegionId, RegionWriteCtx>

Validates and groups requests by region.

Source

fn process_write_requests( &mut self, region_ctxs: &mut HashMap<RegionId, RegionWriteCtx>, write_requests: &mut Vec<SenderWriteRequest>, )

Source

fn process_bulk_requests( &mut self, region_ctxs: &mut HashMap<RegionId, RegionWriteCtx>, requests: &mut Vec<SenderBulkRequest>, )

Processes bulk insert requests.

Source

pub(crate) fn should_reject_write(&self) -> bool

Returns true if the engine needs to reject some write requests.

Source§

impl<S: LogStore> RegionWorkerLoop<S>

Source

async fn run(&mut self)

Starts the worker loop.

Source

async fn handle_requests( &mut self, write_requests: &mut Vec<SenderWriteRequest>, ddl_requests: &mut Vec<SenderDdlRequest>, general_requests: &mut Vec<WorkerRequest>, bulk_requests: &mut Vec<SenderBulkRequest>, )

Dispatches and processes requests.

buffer should be empty.

Source

async fn handle_ddl_requests( &mut self, ddl_requests: &mut Vec<SenderDdlRequest>, )

Takes and handles all ddl requests.

Source

fn handle_periodical_tasks(&mut self)

Handle periodical tasks such as region auto flush.

Source

async fn handle_background_notify( &mut self, region_id: RegionId, notify: BackgroundNotify, )

Handles region background request

Source

async fn set_role_state_gracefully( &mut self, region_id: RegionId, region_role_state: SettableRegionRoleState, sender: Sender<SetRegionRoleStateResponse>, )

Handles set_region_role_gracefully.

Source§

impl<S> RegionWorkerLoop<S>

Source

async fn clean(&self)

Cleans up the worker.

Source

fn notify_group(&mut self)

Notifies the whole group that a flush job is finished so other workers can handle stalled requests.

Auto Trait Implementations§

§

impl<S> Freeze for RegionWorkerLoop<S>

§

impl<S> !RefUnwindSafe for RegionWorkerLoop<S>

§

impl<S> Send for RegionWorkerLoop<S>
where S: Sync + Send,

§

impl<S> Sync for RegionWorkerLoop<S>
where S: Sync + Send,

§

impl<S> Unpin for RegionWorkerLoop<S>

§

impl<S> !UnwindSafe for RegionWorkerLoop<S>

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
§

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

§

fn into_any(self: Box<T>) -> Box<dyn Any>

§

fn into_any_rc(self: Rc<T>) -> Rc<dyn Any>

§

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

§

impl<T> AnySync for T
where T: Any + Send + Sync,

§

fn into_any_arc(self: Arc<T>) -> Arc<dyn Any + Sync + Send>

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
§

impl<T> Conv for T

§

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

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

impl<T, V> Convert<T> for V
where V: Into<T>,

§

fn convert(value: Self) -> T

§

fn convert_box(value: Box<Self>) -> Box<T>

§

fn convert_vec(value: Vec<Self>) -> Vec<T>

§

fn convert_vec_box(value: Vec<Box<Self>>) -> Vec<Box<T>>

§

fn convert_matrix(value: Vec<Vec<Self>>) -> Vec<Vec<T>>

§

fn convert_option(value: Option<Self>) -> Option<T>

§

fn convert_option_box(value: Option<Box<Self>>) -> Option<Box<T>>

§

fn convert_option_vec(value: Option<Vec<Self>>) -> Option<Vec<T>>

§

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

§

fn into_any(self: Box<T>) -> Box<dyn Any>

Converts Box<dyn Trait> (where Trait: Downcast) to Box<dyn Any>, which can then be downcast into Box<dyn ConcreteType> where ConcreteType implements Trait.
§

fn into_any_rc(self: Rc<T>) -> Rc<dyn Any>

Converts Rc<Trait> (where Trait: Downcast) to Rc<Any>, which can then be further downcast into Rc<ConcreteType> where ConcreteType implements Trait.
§

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

Converts &Trait (where Trait: Downcast) to &Any. This is needed since Rust cannot generate &Any’s vtable from &Trait’s.
§

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

Converts &mut Trait (where Trait: Downcast) to &Any. This is needed since Rust cannot generate &mut Any’s vtable from &mut Trait’s.
§

impl<T> DowncastSend for T
where T: Any + Send,

§

fn into_any_send(self: Box<T>) -> Box<dyn Any + Send>

Converts Box<Trait> (where Trait: DowncastSend) to Box<dyn Any + Send>, which can then be downcast into Box<ConcreteType> where ConcreteType implements Trait.
§

impl<T> DowncastSync for T
where T: Any + Send + Sync,

§

fn into_any_sync(self: Box<T>) -> Box<dyn Any + Sync + Send>

Converts Box<Trait> (where Trait: DowncastSync) to Box<dyn Any + Send + Sync>, which can then be downcast into Box<ConcreteType> where ConcreteType implements Trait.
§

fn into_any_arc(self: Arc<T>) -> Arc<dyn Any + Sync + Send>

Converts Arc<Trait> (where Trait: DowncastSync) to Arc<Any>, which can then be downcast into Arc<ConcreteType> where ConcreteType implements Trait.
§

impl<T> FmtForward for T

§

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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.

§

impl<T> FutureExt for T

§

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

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

fn with_current_context(self) -> WithContext<Self>

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

impl<T> Instrument for T

§

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

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

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
§

impl<T> IntoRequest<T> for T

§

fn into_request(self) -> Request<T>

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

impl<L> LayerExt<L> for L

§

fn named_layer<S>(&self, service: S) -> Layered<<L as Layer<S>>::Service, S>
where L: Layer<S>,

Applies the layer to a service and wraps it in [Layered].
§

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

§

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
§

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
§

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
§

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
§

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
§

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

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

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

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

impl<T> Pointable for T

§

const ALIGN: usize

The alignment of pointer.
§

type Init = T

The type for initializers.
§

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

Initializes a with the given initializer. Read more
§

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

Dereferences the given pointer. Read more
§

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

Mutably dereferences the given pointer. Read more
§

unsafe fn drop(ptr: usize)

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

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

§

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
§

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<T> Same for T

Source§

type Output = T

Should always be Self
§

impl<T> ServiceExt for T

§

fn propagate_header(self, header: HeaderName) -> PropagateHeader<Self>
where Self: Sized,

Propagate a header from the request to the response. Read more
§

fn add_extension<T>(self, value: T) -> AddExtension<Self, T>
where Self: Sized,

Add some shareable value to request extensions. Read more
§

fn map_request_body<F>(self, f: F) -> MapRequestBody<Self, F>
where Self: Sized,

Apply a transformation to the request body. Read more
§

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

Apply a transformation to the response body. Read more
§

fn compression(self) -> Compression<Self>
where Self: Sized,

Compresses response bodies. Read more
§

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

Decompress response bodies. Read more
§

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

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

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

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

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

Follow redirect resposes using the Standard policy. Read more
§

fn sensitive_headers( self, headers: impl IntoIterator<Item = HeaderName>, ) -> SetSensitiveRequestHeaders<SetSensitiveResponseHeaders<Self>>
where Self: Sized,

Mark headers as sensitive on both requests and responses. Read more
§

fn sensitive_request_headers( self, headers: impl IntoIterator<Item = HeaderName>, ) -> SetSensitiveRequestHeaders<Self>
where Self: Sized,

Mark headers as sensitive on requests. Read more
§

fn sensitive_response_headers( self, headers: impl IntoIterator<Item = HeaderName>, ) -> SetSensitiveResponseHeaders<Self>
where Self: Sized,

Mark headers as sensitive on responses. Read more
§

fn override_request_header<M>( self, header_name: HeaderName, make: M, ) -> SetRequestHeader<Self, M>
where Self: Sized,

Insert a header into the request. Read more
§

fn append_request_header<M>( self, header_name: HeaderName, make: M, ) -> SetRequestHeader<Self, M>
where Self: Sized,

Append a header into the request. Read more
§

fn insert_request_header_if_not_present<M>( self, header_name: HeaderName, make: M, ) -> SetRequestHeader<Self, M>
where Self: Sized,

Insert a header into the request, if the header is not already present. Read more
§

fn override_response_header<M>( self, header_name: HeaderName, make: M, ) -> SetResponseHeader<Self, M>
where Self: Sized,

Insert a header into the response. Read more
§

fn append_response_header<M>( self, header_name: HeaderName, make: M, ) -> SetResponseHeader<Self, M>
where Self: Sized,

Append a header into the response. Read more
§

fn insert_response_header_if_not_present<M>( self, header_name: HeaderName, make: M, ) -> SetResponseHeader<Self, M>
where Self: Sized,

Insert a header into the response, if the header is not already present. Read more
§

fn set_request_id<M>( self, header_name: HeaderName, make_request_id: M, ) -> SetRequestId<Self, M>
where Self: Sized, M: MakeRequestId,

Add request id header and extension. Read more
§

fn set_x_request_id<M>(self, make_request_id: M) -> SetRequestId<Self, M>
where Self: Sized, M: MakeRequestId,

Add request id header and extension, using x-request-id as the header name. Read more
§

fn propagate_request_id( self, header_name: HeaderName, ) -> PropagateRequestId<Self>
where Self: Sized,

Propgate request ids from requests to responses. Read more
§

fn propagate_x_request_id(self) -> PropagateRequestId<Self>
where Self: Sized,

Propgate request ids from requests to responses, using x-request-id as the header name. Read more
§

fn catch_panic(self) -> CatchPanic<Self, DefaultResponseForPanic>
where Self: Sized,

Catch panics and convert them into 500 Internal Server responses. Read more
§

fn request_body_limit(self, limit: usize) -> RequestBodyLimit<Self>
where Self: Sized,

Intercept requests with over-sized payloads and convert them into 413 Payload Too Large responses. Read more
§

fn trim_trailing_slash(self) -> NormalizePath<Self>
where Self: Sized,

Remove trailing slashes from paths. Read more
§

fn append_trailing_slash(self) -> NormalizePath<Self>
where Self: Sized,

Append trailing slash to paths. Read more
§

impl<SS, SP> SupersetOf<SS> for SP
where SS: SubsetOf<SP>,

§

fn to_subset(&self) -> Option<SS>

The inverse inclusion map: attempts to construct self from the equivalent element of its superset. Read more
§

fn is_in_subset(&self) -> bool

Checks if self is actually part of its subset T (and can be converted to it).
§

fn to_subset_unchecked(&self) -> SS

Use with care! Same as self.to_subset but without any property checks. Always succeeds.
§

fn from_subset(element: &SS) -> SP

The inclusion map: converts self to the equivalent element of its superset.
§

impl<T> Tap for T

§

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

Immutable access to a value. Read more
§

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

Mutable access to a value. Read more
§

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
§

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
§

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
§

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
§

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
§

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
§

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

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

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

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

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

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

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

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

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

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

impl<T> TryConv for T

§

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

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

§

fn vzip(self) -> V

§

impl<T> WithSubscriber for T

§

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
§

fn with_current_subscriber(self) -> WithDispatch<Self>

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

impl<G1, G2> Within<G2> for G1
where G2: Contains<G1>,

§

fn is_within(&self, b: &G2) -> bool

§

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

§

impl<T> ErasedDestructor for T
where T: 'static,

§

impl<T> Fruit for T
where T: Send + Downcast,

§

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