Index

A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

O

objectMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
objectMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
 
offset() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
OFFSET - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
The offset of the failed record.
OFFSET - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for the partition offset.
OffsetAndMetadataProvider - Interface in org.springframework.kafka.listener
Provider for OffsetAndMetadata.
offsetHeader(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
Sets the name of the header that will be used to store the offset of the original record.
offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
onAcknowledgement(RecordMetadata, Exception) - Method in class org.springframework.kafka.support.CompositeProducerInterceptor
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
 
onApplicationEvent(ContextStoppedEvent) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
onApplicationEvent(ContextStoppedEvent) - Method in class org.springframework.kafka.core.KafkaTemplate
 
onApplicationEvent(ListenerContainerIdleEvent) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
 
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in class org.springframework.kafka.listener.LoggingCommitCallback
 
onError(ProducerRecord<K, V>, RecordMetadata, Exception) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
onError(ProducerRecord<K, V>, RecordMetadata, Exception) - Method in class org.springframework.kafka.support.LoggingProducerListener
 
onError(ProducerRecord<K, V>, RecordMetadata, Exception) - Method in interface org.springframework.kafka.support.ProducerListener
Invoked after an attempt to send a message has failed.
onFirstPoll() - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
When using manual partition assignment, called when the first poll has completed; useful when using auto.offset.reset=latest and you need to wait until the initial position has been established.
onFirstPoll() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
onIdleContainer(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
onIdleContainer(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
onIdleContainer(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
If the container is configured to emit idle container events, this method is called when the container idle event is emitted - allowing a seek operation.
onMessage(List<ConsumerRecord<K, Collection<ConsumerRecord<K, R>>>>, Consumer<?, ?>) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
 
onMessage(List<ConsumerRecord<K, R>>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
onMessage(List<ConsumerRecord<K, V>>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.BatchConsumerAwareMessageListener
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingMessageListener
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Kafka MessageListener entry point.
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.AcknowledgingMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.ConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in interface org.springframework.kafka.listener.AcknowledgingMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
onMessage(ConsumerRecord, Acknowledgment, Consumer) - Method in class org.springframework.kafka.listener.adapter.ConvertingMessageListener
 
onMessage(ConsumerRecords<K, V>, Acknowledgment, Consumer<K, V>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
 
onMessage(ConsumerRecords<K, V>, Acknowledgment, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchMessageListener
Listener receives the original ConsumerRecords object instead of a list of ConsumerRecord.
onMessage(T) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka.
onMessage(T, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka and provides access to the Consumer.
onMessage(T, Acknowledgment) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka.
onMessage(T, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka and provides access to the Consumer.
onNextBackOff(MessageListenerContainer, Exception, long) - Method in interface org.springframework.kafka.listener.BackOffHandler
Perform the next back off.
onNextBackOff(MessageListenerContainer, Exception, long) - Method in class org.springframework.kafka.listener.ContainerPausingBackOffHandler
 
onNextBackOff(MessageListenerContainer, Exception, long) - Method in class org.springframework.kafka.listener.DefaultBackOffHandler
 
onNextBackOff(MessageListenerContainer, TopicPartition, long) - Method in interface org.springframework.kafka.listener.BackOffHandler
Perform the next back off for a partition.
onNextBackOff(MessageListenerContainer, TopicPartition, long) - Method in class org.springframework.kafka.listener.ContainerPausingBackOffHandler
 
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
When using group management, called when partition assignments change.
onPartitionsAssigned(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsAssigned(Collection) with the additional consumer parameter.
onPartitionsAssigned(Consumer<?, ?>, Collection<TopicPartition>, Runnable) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
Called when partitions are assigned.
onPartitionsAssigned(Consumer<?, ?>, Collection<TopicPartition>, Runnable) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
 
onPartitionsLost(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsLost(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsLost(Collection) with an additional consumer parameter.
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
When using group management, called when partition assignments are revoked.
onPartitionsRevokedAfterCommit(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsRevoked(Collection) with the additional consumer parameter.
onPartitionsRevokedBeforeCommit(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsRevoked(Collection) with the additional consumer parameter.
onSend(ProducerRecord<K, V>) - Method in class org.springframework.kafka.support.CompositeProducerInterceptor
 
onSuccess(ProducerRecord<K, V>, RecordMetadata) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
onSuccess(ProducerRecord<K, V>, RecordMetadata) - Method in interface org.springframework.kafka.support.ProducerListener
Invoked after the successful send of a message (that is, after it has been acknowledged by the broker).
onTopOf(KStream<K, V>) - Method in class org.springframework.kafka.support.KafkaStreamBrancher
Terminating method that builds branches on top of given KStream.
OPTIONAL - Enum constant in enum class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Optional - The LoginModule is not required to succeed.
org.springframework.kafka - package org.springframework.kafka
Base package for kafka
org.springframework.kafka.annotation - package org.springframework.kafka.annotation
Package for kafka annotations
org.springframework.kafka.aot - package org.springframework.kafka.aot
Provides classes to support Spring AOT.
org.springframework.kafka.config - package org.springframework.kafka.config
Package for kafka configuration
org.springframework.kafka.core - package org.springframework.kafka.core
Package for kafka core components
org.springframework.kafka.core.reactive - package org.springframework.kafka.core.reactive
Reactive component for consumer and producer.
org.springframework.kafka.event - package org.springframework.kafka.event
Application Events.
org.springframework.kafka.listener - package org.springframework.kafka.listener
Package for kafka listeners
org.springframework.kafka.listener.adapter - package org.springframework.kafka.listener.adapter
Provides classes for adapting listeners.
org.springframework.kafka.mock - package org.springframework.kafka.mock
Provides classes to support the use of MockConsumer and MockProducer.
org.springframework.kafka.requestreply - package org.springframework.kafka.requestreply
Provides classes for request/reply semantics.
org.springframework.kafka.retrytopic - package org.springframework.kafka.retrytopic
Package for retryable topic handling.
org.springframework.kafka.security.jaas - package org.springframework.kafka.security.jaas
Provides classes related to jaas.
org.springframework.kafka.streams - package org.springframework.kafka.streams
Package for classes related to Kafka Streams.
org.springframework.kafka.streams.messaging - package org.springframework.kafka.streams.messaging
Package for classes related to spring-messaging with Kafka Streams.
org.springframework.kafka.support - package org.springframework.kafka.support
Package for kafka support
org.springframework.kafka.support.converter - package org.springframework.kafka.support.converter
Package for kafka converters
org.springframework.kafka.support.mapping - package org.springframework.kafka.support.mapping
Provides classes related to type mapping.
org.springframework.kafka.support.micrometer - package org.springframework.kafka.support.micrometer
Provides classes to support Micrometer.
org.springframework.kafka.support.serializer - package org.springframework.kafka.support.serializer
 
org.springframework.kafka.test - package org.springframework.kafka.test
 
org.springframework.kafka.test.assertj - package org.springframework.kafka.test.assertj
 
org.springframework.kafka.test.condition - package org.springframework.kafka.test.condition
Provides classes for JUnit5 conditions.
org.springframework.kafka.test.context - package org.springframework.kafka.test.context
 
org.springframework.kafka.test.core - package org.springframework.kafka.test.core
 
org.springframework.kafka.test.hamcrest - package org.springframework.kafka.test.hamcrest
 
org.springframework.kafka.test.junit - package org.springframework.kafka.test.junit
 
org.springframework.kafka.test.rule - package org.springframework.kafka.test.rule
 
org.springframework.kafka.test.utils - package org.springframework.kafka.test.utils
 
org.springframework.kafka.transaction - package org.springframework.kafka.transaction
Provides classes related to transactions.
original() - Static method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder
 
Original() - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
 
ORIGINAL_CONSUMER_GROUP - Static variable in class org.springframework.kafka.support.KafkaHeaders
Consumer group that failed to consumer a record published to another topic.
ORIGINAL_OFFSET - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original offset for a record published to another topic.
ORIGINAL_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original partition for a record published to another topic.
ORIGINAL_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original timestamp for a record published to another topic.
ORIGINAL_TIMESTAMP_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original timestamp type for a record published to another topic.
ORIGINAL_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original topic for a record published to another topic.
A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form