Package | Description |
---|---|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.operators |
Modifier and Type | Method and Description |
---|---|
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction)
Applies the given
ProcessFunction on the input stream, thereby creating a transformed
output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<R> outputType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<R> outputType)
Applies the given
ProcessFunction on the input stream, thereby creating a transformed
output stream. |
Constructor and Description |
---|
LegacyKeyedProcessOperator(ProcessFunction<IN,OUT> function)
Deprecated.
|
ProcessOperator(ProcessFunction<IN,OUT> function) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.