Class BinaryHashPartitioner

  • All Implemented Interfaces:
    Serializable, org.apache.flink.runtime.io.network.api.writer.ChannelSelector<org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.table.data.RowData>>>

    public class BinaryHashPartitioner
    extends org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>
    Hash partitioner for BinaryRowData.
    See Also:
    Serialized Form
    • Field Summary

      • Fields inherited from class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner

        numberOfChannels
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData> copy()  
      boolean equals​(Object o)  
      org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper getDownstreamSubtaskStateMapper()  
      int hashCode()  
      boolean isPointwise()  
      int selectChannel​(org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.table.data.RowData>> record)  
      String toString()  
      • Methods inherited from class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner

        disableUnalignedCheckpoints, getUpstreamSubtaskStateMapper, isBroadcast, isSupportsUnalignedCheckpoint, setup
    • Method Detail

      • copy

        public org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData> copy()
        Specified by:
        copy in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>
      • selectChannel

        public int selectChannel​(org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.table.data.RowData>> record)
      • getDownstreamSubtaskStateMapper

        public org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper getDownstreamSubtaskStateMapper()
        Specified by:
        getDownstreamSubtaskStateMapper in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>
      • isPointwise

        public boolean isPointwise()
        Specified by:
        isPointwise in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>
      • equals

        public boolean equals​(Object o)
        Overrides:
        equals in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>
      • hashCode

        public int hashCode()
        Overrides:
        hashCode in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>