Class RoundRobinPartitioner
- java.lang.Object
 - 
- org.apache.kafka.clients.producer.RoundRobinPartitioner
 
 
- 
- All Implemented Interfaces:
 Closeable,AutoCloseable,Partitioner,Configurable
public class RoundRobinPartitioner extends 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 Summary
Constructors Constructor Description RoundRobinPartitioner() 
- 
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidclose()This is called when partitioner is closed.voidconfigure(Map<String,?> configs)Configure this class with the given key-value pairsintpartition(String topic, Object key, byte[] keyBytes, Object value, byte[] valueBytes, Cluster cluster)Compute the partition for the given record.- 
Methods inherited from class java.lang.Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait 
- 
Methods inherited from interface org.apache.kafka.clients.producer.Partitioner
onNewBatch 
 - 
 
 - 
 
- 
- 
Method Detail
- 
configure
public void configure(Map<String,?> configs)
Description copied from interface:ConfigurableConfigure this class with the given key-value pairs- Specified by:
 configurein interfaceConfigurable
 
- 
partition
public int partition(String topic, Object key, byte[] keyBytes, Object value, byte[] valueBytes, Cluster cluster)
Compute the partition for the given record.- Specified by:
 partitionin interfacePartitioner- Parameters:
 topic- The topic namekey- 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 nullvalueBytes- serialized value to partition on or nullcluster- The current cluster metadata
 
- 
close
public void close()
Description copied from interface:PartitionerThis is called when partitioner is closed.- Specified by:
 closein interfaceAutoCloseable- Specified by:
 closein interfaceCloseable- Specified by:
 closein interfacePartitioner
 
 - 
 
 -