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.

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.
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.
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.
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

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

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

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

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.
KafkaSender<K,V> - Interface in reactor.kafka.sender
Reactive producer that sends outgoing records to topic partitions of a Kafka cluster.
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.
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.

O

offset() - Method in interface reactor.kafka.receiver.ReceiverOffset
Returns the partition offset corresponding to the record to which this instance is associated.

P

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.
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.

R

reactor.kafka.receiver - package reactor.kafka.receiver
Reactor Kafka Receiver API
reactor.kafka.sender - package reactor.kafka.sender
Reactor Kafka Sender API
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() - 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() - 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.
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
 
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.
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
 
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
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

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.
toImmutable() - Method in interface reactor.kafka.receiver.ReceiverOptions
Deprecated.
will be removed since all operations should be immutable
toImmutable() - Method in interface reactor.kafka.sender.SenderOptions
Deprecated.
starting from 3.x version will be immutable by default
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
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.
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.
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