Class ProcessJoinFunction.Context
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
- Enclosing class:
- ProcessJoinFunction<IN1,IN2,OUT>
public abstract class ProcessJoinFunction.Context extends Object
The context that is available during an invocation of#processElement(Object, Object, Context, Collector)
. It gives access to the timestamps of the left element in the joined pair, the right one, and that of the joined pair. In addition, this context allows to emit elements on a side output.
-
-
Constructor Summary
Constructors Constructor Description Context()
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description abstract long
getLeftTimestamp()
abstract long
getRightTimestamp()
abstract long
getTimestamp()
abstract <X> void
output(OutputTag<X> outputTag, X value)
Emits a record to the side output identified by theOutputTag
.
-
-
-
Method Detail
-
getLeftTimestamp
public abstract long getLeftTimestamp()
- Returns:
- The timestamp of the left element of a joined pair
-
getRightTimestamp
public abstract long getRightTimestamp()
- Returns:
- The timestamp of the right element of a joined pair
-
getTimestamp
public abstract long getTimestamp()
- Returns:
- The timestamp of the joined pair.
-
-