Package org.apache.flink.streaming.runtime.io
-
Interface Summary Interface Description PushingAsyncDataInput<T> The variant ofPullingAsyncDataInputthat 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> AStreamTaskInputused 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 designatedRecordDeserializerfor spanning records.BlockingQueueBroker Brokerfor theBlockingQueueused inStreamIterationHeadandStreamIterationTailfor implementing feedback streams.FinishedDataOutput<IN> An emptyPushingAsyncDataInput.DataOutputwhich is used byStreamOneInputProcessoronce anDataInputStatus.END_OF_DATAis 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 forInputStreamOperator.RecordWriterOutput<OUT> Implementation ofOutputthat sends data using aRecordWriter.StreamMultipleInputProcessor Input processor forMultipleInputStreamOperator.StreamMultipleInputProcessorFactory A factory forStreamMultipleInputProcessor.StreamOneInputProcessor<IN> Input reader forOneInputStreamTask.StreamTaskExternallyInducedSourceInput<T> A subclass ofStreamTaskSourceInputforExternallyInducedSourceReader.StreamTaskNetworkInput<T> Implementation ofStreamTaskInputthat wraps an input from network taken fromCheckpointedInputGate.StreamTaskNetworkInputFactory Factory forStreamTaskNetworkInputandRescalingStreamTaskNetworkInput.StreamTaskSourceInput<T> Implementation ofStreamTaskInputthat reads data from theSourceOperatorand returns theDataInputStatusto indicate whether the source state is available, unavailable or finished.StreamTwoInputProcessorFactory A factory to createStreamMultipleInputProcessorfor two input case. -
Enum Summary Enum Description DataInputStatus It is an internal equivalent ofInputStatusthat provides additional non public statuses.