Uses of Interface
org.apache.flink.api.common.operators.MailboxExecutor
-
-
Uses of MailboxExecutor in org.apache.flink.api.connector.sink2
Methods in org.apache.flink.api.connector.sink2 that return MailboxExecutor Modifier and Type Method Description MailboxExecutor
WriterInitContext. getMailboxExecutor()
Returns the mailbox executor that allows to executeRunnable
s inside the task thread in between record processing. -
Uses of MailboxExecutor in org.apache.flink.changelog.fs
Methods in org.apache.flink.changelog.fs with parameters of type MailboxExecutor Modifier and Type Method Description org.apache.flink.changelog.fs.FsStateChangelogWriter
FsStateChangelogStorage. createWriter(String operatorID, KeyGroupRange keyGroupRange, MailboxExecutor mailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.runtime.asyncprocessing
Constructors in org.apache.flink.runtime.asyncprocessing with parameters of type MailboxExecutor Constructor Description AsyncExecutionController(MailboxExecutor mailboxExecutor, StateFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, StateExecutor stateExecutor, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener)
-
Uses of MailboxExecutor in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution that return MailboxExecutor Modifier and Type Method Description default MailboxExecutor
Environment. getMainMailboxExecutor()
Methods in org.apache.flink.runtime.execution with parameters of type MailboxExecutor Modifier and Type Method Description default void
Environment. setMainMailboxExecutor(MailboxExecutor mainMailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog with parameters of type MailboxExecutor Modifier and Type Method Description StateChangelogWriter<Handle>
StateChangelogStorage. createWriter(String operatorID, KeyGroupRange keyGroupRange, MailboxExecutor mailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory with parameters of type MailboxExecutor Modifier and Type Method Description org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogWriter
InMemoryStateChangelogStorage. createWriter(String operatorID, KeyGroupRange keyGroupRange, MailboxExecutor mailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return MailboxExecutor Modifier and Type Method Description MailboxExecutor
RuntimeEnvironment. getMainMailboxExecutor()
Methods in org.apache.flink.runtime.taskmanager with parameters of type MailboxExecutor Modifier and Type Method Description void
RuntimeEnvironment. setMainMailboxExecutor(MailboxExecutor mainMailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.state.common
Constructors in org.apache.flink.state.common with parameters of type MailboxExecutor Constructor Description PeriodicMaterializationManager(MailboxExecutor mailboxExecutor, ExecutorService asyncOperationsThreadPool, String subtaskName, AsyncExceptionHandler asyncExceptionHandler, PeriodicMaterializationManager.MaterializationTarget target, ChangelogMaterializationMetricGroup metricGroup, boolean isPeriodicMaterializeEnabled, long periodicMaterializeDelay, int allowedNumberOfFailures, String operatorSubtaskId)
-
Uses of MailboxExecutor in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return MailboxExecutor Modifier and Type Method Description protected MailboxExecutor
AbstractStreamOperatorFactory. getMailboxExecutor()
Provides the mailbox executor iff this factory implementsYieldingOperatorFactory
.MailboxExecutor
StreamOperatorParameters. getMailboxExecutor()
Methods in org.apache.flink.streaming.api.operators with parameters of type MailboxExecutor Modifier and Type Method Description void
AbstractStreamOperator. setMailboxExecutor(MailboxExecutor mailboxExecutor)
void
AbstractStreamOperatorFactory. setMailboxExecutor(MailboxExecutor mailboxExecutor)
void
YieldingOperator. setMailboxExecutor(MailboxExecutor mailboxExecutor)
Constructors in org.apache.flink.streaming.api.operators with parameters of type MailboxExecutor Constructor Description MailboxWatermarkProcessor(Output<StreamRecord<OUT>> output, MailboxExecutor mailboxExecutor, InternalTimeServiceManager<?> internalTimeServiceManager)
StreamOperatorParameters(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output, Supplier<ProcessingTimeService> processingTimeServiceFactory, OperatorEventDispatcher operatorEventDispatcher, MailboxExecutor mailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.streaming.api.operators.async
Constructors in org.apache.flink.streaming.api.operators.async with parameters of type MailboxExecutor Constructor Description AsyncWaitOperator(StreamOperatorParameters<OUT> parameters, AsyncFunction<IN,OUT> asyncFunction, long timeout, int capacity, AsyncDataStream.OutputMode outputMode, AsyncRetryStrategy<OUT> asyncRetryStrategy, ProcessingTimeService processingTimeService, MailboxExecutor mailboxExecutor)
-
Uses of MailboxExecutor in org.apache.flink.streaming.api.operators.legacy
Methods in org.apache.flink.streaming.api.operators.legacy with parameters of type MailboxExecutor Modifier and Type Method Description void
YieldingOperatorFactory. setMailboxExecutor(MailboxExecutor mailboxExecutor)
Deprecated. -
Uses of MailboxExecutor in org.apache.flink.streaming.runtime.io.checkpointing
Methods in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type MailboxExecutor Modifier and Type Method Description static CheckpointBarrierHandler
InputProcessorUtil. createCheckpointBarrierHandler(CheckpointableTask toNotifyOnCheckpoint, StreamConfig config, SubtaskCheckpointCoordinator checkpointCoordinator, String taskName, List<IndexedInputGate>[] inputGates, List<StreamTaskSourceInput<?>> sourceInputs, MailboxExecutor mailboxExecutor, TimerService timerService)
static CheckpointedInputGate[]
InputProcessorUtil. createCheckpointedMultipleInputGate(MailboxExecutor mailboxExecutor, List<IndexedInputGate>[] inputGates, TaskIOMetricGroup taskIOMetricGroup, CheckpointBarrierHandler barrierHandler, StreamConfig config)
static BarrierAlignmentUtil.DelayableTimer
BarrierAlignmentUtil. createRegisterTimerCallback(MailboxExecutor mailboxExecutor, TimerService timerService)
Constructors in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type MailboxExecutor Constructor Description CheckpointedInputGate(InputGate inputGate, CheckpointBarrierHandler barrierHandler, MailboxExecutor mailboxExecutor)
Creates a new checkpoint stream aligner.CheckpointedInputGate(InputGate inputGate, CheckpointBarrierHandler barrierHandler, MailboxExecutor mailboxExecutor, UpstreamRecoveryTracker upstreamRecoveryTracker)
-
Uses of MailboxExecutor in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type MailboxExecutor Modifier and Type Method Description ProcessingTimeService
ProcessingTimeServiceFactory. createProcessingTimeService(MailboxExecutor mailboxExecutor)
Creates a new processing time service with the mailbox executor. -
Uses of MailboxExecutor in org.apache.flink.streaming.runtime.tasks.mailbox
Classes in org.apache.flink.streaming.runtime.tasks.mailbox that implement MailboxExecutor Modifier and Type Class Description class
MailboxExecutorImpl
Implementation of an executor service build around a mailbox-based execution model.Methods in org.apache.flink.streaming.runtime.tasks.mailbox that return MailboxExecutor Modifier and Type Method Description MailboxExecutor
MailboxExecutorFactory. createExecutor(int priority)
Creates a new executor for the given priority.MailboxExecutor
MailboxProcessor. getMailboxExecutor(int priority)
Returns an executor service facade to submit actions to the mailbox.MailboxExecutor
MailboxProcessor. getMainMailboxExecutor()
Methods in org.apache.flink.streaming.runtime.tasks.mailbox with parameters of type MailboxExecutor Modifier and Type Method Description void
MailboxMetricsController. setupLatencyMeasurement(TimerService timerService, MailboxExecutor mailboxExecutor)
Sets up latency measurement with requiredTimerService
andMailboxExecutor
.
-