Class JoinedStreams.Where<KEY>
- java.lang.Object
-
- org.apache.flink.streaming.api.datastream.JoinedStreams.Where<KEY>
-
- Type Parameters:
KEY- The type of the key.
- Enclosing class:
- JoinedStreams<T1,T2>
@Public public class JoinedStreams.Where<KEY> extends Object
Joined streams that have the key for one side defined.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description classJoinedStreams.Where.EqualToA join operation that hasKeySelectorsdefined for both inputs.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description JoinedStreams.Where.EqualToequalTo(org.apache.flink.api.java.functions.KeySelector<T2,KEY> keySelector)Specifies aKeySelectorfor elements from the second input.JoinedStreams.Where.EqualToequalTo(org.apache.flink.api.java.functions.KeySelector<T2,KEY> keySelector, org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType)Specifies aKeySelectorfor elements from the second input with explicit type information for the key type.
-
-
-
Method Detail
-
equalTo
public JoinedStreams.Where.EqualTo equalTo(org.apache.flink.api.java.functions.KeySelector<T2,KEY> keySelector)
Specifies aKeySelectorfor elements from the second input.- Parameters:
keySelector- The KeySelector to be used for extracting the second input's key for partitioning.
-
equalTo
public JoinedStreams.Where.EqualTo equalTo(org.apache.flink.api.java.functions.KeySelector<T2,KEY> keySelector, org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType)
Specifies aKeySelectorfor elements from the second input with explicit type information for the key type.- Parameters:
keySelector- The KeySelector to be used for extracting the second input's key for partitioning.keyType- The type information describing the key type.
-
-