See: Description
Interface | Description |
---|---|
AsyncExceptionHandler |
An interface marking a task as capable of handling exceptions thrown
by different threads, other than the one executing the task itself.
|
CheckpointExceptionHandler |
Handler for exceptions that happen on checkpointing.
|
OperatorChain.WatermarkGaugeExposingOutput<T> |
An
Output that measures the last emitted watermark with a WatermarkGauge . |
ProcessingTimeCallback |
Interface for processing-time callbacks that can be registered at a
ProcessingTimeService . |
Class | Description |
---|---|
CheckpointExceptionHandlerFactory |
This factory produces
CheckpointExceptionHandler instances that handle exceptions during checkpointing in a
StreamTask . |
OneInputStreamTask<IN,OUT> |
A
StreamTask for executing a OneInputStreamOperator . |
OperatorChain<OUT,OP extends StreamOperator<OUT>> |
The
OperatorChain contains all operators that are executed as one chain within a single
StreamTask . |
ProcessingTimeService |
Defines the current processing time and handles all related actions,
such as register timers for tasks to be executed in the future.
|
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> |
StreamTask for executing a StreamSource . |
StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> |
Stoppable task for executing stoppable streaming sources.
|
StreamIterationHead<OUT> |
A special
StreamTask that is used for executing feedback edges. |
StreamIterationTail<IN> |
A special
StreamTask that is used for executing feedback edges. |
StreamTask<OUT,OP extends StreamOperator<OUT>> |
Base class for all streaming tasks.
|
StreamTask.AsyncCheckpointRunnable |
This runnable executes the asynchronous parts of all involved backend snapshots for the subtask.
|
SystemProcessingTimeService |
A
ProcessingTimeService which assigns as current processing time the result of calling
System.currentTimeMillis() and registers timers using a ScheduledThreadPoolExecutor . |
TestProcessingTimeService |
This is a
ProcessingTimeService used strictly for testing the
processing time functionality. |
TwoInputStreamTask<IN1,IN2,OUT> |
A
StreamTask for executing a TwoInputStreamOperator . |
Exception | Description |
---|---|
AsynchronousException |
An exception for wrapping exceptions that are thrown by an operator in threads other than the
main compute thread of that operator.
|
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 |
RuntimeException for wrapping exceptions that are thrown in the timer callback of
the timer service in StreamTask . |
The tasks merely set up the distributed stream coordination and the checkpointing. Internally, the tasks create one or more operators, perform the stream transformations.
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.