Uses of Class
org.apache.flink.runtime.asyncprocessing.AsyncRequest
-
Packages that use AsyncRequest Package Description org.apache.flink.runtime.asyncprocessing -
-
Uses of AsyncRequest in org.apache.flink.runtime.asyncprocessing
Classes in org.apache.flink.runtime.asyncprocessing with type parameters of type AsyncRequest Modifier and Type Class Description class
AsyncExecutionController<K,REQUEST extends AsyncRequest<?>>
The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies.interface
AsyncExecutor<REQUEST extends AsyncRequest<?>>
Executor for executing batchAsyncRequest
s.interface
AsyncRequestContainer<REQUEST extends AsyncRequest<?>>
A container which is used to holdAsyncRequest
s.Subclasses of AsyncRequest in org.apache.flink.runtime.asyncprocessing Modifier and Type Class Description static class
SimpleAsyncExecutionController.RunnableTask<K,RET>
class
StateRequest<K,N,IN,OUT>
A request encapsulates the necessary data to perform a state request.class
SyncPointRequest<K>
The Sync point request that will be trigger callback once it is allowed to be triggered.Methods in org.apache.flink.runtime.asyncprocessing with parameters of type AsyncRequest Modifier and Type Method Description void
AsyncExecutionController. handleRequest(AsyncRequest<K> request, boolean allowOverdraft)
Submit aAsyncRequest
to this AsyncExecutionController and trigger it if needed.
-