Uses of Class
org.apache.flink.streaming.api.datastream.JoinedStreams.Where
-
Packages that use JoinedStreams.Where Package Description org.apache.flink.streaming.api.datastream -
-
Uses of JoinedStreams.Where in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream that return JoinedStreams.Where Modifier and Type Method Description <KEY> JoinedStreams.Where<KEY>
JoinedStreams. where(org.apache.flink.api.java.functions.KeySelector<T1,KEY> keySelector)
Specifies aKeySelector
for elements from the first input.<KEY> JoinedStreams.Where<KEY>
JoinedStreams. where(org.apache.flink.api.java.functions.KeySelector<T1,KEY> keySelector, org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType)
Specifies aKeySelector
for elements from the first input with explicit type information for the key type.
-