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 |
---|---|
AbstractDataOutput<T> |
Base class for all data outputs.
|
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. |
InputGateUtil |
Utility for dealing with input gates.
|
MultipleInputSelectionHandler |
This handler is mainly used for selecting the next available input index in
StreamMultipleInputProcessor . |
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 InputStatus to indicate whether the source state is available, unavailable or
finished. |
StreamTwoInputProcessor<IN1,IN2> |
Input reader for
TwoInputStreamTask . |
StreamTwoInputProcessorFactory |
A factory for
StreamTwoInputProcessor . |
TwoInputSelectionHandler |
This handler is mainly used for selecting the next available input index in
StreamTwoInputProcessor . |
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.