Interface TwoInputNonBroadcastStreamProcessFunction<IN1,IN2,OUT>
-
- All Superinterfaces:
Function
,ProcessFunction
,Serializable
@Experimental public interface TwoInputNonBroadcastStreamProcessFunction<IN1,IN2,OUT> extends ProcessFunction
This contains all logical related to process records from two non-broadcast input.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description default void
endFirstInput(NonPartitionedContext<OUT> ctx)
This is a life-cycle method indicates that this function will no longer receive any data from the first input.default void
endSecondInput(NonPartitionedContext<OUT> ctx)
This is a life-cycle method indicates that this function will no longer receive any data from the second input.default void
onProcessingTimer(long timestamp, Collector<OUT> output, PartitionedContext ctx)
Callback for processing timer.void
processRecordFromFirstInput(IN1 record, Collector<OUT> output, PartitionedContext ctx)
Process record from the first input and emit data throughCollector
.void
processRecordFromSecondInput(IN2 record, Collector<OUT> output, PartitionedContext ctx)
Process record from the second input and emit data throughCollector
.-
Methods inherited from interface org.apache.flink.datastream.api.function.ProcessFunction
close, open, usesStates
-
-
-
-
Method Detail
-
processRecordFromFirstInput
void processRecordFromFirstInput(IN1 record, Collector<OUT> output, PartitionedContext ctx) throws Exception
Process record from the first input and emit data throughCollector
.- Parameters:
record
- to process.output
- to emit processed records.ctx
- runtime context in which this function is executed.- Throws:
Exception
-
processRecordFromSecondInput
void processRecordFromSecondInput(IN2 record, Collector<OUT> output, PartitionedContext ctx) throws Exception
Process record from the second input and emit data throughCollector
.- Parameters:
record
- to process.output
- to emit processed records.ctx
- runtime context in which this function is executed.- Throws:
Exception
-
endFirstInput
default void endFirstInput(NonPartitionedContext<OUT> ctx)
This is a life-cycle method indicates that this function will no longer receive any data from the first input.- Parameters:
ctx
- the context in which this function is executed.
-
endSecondInput
default void endSecondInput(NonPartitionedContext<OUT> ctx)
This is a life-cycle method indicates that this function will no longer receive any data from the second 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.
-
-