Uses of Class
org.apache.flink.runtime.asyncprocessing.declare.DeclarationManager
-
-
Uses of DeclarationManager in org.apache.flink.runtime.asyncprocessing
Constructors in org.apache.flink.runtime.asyncprocessing with parameters of type DeclarationManager Constructor Description AsyncExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, AsyncExecutor<REQUEST> asyncExecutor, DeclarationManager declarationManager, EpochManager.ParallelMode epochParallelMode, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
SimpleAsyncExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, ExecutorService asyncThreadPool, DeclarationManager declarationManager, EpochManager.ParallelMode epochParallelMode, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
StateExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, AsyncExecutor<StateRequest<?,?,?,?>> stateExecutor, DeclarationManager declarationManager, EpochManager.ParallelMode epochParallelMode, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
-
Uses of DeclarationManager in org.apache.flink.runtime.asyncprocessing.declare
Constructors in org.apache.flink.runtime.asyncprocessing.declare with parameters of type DeclarationManager Constructor Description DeclarationContext(DeclarationManager manager)
-
Uses of DeclarationManager in org.apache.flink.runtime.asyncprocessing.operators
Fields in org.apache.flink.runtime.asyncprocessing.operators declared as DeclarationManager Modifier and Type Field Description protected DeclarationManager
AbstractAsyncKeyOrderedStreamOperator. declarationManager
protected DeclarationManager
AbstractAsyncStateStreamOperatorV2. declarationManager
Methods in org.apache.flink.runtime.asyncprocessing.operators that return DeclarationManager Modifier and Type Method Description DeclarationManager
AbstractAsyncKeyOrderedStreamOperator. getDeclarationManager()
DeclarationManager
AbstractAsyncStateStreamOperatorV2. getDeclarationManager()
-
Uses of DeclarationManager in org.apache.flink.streaming.runtime.operators.asyncprocessing
Methods in org.apache.flink.streaming.runtime.operators.asyncprocessing that return DeclarationManager Modifier and Type Method Description DeclarationManager
AsyncKeyOrderedProcessingOperator. getDeclarationManager()
Get the declaration manager for user-logic declaring.
-