Package org.apache.flink.streaming.runtime.io
-
Interface Summary Interface Description PushingAsyncDataInput<T> The variant ofPullingAsyncDataInput
that is defined for handling both network input and source input in a unified way viaPushingAsyncDataInput.emitNext(DataOutput)
instead of returningOptional.empty()
viaPullingAsyncDataInput.pollNext()
.PushingAsyncDataInput.DataOutput<T> Basic data output interface used in emitting the next element from data input.RecoverableStreamTaskInput<T> AStreamTaskInput
used during recovery of in-flight data.StreamInputProcessor Interface for processing records byStreamTask
.StreamTaskInput<T> Basic interface for inputs of stream operators. -
Class Summary Class Description AbstractStreamTaskNetworkInput<T,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>> Base class for network-based StreamTaskInput where each channel has a designatedRecordDeserializer
for spanning records.BlockingQueueBroker Broker
for theBlockingQueue
used inStreamIterationHead
andStreamIterationTail
for implementing feedback streams.FinishedDataOutput<IN> An emptyPushingAsyncDataInput.DataOutput
which is used byStreamOneInputProcessor
once anDataInputStatus.END_OF_DATA
is received.InputGateUtil Utility for dealing with input gates.MultipleFuturesAvailabilityHelper This class is semi-thread safe.MultipleInputSelectionHandler This handler is mainly used for selecting the next available input index inStreamMultipleInputProcessor
.RecordAttributesCombiner RecordAttributesValve combine RecordAttributes from different input channels.RecordProcessorUtils Utility class for creating record processor forInput
StreamOperator
.RecordWriterOutput<OUT> Implementation ofOutput
that sends data using aRecordWriter
.StreamMultipleInputProcessor Input processor forMultipleInputStreamOperator
.StreamMultipleInputProcessorFactory A factory forStreamMultipleInputProcessor
.StreamOneInputProcessor<IN> Input reader forOneInputStreamTask
.StreamTaskExternallyInducedSourceInput<T> A subclass ofStreamTaskSourceInput
forExternallyInducedSourceReader
.StreamTaskNetworkInput<T> Implementation ofStreamTaskInput
that wraps an input from network taken fromCheckpointedInputGate
.StreamTaskNetworkInputFactory Factory forStreamTaskNetworkInput
andRescalingStreamTaskNetworkInput
.StreamTaskSourceInput<T> Implementation ofStreamTaskInput
that reads data from theSourceOperator
and returns theDataInputStatus
to indicate whether the source state is available, unavailable or finished.StreamTwoInputProcessorFactory A factory to createStreamMultipleInputProcessor
for two input case. -
Enum Summary Enum Description DataInputStatus It is an internal equivalent ofInputStatus
that provides additional non public statuses.