Package org.apache.kafka.clients.producer
Provides a Kafka client for producing records to topics and/or partitions in a Kafka cluster.
-
Interface Summary Interface Description Callback A callback interface that the user can implement to allow code to execute when the request is complete.Partitioner Not supported in MapR Kafka Partitioner InterfaceProducer<K,V> The interface for theKafkaProducer
ProducerInterceptor<K,V> A plugin interface that allows you to intercept (and possibly mutate) the records received by the producer before they are published to the Kafka cluster.StreamsPartitioner Partitioner Interface -
Class Summary Class Description DefaultStreamsPartitioner KafkaProducer<K,V> A Kafka client that publishes records to the Kafka cluster.MockProducer<K,V> Not supported in MapR Kafka A mock of the producer interface you can use for testing code that uses Kafka.ProducerConfig Configuration for the Kafka Producer.ProducerRecord<K,V> A key/value pair to be sent to Kafka.RecordMetadata The metadata for a record that has been acknowledged by the serverRoundRobinPartitioner The "Round-Robin" partitioner This partitioning strategy can be used when user wants to distribute the writes to all partitions equally.UniformStickyPartitioner Deprecated. Since 3.3.0, in order to use default partitioning logic remove thepartitioner.class
configuration setting and setpartitioner.ignore.keys=true
. -
Exception Summary Exception Description BufferExhaustedException This exception is thrown if the producer cannot allocate memory for a record within max.block.ms due to the buffer being too full.