Interface OneInputStreamProcessFunction<IN,OUT>
-
- All Superinterfaces:
Function
,ProcessFunction
,Serializable
@Experimental public interface OneInputStreamProcessFunction<IN,OUT> extends ProcessFunction
This contains all logical related to process records from single input.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description default void
endInput(NonPartitionedContext<OUT> ctx)
This is a life-cycle method indicates that this function will no longer receive any data from the input.default void
onProcessingTimer(long timestamp, Collector<OUT> output, PartitionedContext ctx)
Callback for processing timer.void
processRecord(IN record, Collector<OUT> output, PartitionedContext ctx)
Process record and emit data throughCollector
.-
Methods inherited from interface org.apache.flink.datastream.api.function.ProcessFunction
close, open, usesStates
-
-
-
-
Method Detail
-
processRecord
void processRecord(IN record, Collector<OUT> output, PartitionedContext ctx) throws Exception
Process record and emit data throughCollector
.- Parameters:
record
- to process.output
- to emit processed records.ctx
- runtime context in which this function is executed.- Throws:
Exception
-
endInput
default void endInput(NonPartitionedContext<OUT> ctx)
This is a life-cycle method indicates that this function will no longer receive any data from the input.- Parameters:
ctx
- the context in which this function is executed.
-
onProcessingTimer
default void onProcessingTimer(long timestamp, Collector<OUT> output, PartitionedContext ctx)
Callback for processing timer.- Parameters:
timestamp
- when this callback is triggered.output
- to emit record.ctx
- runtime context in which this function is executed.
-
-