Class CoGroupedStreams.Where<KEY>

  • Type Parameters:
    KEY - The type of the key.
    Enclosing class:
    CoGroupedStreams<T1,​T2>

    @Public
    public class CoGroupedStreams.Where<KEY>
    extends Object
    CoGrouped streams that have the key for one side defined.
    • Method Detail

      • equalTo

        public CoGroupedStreams.Where.EqualTo equalTo​(org.apache.flink.api.java.functions.KeySelector<T2,​KEY> keySelector)
        Specifies a KeySelector for elements from the second input.
        Parameters:
        keySelector - The KeySelector to be used for extracting the second input's key for partitioning.
      • equalTo

        public CoGroupedStreams.Where.EqualTo equalTo​(org.apache.flink.api.java.functions.KeySelector<T2,​KEY> keySelector,
                                                      org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType)
        Specifies a KeySelector for elements from the second input with explicit type information for the key type.
        Parameters:
        keySelector - The KeySelector to be used for extracting the key for partitioning.
        keyType - The type information describing the key type.