- 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
RetriableCommitFailedException
s.
- 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
-
- create(String, Integer, Long, K, V, T) - Static method in class reactor.kafka.sender.SenderRecord
-
- createOutbound() - Method in interface reactor.kafka.sender.KafkaSender
-
Creates a reactive gateway for outgoing Kafka records.
- 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.
- 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.
- 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
-
- 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
-
- subscribe(Subscriber<? super Void>) - Method in interface reactor.kafka.sender.KafkaOutbound
-
- 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
-