Uses of Class
org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
-
Packages that use CoGroupedStreams.Where Package Description org.apache.flink.streaming.api.datastream -
-
Uses of CoGroupedStreams.Where in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream that return CoGroupedStreams.Where Modifier and Type Method Description <KEY> CoGroupedStreams.Where<KEY>
CoGroupedStreams. where(org.apache.flink.api.java.functions.KeySelector<T1,KEY> keySelector)
Specifies aKeySelector
for elements from the first input.<KEY> CoGroupedStreams.Where<KEY>
CoGroupedStreams. 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.
-