Package org.apache.flink.streaming.runtime.tasks
-
Interface Summary Interface Description ContainingTaskDetails Details about the operator containing task (such asStreamTask).OutputWithChainingCheck<OUT> This is a wrapper for outputs to check whether the collected record has been emitted to a downstream subtask or to a chained operator.ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceAware Interface forStreamOperatorFactory, which enables stream operators to accessProcessingTimeService.ProcessingTimeServiceFactory A factory for creating processing time services with a givenMailboxExecutor.StreamTask.CanEmitBatchOfRecordsChecker Check whether records can be emitted in batch.StreamTaskActionExecutor StreamTaskCancellationContext Context on theStreamTaskfor figuring out whether it has been cancelled.SubtaskCheckpointCoordinator Coordinates checkpointing-related work for a subtask (i.e.TimerService A common timer service interface with life cycle methods.WatermarkGaugeExposingOutput<T> AnOutputthat measures the last emitted watermark with aWatermarkGauge. -
Class Summary Class Description AbstractTwoInputStreamTask<IN1,IN2,OUT> Abstract class for executing aTwoInputStreamOperator.FinishedOnRestoreInput<IN> A fakeInputfor finished on restore tasks.FinishedOnRestoreMainOperatorOutput<OUT> A fake main operator output that skips all the following operators for finished on restored tasks.FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>> TheOperatorChainthat is used for restoring tasks that areTaskStateManager.isTaskDeployedAsFinished().MultipleInputStreamTask<OUT> AStreamTaskfor executing aMultipleInputStreamOperatorand supporting theMultipleInputStreamOperatorto select input for reading.OneInputStreamTask<IN,OUT> AStreamTaskfor executing aOneInputStreamOperator.OperatorChain<OUT,OP extends StreamOperator<OUT>> TheOperatorChaincontains all operators that are executed as one chain within a singleStreamTask.OperatorChain.ChainedSource Wrapper class to access the chained sources and their's outputs.OperatorEventDispatcherImpl An implementation of theOperatorEventDispatcher.ProcessingTimeServiceUtil Utility for classes that implements theProcessingTimeServiceinterface.RegularOperatorChain<OUT,OP extends StreamOperator<OUT>> A regular non finished on restoreOperatorChain.SourceOperatorStreamTask<T> A subclass ofStreamTaskfor executing theSourceOperator.SourceOperatorStreamTask.AsyncDataOutputToOutput<T> Implementation ofPushingAsyncDataInput.DataOutputthat wraps a specificOutput.SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> Deprecated. This class is based on theSourceFunctionAPI, which is due to be removed.StreamIterationHead<OUT> A specialStreamTaskthat is used for executing feedback edges.StreamIterationTail<IN> A specialStreamTaskthat is used for executing feedback edges.StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>> This class handles the finish, endInput and other related logic of aStreamOperator.StreamTask<OUT,OP extends StreamOperator<OUT>> Base class for all streaming tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor Deprecated. this class should only be used inSourceStreamTaskwhich exposes the checkpoint lock as part of Public API.StreamTaskFinishedOnRestoreSourceInput<T> A special source input implementation that immediately emit END_OF_INPUT.SystemProcessingTimeService ATimerServicewhich assigns as current processing time the result of callingSystem.currentTimeMillis()and registers timers using aScheduledThreadPoolExecutor.TwoInputStreamTask<IN1,IN2,OUT> AStreamTaskfor executing aTwoInputStreamOperatorand supporting theTwoInputStreamOperatorto select input for reading. -
Exception Summary Exception Description ExceptionInChainedOperatorException A special exception that signifies that the cause exception came from a chained operator.StreamTaskException An exception that is thrown by the stream vertices when encountering an illegal condition.TimerException RuntimeExceptionfor wrapping exceptions that are thrown in the timer callback of the timer service inStreamTask.