IN1
- Input type of elements from the first streamIN2
- Input type of elements from the second streamKEY
- The type of the key@PublicEvolving public static class KeyedStream.IntervalJoined<IN1,IN2,KEY> extends Object
Constructor and Description |
---|
IntervalJoined(KeyedStream<IN1,KEY> left,
KeyedStream<IN2,KEY> right,
long lowerBound,
long upperBound,
boolean lowerBoundInclusive,
boolean upperBoundInclusive) |
Modifier and Type | Method and Description |
---|---|
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
lowerBoundExclusive()
Set the lower bound to be exclusive.
|
<OUT> SingleOutputStreamOperator<OUT> |
process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction)
Completes the join operation with the given user function that is executed for each
joined pair of elements.
|
<OUT> SingleOutputStreamOperator<OUT> |
process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType)
Completes the join operation with the given user function that is executed for each
joined pair of elements.
|
KeyedStream.IntervalJoined<IN1,IN2,KEY> |
upperBoundExclusive()
Set the upper bound to be exclusive.
|
public IntervalJoined(KeyedStream<IN1,KEY> left, KeyedStream<IN2,KEY> right, long lowerBound, long upperBound, boolean lowerBoundInclusive, boolean upperBoundInclusive)
@PublicEvolving public KeyedStream.IntervalJoined<IN1,IN2,KEY> upperBoundExclusive()
@PublicEvolving public KeyedStream.IntervalJoined<IN1,IN2,KEY> lowerBoundExclusive()
@PublicEvolving public <OUT> SingleOutputStreamOperator<OUT> process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction)
OUT
- The output type.processJoinFunction
- The user-defined process join function.DataStream
.@PublicEvolving public <OUT> SingleOutputStreamOperator<OUT> process(ProcessJoinFunction<IN1,IN2,OUT> processJoinFunction, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType)
OUT
- The output type.processJoinFunction
- The user-defined process join function.outputType
- The type information for the output type.DataStream
.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.