Uses of Interface
org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessing
-
-
Uses of AsyncStateProcessing in org.apache.flink.runtime.asyncprocessing.operators
Classes in org.apache.flink.runtime.asyncprocessing.operators that implement AsyncStateProcessing Modifier and Type Class Description class
AbstractAsyncStateStreamOperator<OUT>
This operator is an abstract class that give theAbstractStreamOperator
the ability to performAsyncStateProcessing
.class
AbstractAsyncStateStreamOperatorV2<OUT>
This operator is an abstract class that give theAbstractStreamOperatorV2
the ability to performAsyncStateProcessing
.class
AbstractAsyncStateUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function. -
Uses of AsyncStateProcessing in org.apache.flink.streaming.api.operators
Classes in org.apache.flink.streaming.api.operators that implement AsyncStateProcessing Modifier and Type Class Description class
AbstractInput<IN,OUT>
Base abstract implementation ofInput
interface intended to be used when extendingAbstractStreamOperatorV2
. -
Uses of AsyncStateProcessing in org.apache.flink.streaming.runtime.operators.asyncprocessing
Subinterfaces of AsyncStateProcessing in org.apache.flink.streaming.runtime.operators.asyncprocessing Modifier and Type Interface Description interface
AsyncStateProcessingOperator
A more detailed interface based onAsyncStateProcessing
, which gives the essential methods for an operator to perform async state processing. -
Uses of AsyncStateProcessing in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing
Classes in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing that implement AsyncStateProcessing Modifier and Type Class Description class
AbstractAsyncStateStreamingJoinOperator
Abstract implementation for streaming unbounded Join operator based on async state api, which defines some member fields can be shared between different implementations.class
AsyncStateStreamingJoinOperator
Streaming unbounded Join operator based on async state api, which supports INNER/LEFT/RIGHT/FULL JOIN. -
Uses of AsyncStateProcessing in org.apache.flink.table.runtime.operators.multipleinput.input
Classes in org.apache.flink.table.runtime.operators.multipleinput.input that implement AsyncStateProcessing Modifier and Type Class Description class
FirstInputOfTwoInput
Input
for the first input ofTwoInputStreamOperator
.class
OneInput
class
SecondInputOfTwoInput
Input
for the second input ofTwoInputStreamOperator
.
-