Skip navigation links
Reactor Kafka
A B C D E F G H I K M O P R S T V W 

A

abort() - Method in interface reactor.kafka.sender.TransactionManager
Aborts the current transaction.
acknowledge() - Method in interface reactor.kafka.receiver.ReceiverOffset
Acknowledges the ReceiverRecord associated with this offset.
addAssignListener(Consumer<Collection<ReceiverPartition>>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Adds a listener for partition assignments.
addRevokeListener(Consumer<Collection<ReceiverPartition>>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Adds a listener for partition revocations.
assignListeners() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns list of configured partition assignment listeners.
assignment(Collection<TopicPartition>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Sets subscription using manual assignment to the specified partitions.
assignment() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the collection of partitions to be assigned if this instance is configured for manual partition assignment.
atmostOnceCommitAheadSize(int) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configures commit ahead size per partition for at-most-once delivery.
atmostOnceCommitAheadSize() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the maximum difference between the offset committed for at-most-once delivery and the offset of the last record dispatched.

B

begin() - Method in interface reactor.kafka.sender.TransactionManager
Begins a new transaction.
beginningOffset() - Method in interface reactor.kafka.receiver.ReceiverPartition
Return the beginning offset for this partition.
bootstrapServers() - Method in interface reactor.kafka.receiver.ReceiverOptions
Return the bootstrap servers from the provided ConsumerConfig.
bootstrapServers() - Method in interface reactor.kafka.sender.SenderOptions
Return the bootstrap servers from the provided ProducerConfig.

C

clearAssignListeners() - Method in interface reactor.kafka.receiver.ReceiverOptions
Removes all partition assignment listeners.
clearRevokeListeners() - Method in interface reactor.kafka.receiver.ReceiverOptions
Removes all partition revocation listeners.
clientId() - Method in interface reactor.kafka.receiver.ReceiverOptions
Return the client id provided by the ConsumerConfig.
clientId() - Method in interface reactor.kafka.sender.SenderOptions
Return the client id provided by the ProducerConfig.
close() - Method in interface reactor.kafka.sender.KafkaSender
Closes this sender and the underlying Kafka producer and releases all resources allocated to it.
closeTimeout(Duration) - Method in interface reactor.kafka.receiver.ReceiverOptions
Sets timeout for graceful shutdown of KafkaConsumer.
closeTimeout() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns timeout for graceful shutdown of KafkaConsumer.
closeTimeout() - Method in interface reactor.kafka.sender.SenderOptions
Returns the timeout for graceful shutdown of this sender.
closeTimeout(Duration) - Method in interface reactor.kafka.sender.SenderOptions
Configures the timeout for graceful shutdown of this sender.
commit() - Method in interface reactor.kafka.receiver.ReceiverOffset
Acknowledges the record associated with this instance and commits all acknowledged offsets.
commit() - Method in interface reactor.kafka.sender.TransactionManager
Commits the current transaction.
commitBatchSize(int) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configures commit batch size for automatic commits.
commitBatchSize() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the configured commit batch size for automatic commits of acknowledged records.
commitInterval(Duration) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configures commit interval for automatic commits.
commitInterval() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the configured commit interval for automatic commits of acknowledged records.
commitIntervalDuringDelay(long) - Method in interface reactor.kafka.receiver.ReceiverOptions
Set how often to commit offsets, in milliseconds, while a rebalance is being delayed.
commitIntervalDuringDelay() - Method in interface reactor.kafka.receiver.ReceiverOptions
Get how often to commit offsets, in milliseconds, while a rebalance is being delayed.
commitRetryInterval(Duration) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configures the retry commit interval for commits that fail with non-fatal RetriableCommitFailedException.
commitRetryInterval() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the configured retry commit interval for commits that fail with non-fatal RetriableCommitFailedExceptions.
consumerAdded(String, Consumer<?, ?>) - Method in class reactor.kafka.receiver.MicrometerConsumerListener
 
consumerAdded(String, Consumer<?, ?>) - Method in interface reactor.kafka.receiver.ReceiverOptions.ConsumerListener
A new consumer was created.
consumerListener(ReceiverOptions.ConsumerListener) - Method in interface reactor.kafka.receiver.ReceiverOptions
Set a function that will be applied after a consumer is created but before it is subscribed.
consumerListener() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the function that will be applied after a consumer is created but before it is subscribed.
consumerProperties() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the configuration properties of the underlying KafkaConsumer.
consumerProperty(String, Object) - Method in interface reactor.kafka.receiver.ReceiverOptions
Sets KafkaConsumer configuration property to the specified value.
consumerProperty(String) - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the KafkaConsumer configuration property value for the specified option name.
consumerRemoved(String, Consumer<?, ?>) - Method in class reactor.kafka.receiver.MicrometerConsumerListener
 
consumerRemoved(String, Consumer<?, ?>) - Method in interface reactor.kafka.receiver.ReceiverOptions.ConsumerListener
An existing consumer was removed.
correlationMetadata() - Method in class reactor.kafka.sender.SenderRecord
Returns the correlation metadata associated with this instance which is not sent to Kafka, but can be used to correlate response to outbound request.
correlationMetadata() - Method in interface reactor.kafka.sender.SenderResult
Returns the correlation metadata associated with this instance to enable this result to be matched with the corresponding SenderRecord that was sent to Kafka.
create(ReceiverOptions<K, V>) - Static method in interface reactor.kafka.receiver.KafkaReceiver
Creates a reactive Kafka receiver with the specified configuration options.
create(ConsumerFactory, ReceiverOptions<K, V>) - Static method in interface reactor.kafka.receiver.KafkaReceiver
Creates a reactive Kafka receiver with the specified configuration options.
create() - Static method in interface reactor.kafka.receiver.ReceiverOptions
Creates an options instance with default properties.
create(Map<String, Object>) - Static method in interface reactor.kafka.receiver.ReceiverOptions
Creates an options instance with the specified config overrides for KafkaConsumer.
create(Properties) - Static method in interface reactor.kafka.receiver.ReceiverOptions
Creates an options instance with the specified config overrides for KafkaConsumer.
create(SenderOptions<K, V>) - Static method in interface reactor.kafka.sender.KafkaSender
Creates a Kafka sender that appends records to Kafka topic partitions.
create(ProducerFactory, SenderOptions<K, V>) - Static method in interface reactor.kafka.sender.KafkaSender
Creates a Kafka sender that appends records to Kafka topic partitions.
create() - Static method in interface reactor.kafka.sender.SenderOptions
Creates a sender options instance with default properties.
create(Map<String, Object>) - Static method in interface reactor.kafka.sender.SenderOptions
Creates a sender options instance with the specified config overrides for the underlying Kafka Producer.
create(Properties) - Static method in interface reactor.kafka.sender.SenderOptions
Creates a sender options instance with the specified config overrides for the underlying Kafka Producer.
create(ProducerRecord<K, V>, T) - Static method in class reactor.kafka.sender.SenderRecord
Converts a ProducerRecord a SenderRecord to send to Kafka.
create(String, Integer, Long, K, V, T) - Static method in class reactor.kafka.sender.SenderRecord
Creates a SenderRecord to send to Kafka.
createOutbound() - Method in interface reactor.kafka.sender.KafkaSender
Creates a reactive gateway for outgoing Kafka records.

D

DefaultKafkaReceiverObservationConvention() - Constructor for class reactor.kafka.receiver.observation.KafkaReceiverObservation.DefaultKafkaReceiverObservationConvention
 
DefaultKafkaSenderObservationConvention() - Constructor for class reactor.kafka.sender.observation.KafkaSenderObservation.DefaultKafkaSenderObservationConvention
 
doOnConsumer(Function<Consumer<K, V>, ? extends T>) - Method in interface reactor.kafka.receiver.KafkaReceiver
Invokes the specified function on the Kafka Consumer associated with this KafkaReceiver.
doOnProducer(Function<Producer<K, V>, ? extends T>) - Method in interface reactor.kafka.sender.KafkaSender
Invokes the specified function on the Kafka Producer associated with this KafkaSender.

E

endOffset() - Method in interface reactor.kafka.receiver.ReceiverPartition
Return the end offset for this partition.
exception() - Method in interface reactor.kafka.sender.SenderResult
Returns the exception associated with a send failure.

F

fatalException(Throwable) - Method in interface reactor.kafka.sender.SenderOptions
 

G

getContextualName(KafkaRecordReceiverContext) - Method in interface reactor.kafka.receiver.observation.KafkaReceiverObservationConvention
 
getContextualName(KafkaRecordSenderContext) - Method in interface reactor.kafka.sender.observation.KafkaSenderObservationConvention
 
getDestination() - Method in class reactor.kafka.sender.observation.KafkaRecordSenderContext
Return the destination topic.
getLowCardinalityKeyValues(KafkaRecordReceiverContext) - Method in class reactor.kafka.receiver.observation.KafkaReceiverObservation.DefaultKafkaReceiverObservationConvention
 
getLowCardinalityKeyValues(KafkaRecordSenderContext) - Method in class reactor.kafka.sender.observation.KafkaSenderObservation.DefaultKafkaSenderObservationConvention
 
getName() - Method in interface reactor.kafka.receiver.observation.KafkaReceiverObservationConvention
 
getName() - Method in interface reactor.kafka.sender.observation.KafkaSenderObservationConvention
 
getProducerId() - Method in class reactor.kafka.sender.observation.KafkaRecordSenderContext
 
getReceiverId() - Method in class reactor.kafka.receiver.observation.KafkaRecordReceiverContext
 
getSource() - Method in class reactor.kafka.receiver.observation.KafkaRecordReceiverContext
Return the source topic.
groupId() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the configured Kafka consumer group id.

H

heartbeatInterval() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the configured heartbeat interval for Kafka consumer.

I

INSTANCE - Static variable in class reactor.kafka.receiver.observation.KafkaReceiverObservation.DefaultKafkaReceiverObservationConvention
A singleton instance of the convention.
INSTANCE - Static variable in class reactor.kafka.sender.observation.KafkaSenderObservation.DefaultKafkaSenderObservationConvention
A singleton instance of the convention.
isTransactional() - Method in interface reactor.kafka.sender.SenderOptions
Senders created from this options will be transactional if a transactional id is configured using ProducerConfig.TRANSACTIONAL_ID_CONFIG.

K

KafkaOutbound<K,V> - Interface in reactor.kafka.sender
KafkaOutbound is a reactive gateway for outgoing data flows to Kafka.
KafkaReceiver<K,V> - Interface in reactor.kafka.receiver
A reactive Kafka receiver for consuming records from topic partitions of a Kafka cluster.
KafkaReceiverObservation - Enum in reactor.kafka.receiver.observation
An Observation for KafkaReceiver.
KafkaReceiverObservation.DefaultKafkaReceiverObservationConvention - Class in reactor.kafka.receiver.observation
Default KafkaReceiverObservationConvention for Kafka listener key values.
KafkaReceiverObservation.ReceiverLowCardinalityTags - Enum in reactor.kafka.receiver.observation
Low cardinality tags.
KafkaReceiverObservationConvention - Interface in reactor.kafka.receiver.observation
ObservationConvention for Reactor Kafka receiver key values.
KafkaRecordReceiverContext - Class in reactor.kafka.receiver.observation
ReceiverContext for ConsumerRecords.
KafkaRecordReceiverContext(ConsumerRecord<?, ?>, String, String) - Constructor for class reactor.kafka.receiver.observation.KafkaRecordReceiverContext
 
KafkaRecordSenderContext - Class in reactor.kafka.sender.observation
SenderContext for ProducerRecords.
KafkaRecordSenderContext(ProducerRecord<?, ?>, String, String) - Constructor for class reactor.kafka.sender.observation.KafkaRecordSenderContext
 
KafkaSender<K,V> - Interface in reactor.kafka.sender
Reactive producer that sends outgoing records to topic partitions of a Kafka cluster.
KafkaSenderObservation - Enum in reactor.kafka.sender.observation
An Observation for KafkaSender.
KafkaSenderObservation.DefaultKafkaSenderObservationConvention - Class in reactor.kafka.sender.observation
Default KafkaSenderObservationConvention for Kafka Sender key values.
KafkaSenderObservation.SenderLowCardinalityTags - Enum in reactor.kafka.sender.observation
Low cardinality tags.
KafkaSenderObservationConvention - Interface in reactor.kafka.sender.observation
An ObservationConvention for Kafka Sender key values.
keyDeserializer() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns optionally a deserializer witch is used by KafkaConsumer for key deserialization.
keySerializer() - Method in interface reactor.kafka.sender.SenderOptions
Returns optionally a serializer witch is used by KafkaProducer for key serialization.

M

maxCommitAttempts(int) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configures the maximum number of consecutive non-fatal RetriableCommitFailedException commit failures that are tolerated.
maxCommitAttempts() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the maximum number of consecutive non-fatal commit failures that are tolerated.
maxDeferredCommits(int) - Method in interface reactor.kafka.receiver.ReceiverOptions
Set to greater than 0 to enable out of order commit sequencing.
maxDeferredCommits() - Method in interface reactor.kafka.receiver.ReceiverOptions
When greater than 0, enables out of order commit sequencing.
maxDelayRebalance(Duration) - Method in interface reactor.kafka.receiver.ReceiverOptions
Set the maximum amount of time to delay a rebalance until existing records in the pipeline have been processed.
maxDelayRebalance() - Method in interface reactor.kafka.receiver.ReceiverOptions
Get the maximum amount of time to delay a rebalance until existing records in the pipeline have been processed.
maxInFlight() - Method in interface reactor.kafka.sender.SenderOptions
Returns the maximum number of in-flight records that are fetched from the outbound record publisher while acknowledgements are pending.
maxInFlight(int) - Method in interface reactor.kafka.sender.SenderOptions
Configures the maximum number of in-flight records that are fetched from the outbound record publisher while acknowledgements are pending.
MicrometerConsumerListener - Class in reactor.kafka.receiver
A consumer listener that manages KafkaClientMetrics.
MicrometerConsumerListener(MeterRegistry) - Constructor for class reactor.kafka.receiver.MicrometerConsumerListener
Construct an instance with the provided registry.
MicrometerConsumerListener(MeterRegistry, List<Tag>) - Constructor for class reactor.kafka.receiver.MicrometerConsumerListener
Construct an instance with the provided registry and tags.
MicrometerProducerListener - Class in reactor.kafka.sender
A producer listener that manages KafkaClientMetrics.
MicrometerProducerListener(MeterRegistry) - Constructor for class reactor.kafka.sender.MicrometerProducerListener
Construct an instance with the provided registry.
MicrometerProducerListener(MeterRegistry, List<Tag>) - Constructor for class reactor.kafka.sender.MicrometerProducerListener
Construct an instance with the provided registry and tags.

O

observationConvention() - Method in interface reactor.kafka.receiver.ReceiverOptions
Return a KafkaReceiverObservationConvention to support a publishing operation observation.
observationConvention() - Method in interface reactor.kafka.sender.SenderOptions
Return a KafkaSenderObservationConvention to support a publishing operation observation.
observationRegistry() - Method in interface reactor.kafka.receiver.ReceiverOptions
Return an ObservationRegistry to observe Kafka record consuming operation.
observationRegistry() - Method in interface reactor.kafka.sender.SenderOptions
Return an ObservationRegistry to observe Kafka record publishing operation.
offset() - Method in interface reactor.kafka.receiver.ReceiverOffset
Returns the partition offset corresponding to the record to which this instance is associated.

P

pauseAllAfterRebalance(boolean) - Method in interface reactor.kafka.receiver.ReceiverOptions
When true, pause all partitions on assignment after rebalance, if any partitions were paused by User before the rebalance.
pauseAllAfterRebalance() - Method in interface reactor.kafka.receiver.ReceiverOptions
When true, pause all partitions on assignment after rebalance, if any partitions were paused by User before the rebalance.
pollTimeout(Duration) - Method in interface reactor.kafka.receiver.ReceiverOptions
Sets the timeout for each KafkaConsumer.poll(long) operation.
pollTimeout() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the timeout for each KafkaConsumer.poll(long) operation.
position() - Method in interface reactor.kafka.receiver.ReceiverPartition
Returns the offset of the next record that will be fetched from this topic partition.
producerAdded(String, Producer<?, ?>) - Method in class reactor.kafka.sender.MicrometerProducerListener
 
producerAdded(String, Producer<?, ?>) - Method in interface reactor.kafka.sender.SenderOptions.ProducerListener
A new producer was created.
producerListener() - Method in interface reactor.kafka.sender.SenderOptions
Returns the listener that will be applied after a producer is added and removed.
producerListener(SenderOptions.ProducerListener) - Method in interface reactor.kafka.sender.SenderOptions
Set a listener that will be applied after a producer is added and removed.
producerProperties() - Method in interface reactor.kafka.sender.SenderOptions
Returns the configuration properties for the underlying Kafka Producer.
producerProperty(String) - Method in interface reactor.kafka.sender.SenderOptions
Returns the Kafka Producer configuration property value for the specified option name.
producerProperty(String, Object) - Method in interface reactor.kafka.sender.SenderOptions
Sets Kafka Producer configuration property to the specified value.
producerRemoved(String, Producer<?, ?>) - Method in class reactor.kafka.sender.MicrometerProducerListener
 
producerRemoved(String, Producer<?, ?>) - Method in interface reactor.kafka.sender.SenderOptions.ProducerListener
An existing producer was removed.

R

reactor.kafka.receiver - package reactor.kafka.receiver
Reactor Kafka Receiver API
reactor.kafka.receiver.observation - package reactor.kafka.receiver.observation
Provides classes to support of Micrometer Observation API for Reactor Kafka Receiver.
reactor.kafka.sender - package reactor.kafka.sender
Reactor Kafka Sender API
reactor.kafka.sender.observation - package reactor.kafka.sender.observation
Provides classes to support of Micrometer Observation API for Reactor Kafka Sender.
receive(Integer) - Method in interface reactor.kafka.receiver.KafkaReceiver
Starts a Kafka consumer that consumes records from the subscriptions or partition assignments configured for this receiver.
receive() - Method in interface reactor.kafka.receiver.KafkaReceiver
Starts a Kafka consumer that consumes records from the subscriptions or partition assignments configured for this receiver.
receiveAtmostOnce(Integer) - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux of consumer records that are committed before the record is dispatched to provide atmost-once delivery semantics.
receiveAtmostOnce() - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux of consumer records that are committed before the record is dispatched to provide atmost-once delivery semantics.
receiveAutoAck(Integer) - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux containing each batch of consumer records returned by Consumer.poll(long).
receiveAutoAck() - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux containing each batch of consumer records returned by Consumer.poll(long).
receiveBatch(Integer) - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux containing each batch of consumer records returned by Consumer.poll(long).
receiveBatch() - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux containing each batch of consumer records returned by Consumer.poll(long).
receiveExactlyOnce(TransactionManager) - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux of consumer record batches that may be used for exactly once delivery semantics.
receiveExactlyOnce(TransactionManager, Integer) - Method in interface reactor.kafka.receiver.KafkaReceiver
Returns a Flux of consumer record batches that may be used for exactly once delivery semantics.
ReceiverOffset - Interface in reactor.kafka.receiver
Topic partition offset that must be acknowledged after the record in the corresponding ReceiverRecord is processed.
receiverOffset() - Method in class reactor.kafka.receiver.ReceiverRecord
Returns an acknowledgeable offset instance that should be acknowledged after this record has been consumed.
ReceiverOptions<K,V> - Interface in reactor.kafka.receiver
 
ReceiverOptions.ConsumerListener - Interface in reactor.kafka.receiver
Called whenever a consumer is added or removed.
ReceiverPartition - Interface in reactor.kafka.receiver
Topic partition interface that supports seek operations that can be invoked when partitions are assigned.
ReceiverRecord<K,V> - Class in reactor.kafka.receiver
Represents an incoming record dispatched by KafkaReceiver.
ReceiverRecord(ConsumerRecord<K, V>, ReceiverOffset) - Constructor for class reactor.kafka.receiver.ReceiverRecord
 
recordMetadata() - Method in interface reactor.kafka.sender.SenderResult
Returns the record metadata returned by Kafka.
revokeListeners() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns list of configured partition revocation listeners.

S

scheduler() - Method in interface reactor.kafka.sender.SenderOptions
Returns the scheduler used for publishing send results.
scheduler(Scheduler) - Method in interface reactor.kafka.sender.SenderOptions
Sets the scheduler used for publishing send results.
scheduler() - Method in interface reactor.kafka.sender.TransactionManager
Returns the scheduler associated with this transaction instance.
schedulerSupplier(Supplier<Scheduler>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configures the Supplier for a Scheduler on which Records will be published
schedulerSupplier() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the Supplier for a Scheduler that Records will be published on
seek(long) - Method in interface reactor.kafka.receiver.ReceiverPartition
Seeks to the specified offset of the topic partition.
seekToBeginning() - Method in interface reactor.kafka.receiver.ReceiverPartition
Seeks to the first available offset of the topic partition.
seekToEnd() - Method in interface reactor.kafka.receiver.ReceiverPartition
Seeks to the last offset of the topic partition.
seekToTimestamp(long) - Method in interface reactor.kafka.receiver.ReceiverPartition
Seek to the topic partition offset that is greater than or equal to the timestamp.
send(Publisher<? extends ProducerRecord<K, V>>) - Method in interface reactor.kafka.sender.KafkaOutbound
Sends a sequence of producer records to Kafka.
send(Publisher<? extends SenderRecord<K, V, T>>) - Method in interface reactor.kafka.sender.KafkaSender
Sends a sequence of records to Kafka and returns a Flux of response record metadata including partition and offset of each record.
SenderOptions<K,V> - Interface in reactor.kafka.sender
 
SenderOptions.ProducerListener - Interface in reactor.kafka.sender
Called whenever a producer is added or removed.
SenderRecord<K,V,T> - Class in reactor.kafka.sender
Represents an outgoing record.
SenderResult<T> - Interface in reactor.kafka.sender
Result metadata for an outbound record that was acknowledged by Kafka.
sendOffsets(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface reactor.kafka.sender.TransactionManager
Deprecated.
in favor of #sendOffsets(Map, ConsumerGroupMetadata)
sendOffsets(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface reactor.kafka.sender.TransactionManager
Sends provided offsets to the consumer offsets topic.
sendTransactionally(Publisher<? extends Publisher<? extends ProducerRecord<K, V>>>) - Method in interface reactor.kafka.sender.KafkaOutbound
Sends records from each inner flux of records within a transaction.
sendTransactionally(Publisher<? extends Publisher<? extends SenderRecord<K, V, T>>>) - Method in interface reactor.kafka.sender.KafkaSender
Sends records from each inner publisher of records within a transaction.
stopOnError() - Method in interface reactor.kafka.sender.SenderOptions
Returns stopOnError configuration which indicates if a send operation should be terminated when an error is encountered.
stopOnError(boolean) - Method in interface reactor.kafka.sender.SenderOptions
Configures error handling behaviour for KafkaSender.send(org.reactivestreams.Publisher).
subscribe(Subscriber<? super Void>) - Method in interface reactor.kafka.sender.KafkaOutbound
Subscribes the specified Void subscriber to this KafkaOutbound and triggers the send of pending producer record sequence queued using KafkaOutbound.send(Publisher) to Kafka.
subscriber(ConsumerRebalanceListener) - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the KafkaConsumer.subscribe(Collection, ConsumerRebalanceListener), KafkaConsumer.subscribe(Pattern, ConsumerRebalanceListener) or KafkaConsumer.assign(Collection) operation corresponding to the subscription or assignment options configured for this instance.
subscription(Collection<String>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Sets subscription using group management to the specified collection of topics.
subscription(Pattern) - Method in interface reactor.kafka.receiver.ReceiverOptions
Sets subscription using group management to the specified pattern.
subscriptionPattern() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the Pattern by which the topic should be selected
subscriptionTopics() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns the collection of Topics to be subscribed
supportsContext(Observation.Context) - Method in interface reactor.kafka.receiver.observation.KafkaReceiverObservationConvention
 
supportsContext(Observation.Context) - Method in interface reactor.kafka.sender.observation.KafkaSenderObservationConvention
 

T

then(Publisher<Void>) - Method in interface reactor.kafka.sender.KafkaOutbound
Appends a Publisher task and returns a new KafkaOutbound to schedule further send sequences to Kafka after pending send sequences are complete.
then() - Method in interface reactor.kafka.sender.KafkaOutbound
Returns a Mono that completes when all the producer records in this outbound sequence sent using KafkaOutbound.send(Publisher) are delivered to Kafka.
topicPartition() - Method in interface reactor.kafka.receiver.ReceiverOffset
Returns the topic partition corresponding to this instance.
topicPartition() - Method in interface reactor.kafka.receiver.ReceiverPartition
Returns the underlying Kafka topic partition.
transactionalId() - Method in interface reactor.kafka.sender.SenderOptions
Returns the configured transactional id
transactionComplete(Consumer<Boolean>) - Method in interface reactor.kafka.sender.TransactionManager
A callback to indicate a commit or rollback has completed, true for commit.
transactionManager() - Method in interface reactor.kafka.sender.KafkaSender
Returns the TransactionManager instance associated with this sender, which may be used for fine-grained control over transaction states.
TransactionManager - Interface in reactor.kafka.sender
 

V

valueDeserializer() - Method in interface reactor.kafka.receiver.ReceiverOptions
Returns optionally a deserializer witch is used by KafkaConsumer for value deserialization.
valueOf(String) - Static method in enum reactor.kafka.receiver.observation.KafkaReceiverObservation.ReceiverLowCardinalityTags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.kafka.receiver.observation.KafkaReceiverObservation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.kafka.sender.observation.KafkaSenderObservation.SenderLowCardinalityTags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.kafka.sender.observation.KafkaSenderObservation
Returns the enum constant of this type with the specified name.
values() - Static method in enum reactor.kafka.receiver.observation.KafkaReceiverObservation.ReceiverLowCardinalityTags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.kafka.receiver.observation.KafkaReceiverObservation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.kafka.sender.observation.KafkaSenderObservation.SenderLowCardinalityTags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.kafka.sender.observation.KafkaSenderObservation
Returns an array containing the constants of this enum type, in the order they are declared.
valueSerializer() - Method in interface reactor.kafka.sender.SenderOptions
Returns optionally a serializer witch is used by KafkaProducer for value serialization.

W

withKeyDeserializer(Deserializer<K>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Set a concrete deserializer instant to be used by the KafkaConsumer for keys.
withKeySerializer(Serializer<K>) - Method in interface reactor.kafka.sender.SenderOptions
Set a concrete serializer instant to be used by the KafkaProducer for keys.
withObservation(ObservationRegistry) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configure an ObservationRegistry to observe Kafka record consuming operation.
withObservation(ObservationRegistry, KafkaReceiverObservationConvention) - Method in interface reactor.kafka.receiver.ReceiverOptions
Configure an ObservationRegistry to observe Kafka record receiving operation.
withObservation(ObservationRegistry) - Method in interface reactor.kafka.sender.SenderOptions
Configure an ObservationRegistry to observe Kafka record publishing operation.
withObservation(ObservationRegistry, KafkaSenderObservationConvention) - Method in interface reactor.kafka.sender.SenderOptions
Configure an ObservationRegistry to observe Kafka record publishing operation.
withValueDeserializer(Deserializer<V>) - Method in interface reactor.kafka.receiver.ReceiverOptions
Set a concrete deserializer instant to be used by the KafkaConsumer for values.
withValueSerializer(Serializer<V>) - Method in interface reactor.kafka.sender.SenderOptions
Set a concrete serializer instant to be used by the KafkaProducer for values.
A B C D E F G H I K M O P R S T V W 
Skip navigation links
Reactor Kafka