Uses of Class
org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
-
Uses of AsyncExecutionController in org.apache.flink.runtime.asyncprocessing
Constructors in org.apache.flink.runtime.asyncprocessing with parameters of type AsyncExecutionController Constructor Description EpochManager(AsyncExecutionController<?> aec)
-
Uses of AsyncExecutionController in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators that return AsyncExecutionController Modifier and Type Method Description AsyncExecutionController<?>
AbstractAsyncStateStreamOperatorV2. getAsyncExecutionController()
-
Uses of AsyncExecutionController in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type AsyncExecutionController Modifier and Type Method Description <N> InternalTimerService<N>
InternalTimeServiceManager. getAsyncInternalTimerService(String name, TypeSerializer<K> keySerializer, TypeSerializer<N> namespaceSerializer, Triggerable<K,N> triggerable, AsyncExecutionController<K> asyncExecutionController)
Creates anInternalTimerServiceAsyncImpl
for handling a group of timers identified by the givenname
.<N> InternalTimerService<N>
InternalTimeServiceManagerImpl. getAsyncInternalTimerService(String name, TypeSerializer<K> keySerializer, TypeSerializer<N> namespaceSerializer, Triggerable<K,N> triggerable, AsyncExecutionController<K> asyncExecutionController)
-
Uses of AsyncExecutionController in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type AsyncExecutionController Modifier and Type Method Description <N> InternalTimerService<N>
BatchExecutionInternalTimeServiceManager. getAsyncInternalTimerService(String name, TypeSerializer<K> keySerializer, TypeSerializer<N> namespaceSerializer, Triggerable<K,N> triggerable, AsyncExecutionController<K> asyncExecutionController)
-