Class MockProducer<K,V> 
java.lang.Object
org.apache.kafka.clients.producer.MockProducer<K,V> 
- All Implemented Interfaces:
- Closeable,- AutoCloseable,- Producer<K,- V> 
A mock of the producer interface you can use for testing code that uses Kafka.
 
By default this mock will synchronously complete each send call successfully. However it can be configured to allow the user to control the completion of the call and supply an optional error for the producer to throw.
- 
Field SummaryFieldsModifier and TypeFieldDescription
- 
Constructor SummaryConstructorsConstructorDescriptionCreate a new mock producer with invented metadata.MockProducer(boolean autoComplete, Partitioner partitioner, Serializer<K> keySerializer, Serializer<V> valueSerializer) Create a new mock producer with invented metadata the given autoComplete setting, partitioner and key\value serializers.MockProducer(Cluster cluster, boolean autoComplete, Partitioner partitioner, Serializer<K> keySerializer, Serializer<V> valueSerializer) Create a mock producer
- 
Method SummaryModifier and TypeMethodDescriptionvoidvoidvoidclear()Clear the stored history of sent records, consumer group offsetsclientInstanceId(Duration timeout) voidclose()voidbooleanclosed()longvoidbooleanComplete the earliest uncompleted call successfully.Get the list of committed consumer group offsets since the last call toclear()voidbooleanComplete the earliest uncompleted call with the given error.voidvoidflush()booleanflushed()List<ProducerRecord<K, V>> history()Get the list of sent records since the last call toclear()voidvoidinjectTimeoutException(int injectTimeoutExceptionCounter) metrics()partitionsFor(String topic) voidsend(ProducerRecord<K, V> record) Adds the record to the list of sent records.send(ProducerRecord<K, V> record, Callback callback) Adds the record to the list of sent records.voidsendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata> offsets, ConsumerGroupMetadata groupMetadata) booleanvoidsetClientInstanceId(Uuid instanceId) voidsetMockMetrics(MetricName name, Metric metric) Set a mock metric for testing purposebooleanbooleanbooleanbooleanList<ProducerRecord<K, V>> void
- 
Field Details- 
initTransactionException
- 
beginTransactionException
- 
sendOffsetsToTransactionException
- 
commitTransactionException
- 
abortTransactionException
- 
sendException
- 
flushException
- 
partitionsForException
- 
closeException
 
- 
- 
Constructor Details- 
MockProducerpublic MockProducer(Cluster cluster, boolean autoComplete, Partitioner partitioner, Serializer<K> keySerializer, Serializer<V> valueSerializer) Create a mock producer- Parameters:
- cluster- The cluster holding metadata for this producer
- autoComplete- If true automatically complete all requests successfully and execute the callback. Otherwise the user must call- completeNext()or- errorNext(RuntimeException)after- send()to complete the call and unblock the- Future<RecordMetadata>that is returned.
- partitioner- The partition strategy
- keySerializer- The serializer for key that implements- Serializer.
- valueSerializer- The serializer for value that implements- Serializer.
 
- 
MockProducerpublic MockProducer(boolean autoComplete, Partitioner partitioner, Serializer<K> keySerializer, Serializer<V> valueSerializer) Create a new mock producer with invented metadata the given autoComplete setting, partitioner and key\value serializers. Equivalent tonew MockProducer(Cluster.empty(), autoComplete, partitioner, keySerializer, valueSerializer)
- 
MockProducerpublic MockProducer()Create a new mock producer with invented metadata. Equivalent tonew MockProducer(Cluster.empty(), false, null, null, null)
 
- 
- 
Method Details- 
initTransactionspublic void initTransactions()Description copied from interface:Producer- Specified by:
- initTransactionsin interface- Producer<K,- V> 
 
- 
beginTransactionDescription copied from interface:Producer- Specified by:
- beginTransactionin interface- Producer<K,- V> 
- Throws:
- ProducerFencedException
 
- 
sendOffsetsToTransactionpublic void sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata> offsets, ConsumerGroupMetadata groupMetadata) throws ProducerFencedExceptionDescription copied from interface:Producer- Specified by:
- sendOffsetsToTransactionin interface- Producer<K,- V> 
- Throws:
- ProducerFencedException
 
- 
commitTransactionDescription copied from interface:Producer- Specified by:
- commitTransactionin interface- Producer<K,- V> 
- Throws:
- ProducerFencedException
 
- 
abortTransactionDescription copied from interface:Producer- Specified by:
- abortTransactionin interface- Producer<K,- V> 
- Throws:
- ProducerFencedException
 
- 
sendAdds the record to the list of sent records. TheRecordMetadatareturned will be immediately satisfied.
- 
sendAdds the record to the list of sent records.
- 
flushpublic void flush()Description copied from interface:Producer
- 
partitionsForDescription copied from interface:Producer- Specified by:
- partitionsForin interface- Producer<K,- V> 
 
- 
disableTelemetrypublic void disableTelemetry()
- 
injectTimeoutExceptionpublic void injectTimeoutException(int injectTimeoutExceptionCounter) - Parameters:
- injectTimeoutExceptionCounter- use -1 for infinite
 
- 
setClientInstanceId
- 
clientInstanceIdDescription copied from interface:Producer- Specified by:
- clientInstanceIdin interface- Producer<K,- V> 
 
- 
metricsDescription copied from interface:Producer
- 
setMockMetricsSet a mock metric for testing purpose
- 
closepublic void close()Description copied from interface:Producer
- 
closeDescription copied from interface:Producer
- 
closedpublic boolean closed()
- 
fenceProducerpublic void fenceProducer()
- 
transactionInitializedpublic boolean transactionInitialized()
- 
transactionInFlightpublic boolean transactionInFlight()
- 
transactionCommittedpublic boolean transactionCommitted()
- 
transactionAbortedpublic boolean transactionAborted()
- 
flushedpublic boolean flushed()
- 
sentOffsetspublic boolean sentOffsets()
- 
commitCountpublic long commitCount()
- 
historyGet the list of sent records since the last call toclear()
- 
uncommittedRecords
- 
consumerGroupOffsetsHistoryGet the list of committed consumer group offsets since the last call toclear()
- 
uncommittedOffsets
- 
clearpublic void clear()Clear the stored history of sent records, consumer group offsets
- 
completeNextpublic boolean completeNext()Complete the earliest uncompleted call successfully.- Returns:
- true if there was an uncompleted call to complete
 
- 
errorNextComplete the earliest uncompleted call with the given error.- Returns:
- true if there was an uncompleted call to complete
 
- 
addedMetrics
- 
registerMetricForSubscription- Specified by:
- registerMetricForSubscriptionin interface- Producer<K,- V> 
- See Also:
 
- 
unregisterMetricFromSubscription- Specified by:
- unregisterMetricFromSubscriptionin interface- Producer<K,- V> 
- See Also:
 
 
-