Uses of Interface
org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
-
Packages that use PushingAsyncDataInput Package Description org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sort org.apache.flink.streaming.runtime.io org.apache.flink.streaming.runtime.io.recovery org.apache.flink.streaming.runtime.tasks This package contains classes that realize streaming tasks. -
-
Uses of PushingAsyncDataInput in org.apache.flink.streaming.api.operators
Classes in org.apache.flink.streaming.api.operators that implement PushingAsyncDataInput Modifier and Type Class Description class
SourceOperator<OUT,SplitT extends SourceSplit>
Base source operator only used for integrating the source reader which is proposed by FLIP-27. -
Uses of PushingAsyncDataInput in org.apache.flink.streaming.api.operators.sort
Classes in org.apache.flink.streaming.api.operators.sort that implement PushingAsyncDataInput Modifier and Type Class Description class
MultiInputSortingDataInput<IN,K>
An input that wraps an underlying input and sorts the incoming records.class
SortingDataInput<T,K>
AStreamTaskInput
which sorts in the incoming records from a chained input. -
Uses of PushingAsyncDataInput in org.apache.flink.streaming.runtime.io
Subinterfaces of PushingAsyncDataInput in org.apache.flink.streaming.runtime.io Modifier and Type Interface Description interface
RecoverableStreamTaskInput<T>
AStreamTaskInput
used during recovery of in-flight data.interface
StreamTaskInput<T>
Basic interface for inputs of stream operators.Classes in org.apache.flink.streaming.runtime.io that implement PushingAsyncDataInput Modifier and Type Class Description class
AbstractStreamTaskNetworkInput<T,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>>
Base class for network-based StreamTaskInput where each channel has a designatedRecordDeserializer
for spanning records.class
StreamTaskExternallyInducedSourceInput<T>
A subclass ofStreamTaskSourceInput
forExternallyInducedSourceReader
.class
StreamTaskNetworkInput<T>
Implementation ofStreamTaskInput
that wraps an input from network taken fromCheckpointedInputGate
.class
StreamTaskSourceInput<T>
Implementation ofStreamTaskInput
that reads data from theSourceOperator
and returns theDataInputStatus
to indicate whether the source state is available, unavailable or finished. -
Uses of PushingAsyncDataInput in org.apache.flink.streaming.runtime.io.recovery
Classes in org.apache.flink.streaming.runtime.io.recovery that implement PushingAsyncDataInput Modifier and Type Class Description class
RescalingStreamTaskNetworkInput<T>
AStreamTaskNetworkInput
implementation that demultiplexes virtual channels. -
Uses of PushingAsyncDataInput in org.apache.flink.streaming.runtime.tasks
Classes in org.apache.flink.streaming.runtime.tasks that implement PushingAsyncDataInput Modifier and Type Class Description class
StreamTaskFinishedOnRestoreSourceInput<T>
A special source input implementation that immediately emit END_OF_INPUT.
-