Uses of Package
org.apache.flink.streaming.runtime.io
-
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.api.operators Class Description DataInputStatus It is an internal equivalent ofInputStatusthat provides additional non public statuses.PushingAsyncDataInput 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 Basic data output interface used in emitting the next element from data input. -
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.api.operators.sort Class Description DataInputStatus It is an internal equivalent ofInputStatusthat provides additional non public statuses.PushingAsyncDataInput 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 Basic data output interface used in emitting the next element from data input.StreamTaskInput Basic interface for inputs of stream operators. -
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.api.operators.source Class Description PushingAsyncDataInput.DataOutput Basic data output interface used in emitting the next element from data input. -
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.runtime.io Class Description AbstractStreamTaskNetworkInput Base class for network-based StreamTaskInput where each channel has a designatedRecordDeserializerfor spanning records.BlockingQueueBroker Brokerfor theBlockingQueueused inStreamIterationHeadandStreamIterationTailfor implementing feedback streams.DataInputStatus It is an internal equivalent ofInputStatusthat provides additional non public statuses.MultipleInputSelectionHandler This handler is mainly used for selecting the next available input index inStreamMultipleInputProcessor.PushingAsyncDataInput 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 Basic data output interface used in emitting the next element from data input.StreamInputProcessor Interface for processing records byStreamTask.StreamMultipleInputProcessor Input processor forMultipleInputStreamOperator.StreamOneInputProcessor Input reader forOneInputStreamTask.StreamTaskInput Basic interface for inputs of stream operators.StreamTaskSourceInput Implementation ofStreamTaskInputthat reads data from theSourceOperatorand returns theDataInputStatusto indicate whether the source state is available, unavailable or finished. -
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.runtime.io.recovery Class Description AbstractStreamTaskNetworkInput Base class for network-based StreamTaskInput where each channel has a designatedRecordDeserializerfor spanning records.DataInputStatus It is an internal equivalent ofInputStatusthat provides additional non public statuses.PushingAsyncDataInput 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 Basic data output interface used in emitting the next element from data input.RecoverableStreamTaskInput AStreamTaskInputused during recovery of in-flight data.StreamTaskInput Basic interface for inputs of stream operators. -
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.runtime.tasks Class Description DataInputStatus It is an internal equivalent ofInputStatusthat provides additional non public statuses.PushingAsyncDataInput 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 Basic data output interface used in emitting the next element from data input.RecordWriterOutput Implementation ofOutputthat sends data using aRecordWriter.StreamInputProcessor Interface for processing records byStreamTask.StreamTaskInput Basic interface for inputs of stream operators.StreamTaskSourceInput Implementation ofStreamTaskInputthat reads data from theSourceOperatorand returns theDataInputStatusto indicate whether the source state is available, unavailable or finished. -
Classes in org.apache.flink.streaming.runtime.io used by org.apache.flink.streaming.runtime.watermarkstatus Class Description PushingAsyncDataInput.DataOutput Basic data output interface used in emitting the next element from data input.