Interface | Description |
---|---|
PushingAsyncDataInput<T> |
The variant of
PullingAsyncDataInput that is defined for handling both network input and
source input in a unified way via PushingAsyncDataInput.emitNext(DataOutput) instead of returning Optional.empty() via PullingAsyncDataInput.pollNext() . |
PushingAsyncDataInput.DataOutput<T> |
Basic data output interface used in emitting the next element from data input.
|
RecoverableStreamTaskInput<T> |
A
StreamTaskInput used during recovery of in-flight data. |
StreamInputProcessor |
Interface for processing records by
StreamTask . |
StreamTaskInput<T> |
Basic interface for inputs of stream operators.
|
Class | Description |
---|---|
AbstractStreamTaskNetworkInput<T,R extends org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer<org.apache.flink.runtime.plugable.DeserializationDelegate<StreamElement>>> |
Base class for network-based StreamTaskInput where each channel has a designated
RecordDeserializer for spanning records. |
BlockingQueueBroker |
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams. |
FinishedDataOutput<IN> |
An empty
PushingAsyncDataInput.DataOutput which is used by StreamOneInputProcessor once an DataInputStatus.END_OF_DATA is 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 in
StreamMultipleInputProcessor . |
RecordProcessorUtils |
Utility class for creating record processor for
Input StreamOperator . |
RecordWriterOutput<OUT> |
Implementation of
Output that sends data using a RecordWriter . |
StreamMultipleInputProcessor |
Input processor for
MultipleInputStreamOperator . |
StreamMultipleInputProcessorFactory |
A factory for
StreamMultipleInputProcessor . |
StreamOneInputProcessor<IN> |
Input reader for
OneInputStreamTask . |
StreamTaskExternallyInducedSourceInput<T> |
A subclass of
StreamTaskSourceInput for ExternallyInducedSourceReader . |
StreamTaskNetworkInput<T> |
Implementation of
StreamTaskInput that wraps an input from network taken from CheckpointedInputGate . |
StreamTaskNetworkInputFactory |
Factory for
StreamTaskNetworkInput and RescalingStreamTaskNetworkInput . |
StreamTaskSourceInput<T> |
Implementation of
StreamTaskInput that reads data from the SourceOperator and
returns the DataInputStatus to indicate whether the source state is available,
unavailable or finished. |
StreamTwoInputProcessorFactory |
A factory to create
StreamMultipleInputProcessor for two input case. |
Enum | Description |
---|---|
DataInputStatus |
It is an internal equivalent of
InputStatus that provides
additional non public statuses. |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.