Uses of Class
org.apache.flink.streaming.api.functions.KeyedProcessFunction
-
-
Uses of KeyedProcessFunction in org.apache.flink.runtime.asyncprocessing.functions
Subclasses of KeyedProcessFunction in org.apache.flink.runtime.asyncprocessing.functions Modifier and Type Class Description class
DeclaringAsyncKeyedProcessFunction<K,I,O>
A keyed function that processes elements of a stream. -
Uses of KeyedProcessFunction in org.apache.flink.runtime.asyncprocessing.operators
Constructors in org.apache.flink.runtime.asyncprocessing.operators with parameters of type KeyedProcessFunction Constructor Description AsyncKeyedProcessOperator(KeyedProcessFunction<K,IN,OUT> function)
-
Uses of KeyedProcessFunction in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream with parameters of type KeyedProcessFunction Modifier and Type Method Description <R> SingleOutputStreamOperator<R>
KeyedStream. process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction)
Applies the givenKeyedProcessFunction
on the input stream, thereby creating a transformed output stream.<R> SingleOutputStreamOperator<R>
KeyedStream. process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction, org.apache.flink.api.common.typeinfo.TypeInformation<R> outputType)
Applies the givenKeyedProcessFunction
on the input stream, thereby creating a transformed output stream. -
Uses of KeyedProcessFunction in org.apache.flink.streaming.api.operators
Constructors in org.apache.flink.streaming.api.operators with parameters of type KeyedProcessFunction Constructor Description KeyedProcessOperator(KeyedProcessFunction<K,IN,OUT> function)
-