Interface | Description |
---|---|
PushingAsyncDataInput<T> |
The variant of
PullingAsyncDataInput that is defined for handling both network input and
source input in a unified way via PushingAsyncDataInput.emitNext(DataOutput) instead of returning Optional.empty() via PullingAsyncDataInput.pollNext() . |
PushingAsyncDataInput.DataOutput<T> |
Basic data output interface used in emitting the next element from data input.
|
StreamInputProcessor |
Interface for processing records by
StreamTask . |
StreamTaskInput<T> |
Basic interface for inputs of stream operators.
|
Class | Description |
---|---|
AbstractDataOutput<T> |
Base class for all data outputs.
|
BlockingQueueBroker |
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams. |
CheckpointBarrierAligner |
CheckpointBarrierAligner keep tracks of received CheckpointBarrier on given
channels and controls the alignment, by deciding which channels should be blocked and when to
release blocked channels. |
CheckpointBarrierHandler |
The
CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input
channels. |
CheckpointBarrierTracker |
The
CheckpointBarrierTracker keeps track of what checkpoint barriers have been received
from which input channels. |
CheckpointBarrierUnaligner |
CheckpointBarrierUnaligner is used for triggering checkpoint while reading the first
barrier and keeping track of the number of received barriers and consumed barriers. |
CheckpointedInputGate |
The
CheckpointedInputGate uses CheckpointBarrierHandler to handle incoming CheckpointBarrier from the InputGate . |
InputGateUtil |
Utility for dealing with input gates.
|
InputProcessorUtil |
Utility for creating
CheckpointedInputGate based on checkpoint mode for StreamOneInputProcessor and StreamTwoInputProcessor . |
MultipleInputSelectionHandler |
This handler is mainly used for selecting the next available input index in
StreamMultipleInputProcessor . |
RecordWriterOutput<OUT> |
Implementation of
Output that sends data using a RecordWriter . |
StreamMultipleInputProcessor |
Input processor for
MultipleInputStreamOperator . |
StreamOneInputProcessor<IN> |
Input reader for
OneInputStreamTask . |
StreamTaskExternallyInducedSourceInput<T> |
A subclass of
StreamTaskSourceInput for ExternallyInducedSourceReader . |
StreamTaskNetworkInput<T> |
Implementation of
StreamTaskInput that wraps an input from network taken from CheckpointedInputGate . |
StreamTaskSourceInput<T> |
Implementation of
StreamTaskInput that reads data from the SourceOperator and
returns the InputStatus to indicate whether the source state is available, unavailable or
finished. |
StreamTwoInputProcessor<IN1,IN2> |
Input reader for
TwoInputStreamTask . |
TwoInputSelectionHandler |
This handler is mainly used for selecting the next available input index in
StreamTwoInputProcessor . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.