Uses of Interface
org.apache.flink.streaming.runtime.io.StreamTaskInput
-
-
Uses of StreamTaskInput in org.apache.flink.streaming.api.operators.sort
Classes in org.apache.flink.streaming.api.operators.sort that implement StreamTaskInput 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.Methods in org.apache.flink.streaming.api.operators.sort that return StreamTaskInput Modifier and Type Method Description StreamTaskInput<?>[]MultiInputSortingDataInput.SelectableSortingInputs. getPassThroughInputs()StreamTaskInput<?>[]MultiInputSortingDataInput.SelectableSortingInputs. getSortedInputs()Methods in org.apache.flink.streaming.api.operators.sort with parameters of type StreamTaskInput Modifier and Type Method Description static <K> MultiInputSortingDataInput.SelectableSortingInputsMultiInputSortingDataInput. wrapInputs(TaskInvokable containingTask, StreamTaskInput<Object>[] sortingInputs, org.apache.flink.api.java.functions.KeySelector<Object,K>[] keySelectors, org.apache.flink.api.common.typeutils.TypeSerializer<Object>[] inputSerializers, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, StreamTaskInput<Object>[] passThroughInputs, MemoryManager memoryManager, IOManager ioManager, boolean objectReuse, double managedMemoryFraction, org.apache.flink.configuration.Configuration taskManagerConfiguration, org.apache.flink.api.common.ExecutionConfig executionConfig)Constructors in org.apache.flink.streaming.api.operators.sort with parameters of type StreamTaskInput Constructor Description SelectableSortingInputs(StreamTaskInput<?>[] sortedInputs, StreamTaskInput<?>[] passThroughInputs, InputSelectable inputSelectable)SortingDataInput(StreamTaskInput<T> wrappedInput, org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, org.apache.flink.api.java.functions.KeySelector<T,K> keySelector, MemoryManager memoryManager, IOManager ioManager, boolean objectReuse, double managedMemoryFraction, org.apache.flink.configuration.Configuration taskManagerConfiguration, TaskInvokable containingTask, org.apache.flink.api.common.ExecutionConfig executionConfig) -
Uses of StreamTaskInput in org.apache.flink.streaming.runtime.io
Subinterfaces of StreamTaskInput in org.apache.flink.streaming.runtime.io Modifier and Type Interface Description interfaceRecoverableStreamTaskInput<T>AStreamTaskInputused during recovery of in-flight data.Classes in org.apache.flink.streaming.runtime.io that implement StreamTaskInput 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.Methods in org.apache.flink.streaming.runtime.io that return StreamTaskInput Modifier and Type Method Description static <T> StreamTaskInput<T>StreamTaskNetworkInputFactory. create(CheckpointedInputGate checkpointedInputGate, org.apache.flink.api.common.typeutils.TypeSerializer<T> inputSerializer, IOManager ioManager, StatusWatermarkValve statusWatermarkValve, int inputIndex, InflightDataRescalingDescriptor rescalingDescriptorinflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, org.apache.flink.api.common.TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords, Set<AbstractInternalWatermarkDeclaration<?>> watermarkDeclarationSet)Factory method forStreamTaskNetworkInputorRescalingStreamTaskNetworkInputdepending onInflightDataRescalingDescriptor.StreamTaskInput<T>RecoverableStreamTaskInput. finishRecovery()Constructors in org.apache.flink.streaming.runtime.io with parameters of type StreamTaskInput Constructor Description StreamOneInputProcessor(StreamTaskInput<IN> input, PushingAsyncDataInput.DataOutput<IN> output, BoundedMultiInput endOfInputAware) -
Uses of StreamTaskInput in org.apache.flink.streaming.runtime.io.recovery
Classes in org.apache.flink.streaming.runtime.io.recovery that implement StreamTaskInput Modifier and Type Class Description classRescalingStreamTaskNetworkInput<T>AStreamTaskNetworkInputimplementation that demultiplexes virtual channels.Methods in org.apache.flink.streaming.runtime.io.recovery that return StreamTaskInput Modifier and Type Method Description StreamTaskInput<T>RescalingStreamTaskNetworkInput. finishRecovery() -
Uses of StreamTaskInput in org.apache.flink.streaming.runtime.tasks
Classes in org.apache.flink.streaming.runtime.tasks that implement StreamTaskInput Modifier and Type Class Description classStreamTaskFinishedOnRestoreSourceInput<T>A special source input implementation that immediately emit END_OF_INPUT.
-