Class RoundRobinPartitioner
- java.lang.Object
- 
- org.apache.kafka.clients.producer.RoundRobinPartitioner
 
- 
- All Implemented Interfaces:
- java.io.Closeable,- java.lang.AutoCloseable,- Partitioner,- Configurable
 
 public class RoundRobinPartitioner extends java.lang.Object implements Partitioner The "Round-Robin" partitioner This partitioning strategy can be used when user wants to distribute the writes to all partitions equally. This is the behaviour regardless of record key hash.
- 
- 
Constructor SummaryConstructors Constructor Description RoundRobinPartitioner()
 - 
Method SummaryAll Methods Instance Methods Concrete Methods Modifier and Type Method Description voidclose()This is called when partitioner is closed.voidconfigure(java.util.Map<java.lang.String,?> configs)Configure this class with the given key-value pairsintpartition(java.lang.String topic, java.lang.Object key, byte[] keyBytes, java.lang.Object value, byte[] valueBytes, Cluster cluster)Compute the partition for the given record.- 
Methods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 - 
Methods inherited from interface org.apache.kafka.clients.producer.PartitioneronNewBatch
 
- 
 
- 
- 
- 
Method Detail- 
configurepublic void configure(java.util.Map<java.lang.String,?> configs) Description copied from interface:ConfigurableConfigure this class with the given key-value pairs- Specified by:
- configurein interface- Configurable
 
 - 
partitionpublic int partition(java.lang.String topic, java.lang.Object key, byte[] keyBytes, java.lang.Object value, byte[] valueBytes, Cluster cluster)Compute the partition for the given record.- Specified by:
- partitionin interface- Partitioner
- Parameters:
- topic- The topic name
- key- The key to partition on (or null if no key)
- keyBytes- serialized key to partition on (or null if no key)
- value- The value to partition on or null
- valueBytes- serialized value to partition on or null
- cluster- The current cluster metadata
 
 - 
closepublic void close() Description copied from interface:PartitionerThis is called when partitioner is closed.- Specified by:
- closein interface- java.lang.AutoCloseable
- Specified by:
- closein interface- java.io.Closeable
- Specified by:
- closein interface- Partitioner
 
 
- 
 
-