Uses of Package
org.apache.flink.runtime.asyncprocessing
-
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.runtime.asyncprocessing Class Description AsyncExecutionController The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies.AsyncExecutionController.SwitchContextListener A listener listens the key context switch.EpochManager.Epoch All inputs are segment into distinct epochs, marked by the arrival of non-record inputs.EpochManager.ParallelMode This enum defines whether parallel execution between epochs is allowed.RecordContext A context that preserves the necessary variables required by each operation, all operations for one record will share the same element context.RecordContext.DisposerRunner ReferenceCounted An object that can be reference counted, the internal resource would be released when the reference count reaches zero.StateExecutor Executor for executing batchStateRequests.StateRequest A request encapsulates the necessary data to perform a state request.StateRequestContainer A container which is used to holdStateRequests.StateRequestHandler The handler which can processStateRequest.StateRequestType The type of processing request forStatefrom **users' perspective**. -
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.runtime.asyncprocessing.operators Class Description AsyncExecutionController The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies.RecordContext A context that preserves the necessary variables required by each operation, all operations for one record will share the same element context. -
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.runtime.state Class Description AsyncExecutionController.SwitchContextListener A listener listens the key context switch.RecordContext A context that preserves the necessary variables required by each operation, all operations for one record will share the same element context.StateExecutor Executor for executing batchStateRequests.StateRequestHandler The handler which can processStateRequest. -
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.runtime.state.v2 Class Description StateRequestHandler The handler which can processStateRequest.StateRequestType The type of processing request forStatefrom **users' perspective**. -
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.runtime.state.v2.adaptor Class Description AsyncExecutionController.SwitchContextListener A listener listens the key context switch.RecordContext A context that preserves the necessary variables required by each operation, all operations for one record will share the same element context.StateExecutor Executor for executing batchStateRequests.StateRequestHandler The handler which can processStateRequest. -
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.streaming.api.operators Class Description AsyncExecutionController The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies. -
Classes in org.apache.flink.runtime.asyncprocessing used by org.apache.flink.streaming.api.operators.sorted.state Class Description AsyncExecutionController The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies.