Uses of Interface
org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
-
-
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 classSourceOperator<OUT,SplitT extends org.apache.flink.api.connector.source.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 classMultiInputSortingDataInput<IN,K>An input that wraps an underlying input and sorts the incoming records.classSortingDataInput<T,K>AStreamTaskInputwhich 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 interfaceRecoverableStreamTaskInput<T>AStreamTaskInputused during recovery of in-flight data.interfaceStreamTaskInput<T>Basic interface for inputs of stream operators.Classes in org.apache.flink.streaming.runtime.io that implement PushingAsyncDataInput Modifier and Type Class Description classAbstractStreamTaskNetworkInput<T,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>>Base class for network-based StreamTaskInput where each channel has a designatedRecordDeserializerfor spanning records.classStreamTaskExternallyInducedSourceInput<T>A subclass ofStreamTaskSourceInputforExternallyInducedSourceReader.classStreamTaskNetworkInput<T>Implementation ofStreamTaskInputthat wraps an input from network taken fromCheckpointedInputGate.classStreamTaskSourceInput<T>Implementation ofStreamTaskInputthat reads data from theSourceOperatorand returns theDataInputStatusto 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 classRescalingStreamTaskNetworkInput<T>AStreamTaskNetworkInputimplementation 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 classStreamTaskFinishedOnRestoreSourceInput<T>A special source input implementation that immediately emit END_OF_INPUT.
-