Class RowDataCustomStreamPartitioner

  • 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 RowDataCustomStreamPartitioner
    extends org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<org.apache.flink.table.data.RowData>
    The partitioner used to partition row data by the connector's custom logic.
    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()  
      org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper getDownstreamSubtaskStateMapper()  
      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, equals, getUpstreamSubtaskStateMapper, hashCode, isBroadcast, isSupportsUnalignedCheckpoint, setup
    • Constructor Detail

      • RowDataCustomStreamPartitioner

        public RowDataCustomStreamPartitioner​(org.apache.flink.table.connector.source.abilities.SupportsLookupCustomShuffle.InputDataPartitioner partitioner,
                                              RowDataKeySelector keySelector)
    • Method Detail

      • selectChannel

        public int selectChannel​(org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.table.data.RowData>> record)
      • 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>
      • 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>