Class JoinedStreams.WithWindow<T1,T2,KEY,W extends Window>
- java.lang.Object
-
- org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow<T1,T2,KEY,W>
-
- Type Parameters:
T1
- Type of the elements from the first inputT2
- Type of the elements from the second inputKEY
- Type of the key. This must be the same for both inputsW
- Type ofWindow
on which the join operation works.
- Enclosing class:
- JoinedStreams<T1,T2>
@Public public static class JoinedStreams.WithWindow<T1,T2,KEY,W extends Window> extends Object
A join operation that hasKeySelectors
defined for both inputs as well as aWindowAssigner
.
-
-
Constructor Summary
Constructors Modifier Constructor Description protected
WithWindow(DataStream<T1> input1, DataStream<T2> input2, KeySelector<T1,KEY> keySelector1, KeySelector<T2,KEY> keySelector2, TypeInformation<KEY> keyType, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner, Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger, Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor, Duration allowedLateness)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description JoinedStreams.WithWindow<T1,T2,KEY,W>
allowedLateness(Duration newLateness)
Sets the time by which elements are allowed to be late.<T> SingleOutputStreamOperator<T>
apply(FlatJoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.<T> SingleOutputStreamOperator<T>
apply(FlatJoinFunction<T1,T2,T> function, TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.<T> SingleOutputStreamOperator<T>
apply(JoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.<T> SingleOutputStreamOperator<T>
apply(JoinFunction<T1,T2,T> function, TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.JoinedStreams.WithWindow<T1,T2,KEY,W>
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newEvictor)
Sets theEvictor
that should be used to evict elements from a window before emission.JoinedStreams.WithWindow<T1,T2,KEY,W>
trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newTrigger)
Sets theTrigger
that should be used to trigger window emission.
-
-
-
Constructor Detail
-
WithWindow
@PublicEvolving protected WithWindow(DataStream<T1> input1, DataStream<T2> input2, KeySelector<T1,KEY> keySelector1, KeySelector<T2,KEY> keySelector2, TypeInformation<KEY> keyType, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner, Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger, Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor, @Nullable Duration allowedLateness)
-
-
Method Detail
-
trigger
@PublicEvolving public JoinedStreams.WithWindow<T1,T2,KEY,W> trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newTrigger)
Sets theTrigger
that should be used to trigger window emission.
-
evictor
@PublicEvolving public JoinedStreams.WithWindow<T1,T2,KEY,W> evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newEvictor)
Sets theEvictor
that should be used to evict elements from a window before emission.Note: When using an evictor window performance will degrade significantly, since pre-aggregation of window results cannot be used.
-
allowedLateness
@PublicEvolving public JoinedStreams.WithWindow<T1,T2,KEY,W> allowedLateness(@Nullable Duration newLateness)
Sets the time by which elements are allowed to be late.- See Also:
WindowedStream.allowedLateness(Duration)
-
apply
public <T> SingleOutputStreamOperator<T> apply(JoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
-
apply
public <T> SingleOutputStreamOperator<T> apply(FlatJoinFunction<T1,T2,T> function, TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
-
apply
public <T> SingleOutputStreamOperator<T> apply(FlatJoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
-
apply
public <T> SingleOutputStreamOperator<T> apply(JoinFunction<T1,T2,T> function, TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
-
-