Uses of Class
org.apache.flink.streaming.api.functions.ProcessFunction
-
Packages that use ProcessFunction Package Description org.apache.flink.streaming.api.datastream org.apache.flink.streaming.api.operators -
-
Uses of ProcessFunction in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream with parameters of type ProcessFunction Modifier and Type Method Description <R> SingleOutputStreamOperator<R>
DataStream. process(ProcessFunction<T,R> processFunction)
Applies the givenProcessFunction
on the input stream, thereby creating a transformed output stream.<R> SingleOutputStreamOperator<R>
DataStream. process(ProcessFunction<T,R> processFunction, org.apache.flink.api.common.typeinfo.TypeInformation<R> outputType)
Applies the givenProcessFunction
on the input stream, thereby creating a transformed output stream. -
Uses of ProcessFunction in org.apache.flink.streaming.api.operators
Constructors in org.apache.flink.streaming.api.operators with parameters of type ProcessFunction Constructor Description LegacyKeyedProcessOperator(ProcessFunction<IN,OUT> function)
Deprecated.ProcessOperator(ProcessFunction<IN,OUT> function)
-