Class IdPartitioner

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.Partitioner<Integer>

    @Internal
    public class IdPartitioner
    extends Object
    implements org.apache.flink.api.common.functions.Partitioner<Integer>
    Partitioner that partitions by id.
    See Also:
    Serialized Form
    • Constructor Detail

      • IdPartitioner

        public IdPartitioner()
    • Method Detail

      • partition

        public int partition​(Integer key,
                             int numPartitions)
        Specified by:
        partition in interface org.apache.flink.api.common.functions.Partitioner<Integer>