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 All Packages
All Classes All Packages
All Classes All Packages
A
- abortTransaction() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- AbstractConsumerSeekAware - Class in org.springframework.kafka.listener
-
Manages the
ConsumerSeekAware.ConsumerSeekCallback
s for the listener. - AbstractConsumerSeekAware() - Constructor for class org.springframework.kafka.listener.AbstractConsumerSeekAware
- AbstractDelegatingMessageListenerAdapter<T> - Class in org.springframework.kafka.listener.adapter
-
Top level class for all listener adapters.
- AbstractDelegatingMessageListenerAdapter(T) - Constructor for class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- AbstractFilteringMessageListener<K,V,T> - Class in org.springframework.kafka.listener.adapter
-
An abstract message listener adapter that implements record filter logic via a
RecordFilterStrategy
. - AbstractFilteringMessageListener(T, RecordFilterStrategy<K, V>) - Constructor for class org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener
- AbstractJavaTypeMapper - Class in org.springframework.kafka.support.mapping
-
Abstract type mapper.
- AbstractJavaTypeMapper() - Constructor for class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- AbstractKafkaBackOffManagerFactory - Class in org.springframework.kafka.listener
-
Base class for
KafkaBackOffManagerFactory
implementations. - AbstractKafkaBackOffManagerFactory() - Constructor for class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
-
Creates an instance that will retrieve the
ListenerContainerRegistry
from theApplicationContext
. - AbstractKafkaBackOffManagerFactory(ListenerContainerRegistry) - Constructor for class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
-
Creates an instance with the provided
ListenerContainerRegistry
, which will be used to fetch theMessageListenerContainer
to back off. - AbstractKafkaHeaderMapper - Class in org.springframework.kafka.support
-
Base for Kafka header mappers.
- AbstractKafkaHeaderMapper(boolean, String...) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Construct a mapper that will match the supplied patterns (outbound) and all headers (inbound).
- AbstractKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Construct a mapper that will match the supplied patterns (outbound) and all headers (inbound).
- AbstractKafkaHeaderMapper.HeaderMatcher - Interface in org.springframework.kafka.support
-
A matcher for headers.
- AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher - Class in org.springframework.kafka.support
-
A matcher that never matches a set of headers.
- AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher - Class in org.springframework.kafka.support
-
A pattern-based header matcher that matches if the specified header matches the specified simple pattern.
- AbstractKafkaListenerContainerFactory<C extends AbstractMessageListenerContainer<K,V>,K,V> - Class in org.springframework.kafka.config
-
Base
KafkaListenerContainerFactory
for Spring's base container implementation. - AbstractKafkaListenerContainerFactory() - Constructor for class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- AbstractKafkaListenerEndpoint<K,V> - Class in org.springframework.kafka.config
-
Base model for a Kafka listener endpoint.
- AbstractKafkaListenerEndpoint() - Constructor for class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- AbstractMessageListenerContainer<K,V> - Class in org.springframework.kafka.listener
-
The base implementation for the
MessageListenerContainer
. - AbstractMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Construct an instance with the provided factory and properties.
- AbstractRetryingMessageListenerAdapter<K,V,T> - Class in org.springframework.kafka.listener.adapter
-
Base class for retrying message listener adapters.
- AbstractRetryingMessageListenerAdapter(T, RetryTemplate) - Constructor for class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
-
Construct an instance with the supplied retry template.
- AbstractRetryingMessageListenerAdapter(T, RetryTemplate, RecoveryCallback<? extends Object>) - Constructor for class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
-
Construct an instance with the supplied template and callback.
- ABSwitchCluster - Class in org.springframework.kafka.core
-
A
Supplier
for bootstrap servers that can toggle between 2 lists of servers. - ABSwitchCluster(String, String) - Constructor for class org.springframework.kafka.core.ABSwitchCluster
-
Construct an instance with primary and secondary bootstrap servers.
- accept(ConsumerRecord<?, ?>, Exception) - Method in interface org.springframework.kafka.listener.ConsumerAwareRecordRecoverer
- accept(ConsumerRecord<?, ?>, Consumer<?, ?>, Exception) - Method in interface org.springframework.kafka.listener.ConsumerAwareRecordRecoverer
-
Recover the record.
- accept(ConsumerRecord<?, ?>, Consumer<?, ?>, Exception) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
- acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
BiConsumer.accept(Object, Object)
with the arguments if the condition is true. - acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
Consumer.accept(Object)
with the value if the condition is true. - acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
Consumer.accept(Object)
with the value if it is not null or empty. - acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
BiConsumer.accept(Object, Object)
with the arguments if the value argument is not null or empty. - acceptIfInstanceOf(Class<T>, Object, Consumer<T>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
Consumer.accept(Object)
with the cast value if the object is an instance of the provided class. - acceptIfNotEmpty(List<T>, Consumer<List<T>>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
Consumer.accept(Object)
with the value if it is not null or empty. - acceptIfNotEmpty(T[], Consumer<T[]>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
Consumer.accept(Object)
with the value if it is not null or empty. - acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
BiConsumer.accept(Object, Object)
with the arguments if the t2 argument is not null. - acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.kafka.support.JavaUtils
-
Invoke
Consumer.accept(Object)
with the value if it is not null. - acknowledge() - Method in interface org.springframework.kafka.support.Acknowledgment
-
Invoked when the record or batch for which the acknowledgment has been created has been processed.
- ACKNOWLEDGING - org.springframework.kafka.listener.ListenerType
-
Acknowledging.
- ACKNOWLEDGING_CONSUMER_AWARE - org.springframework.kafka.listener.ListenerType
-
Acknowledging and consumer aware.
- AcknowledgingConsumerAwareMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
- AcknowledgingMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
- Acknowledgment - Interface in org.springframework.kafka.support
-
Handle for acknowledging the processing of a
ConsumerRecord
. - ACKNOWLEDGMENT - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for the
Acknowledgment
. - adapt(List<Message<?>>, List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>, BatchToRecordAdapter.Callback<K, V>) - Method in interface org.springframework.kafka.listener.adapter.BatchToRecordAdapter
-
Adapt the list and invoke the callback for each message.
- adapt(List<Message<?>>, List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>, BatchToRecordAdapter.Callback<K, V>) - Method in class org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter
- AdapterUtils - Class in org.springframework.kafka.listener.adapter
-
Utilities for listener adapters.
- ADD_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonSerializer
-
Kafka config property for disabling adding type headers.
- ADD_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Kafka config property for enabling/disabling adding type headers.
- addContainers(MessageListenerContainer...) - Method in class org.springframework.kafka.listener.ContainerGroup
-
Add one or more containers to the group.
- addDelegate(Class<? extends Throwable>, CommonErrorHandler) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
-
Add a delegate to the end of the current collection.
- addDelegate(String, Deserializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- addDelegate(String, Serializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- addDelegate(Pattern, T) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- addDelegate(ProducerListener<K, V>) - Method in class org.springframework.kafka.support.CompositeProducerListener
- addDestinationTopics(List<DestinationTopic>) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- addDestinationTopics(List<DestinationTopic>) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Adds the provided destination topics to the container.
- addHeader(Headers, String, Class<?>) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- addHeadersFunction(BiFunction<ConsumerRecord<?, ?>, Exception, Headers>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Add a function which will be called to obtain additional headers to add to the published record.
- additionalHeaders() - Method in interface org.springframework.kafka.listener.adapter.ReplyHeadersConfigurer
-
A map of additional headers to add to the reply message.
- addKafkaStreamsCustomizers(List<KafkaStreamsCustomizer>) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- addKafkaStreamsCustomizers(KafkaStreamsInfrastructureCustomizer...) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
-
Add customizers.
- addListener(int, ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Add a listener at a specific index.
- addListener(int, ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Add a listener at a specific index.
- addListener(int, ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Add a listener at a specific index.
- addListener(int, ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Add a listener at a specific index.
- addListener(StreamsBuilderFactoryBean.Listener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Add a
StreamsBuilderFactoryBean.Listener
which will be called after starting and stopping the streams. - addListener(ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Add a listener.
- addListener(ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Add a listener.
- addListener(ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Add a listener.
- addListener(ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Add a listener.
- addMatchers(AbstractKafkaHeaderMapper.HeaderMatcher...) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Subclasses can invoke this to add custom
AbstractKafkaHeaderMapper.HeaderMatcher
s. - addNotRetryableException(Class<? extends Exception>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Add exception type to the default list.
- addNotRetryableExceptions(Class<? extends Exception>...) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Add exception types to the default list.
- addPostProcessor(ConsumerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Add a post processor.
- addPostProcessor(ConsumerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- addPostProcessor(ProducerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- addPostProcessor(ProducerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Add a post processor.
- addRawMappedHeader(String, boolean) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Add a raw mapped header.
- addRetryableExceptions(Class<? extends Exception>...) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Add exception types that can be retried.
- addSuffixesAndMethod(DestinationTopic.Properties, Object, Method) - Method in class org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- addTopics(String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Add topics to the existing broker(s) using the configured number of partitions.
- addTopics(NewTopic...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Add topics to the existing broker(s).
- addTopicsWithResults(String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Add topics to the existing broker(s) using the configured number of partitions.
- addTopicsWithResults(NewTopic...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Add topics to the existing broker(s) and returning a map of results.
- addToStringClasses(String...) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Add class names that the outbound mapper should perform toString() operations on before mapping.
- addTrustedPackages(String...) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Add packages to the trusted packages list (default
java.util, java.lang
) used when constructing objects from JSON. - addTrustedPackages(String...) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
-
Specify a set of packages to trust during deserialization.
- addTrustedPackages(String...) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- addTrustedPackages(String...) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Add trusted packages for deserialization.
- addTypeInfo - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
- adjustLogLevels(String, List<Class<?>>, List<String>, Level) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
- admin() - Method in class org.springframework.kafka.jdocs.topics.Config
- adminTimeout() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Timeout in seconds for admin operations (e.g.
- adminTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the timeout in seconds for admin operations (e.g.
- after() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
- afterAll(ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- afterAll(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
- afterEach(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
- afterPropertiesSet() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- afterPropertiesSet() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- afterPropertiesSet() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- afterPropertiesSet() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- afterPropertiesSet() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- afterPropertiesSet() - Method in class org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper
- afterPropertiesSet() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- afterRecord(ConsumerRecord<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- afterRecord(ConsumerRecord<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
-
Called when processing the record is complete either
RecordInterceptor.success(ConsumerRecord, Consumer)
orRecordInterceptor.failure(ConsumerRecord, Exception, Consumer)
. - AfterRollbackProcessor<K,V> - Interface in org.springframework.kafka.listener
-
Invoked by a listener container with remaining, unprocessed, records (including the failed record).
- afterSingletonsInstantiated() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- afterSingletonsInstantiated() - Method in class org.springframework.kafka.core.KafkaAdmin
- afterSingletonsInstantiated() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- afterSingletonsInstantiated() - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- AGGREGATED_RESULTS_TOPIC - Static variable in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Pseudo topic name for the "outer"
ConsumerRecord
that has the aggregated results in its value after a normal release by the release strategy. - AggregatingReplyingKafkaTemplate<K,V,R> - Class in org.springframework.kafka.requestreply
-
A replying template that aggregates multiple replies with the same correlation id.
- AggregatingReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, Collection<ConsumerRecord<K, R>>>, BiPredicate<List<ConsumerRecord<K, R>>, Boolean>) - Constructor for class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Construct an instance using the provided parameter arguments.
- AllowDenyCollectionManager<T> - Class in org.springframework.kafka.support
-
Class for managing Allow / Deny collections and its predicates.
- AllowDenyCollectionManager(Collection<T>, Collection<T>) - Constructor for class org.springframework.kafka.support.AllowDenyCollectionManager
- AllowDenyCollectionManager(Collection<T>, Collection<T>, Collection<Predicate<T>>) - Constructor for class org.springframework.kafka.support.AllowDenyCollectionManager
- allStopped() - Method in class org.springframework.kafka.listener.ContainerGroup
-
Return true if all containers in this group are stopped.
- ALPHA - org.springframework.kafka.listener.ContainerProperties.EOSMode
-
Deprecated.in favor of
ContainerProperties.EOSMode.V1
. - ALWAYS - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
-
Always commit the current offset during partition assignment.
- ALWAYS_RETRY_ON_ERROR - org.springframework.kafka.retrytopic.DltStrategy
-
Always send the message back to the DLT for reprocessing in case of failure in DLT processing.
- alwaysLogListenerException() - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Logs the listener exception at each attempt.
- Application - Class in org.springframework.kafka.jdocs.dynamic
-
Dynamic listeners.
- Application - Class in org.springframework.kafka.jdocs.requestreply
-
Code snippets for request/reply messaging.
- Application - Class in org.springframework.kafka.jdocs.started.consumer
-
Code snippet for quick start.
- Application - Class in org.springframework.kafka.jdocs.started.producer
-
Code snippet for quick start.
- Application() - Constructor for class org.springframework.kafka.jdocs.dynamic.Application
- Application() - Constructor for class org.springframework.kafka.jdocs.requestreply.Application
- Application() - Constructor for class org.springframework.kafka.jdocs.started.consumer.Application
- Application() - Constructor for class org.springframework.kafka.jdocs.started.producer.Application
- Application.Thing - Class in org.springframework.kafka.jdocs.requestreply
- apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.kafka.test.rule.Log4j2LevelAdjuster
- areAllowed(T[]) - Method in class org.springframework.kafka.support.AllowDenyCollectionManager
- asCompletable() - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
-
Return a
CompletableFuture
representation of this instance. - asCompletable() - Method in class org.springframework.kafka.requestreply.RequestReplyMessageFuture
-
Return a
CompletableFuture
representation of this instance. - asCompletable() - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture
- asProperties() - Method in class org.springframework.kafka.config.KafkaStreamsConfiguration
-
Return the configuration map as a
Properties
. - assertBeanFactory() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- assignment() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- assignReplicas(int, List<Integer>) - Method in class org.springframework.kafka.config.TopicBuilder
-
Add an individual replica assignment.
- attempts() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The number of attempts made before the message is sent to the DLT.
- AUTH - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
An authorization exception occurred.
- autoCreateTopics() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Whether or not the topics should be created after registration with the provided configurations.
- autoCreateTopics(boolean, int, short) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- autoCreateTopicsWith(int, short) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- autoStartDltHandler() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Override the container factory's
autoStartup
property for just the DLT container. - autoStartDltHandler() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- autoStartDltHandler(Boolean) - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory
-
Set to false to not start the DLT handler.
- autoStartDltHandler(Boolean) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Set to false to not start the DLT handler (configured or default); overrides the container factory's autoStartup property.
- autoStartup() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Set to true or false, to override the default setting in the container factory.
B
- backoff() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Specify the backoff properties for retrying this operation.
- backOff(BackOff) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.BlockingRetriesConfigurer
-
Set the
BackOff
that should be used with the blocking retry mechanism. - BackOffHandler - Interface in org.springframework.kafka.listener
-
Handler for the provided back off time, listener container and exception.
- backOffIfNecessary(KafkaConsumerBackoffManager.Context) - Method in class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManager
-
Backs off if the current time is before the dueTimestamp provided in the
KafkaConsumerBackoffManager.Context
object. - backOffIfNecessary(KafkaConsumerBackoffManager.Context) - Method in interface org.springframework.kafka.listener.KafkaConsumerBackoffManager
- BackOffValuesGenerator - Class in org.springframework.kafka.retrytopic
-
Generates the backoff values from the provided maxAttempts value and
BackOffPolicy
. - BackOffValuesGenerator(int, BackOffPolicy) - Constructor for class org.springframework.kafka.retrytopic.BackOffValuesGenerator
- batch() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Override the container factory's
batchListener
property. - BATCH - org.springframework.kafka.listener.ContainerProperties.AckMode
-
Commit the offsets of all records returned by the previous poll after they all have been processed by the listener.
- BATCH_CONVERTED_HEADERS - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for a list of Maps of converted native Kafka headers.
- BatchAcknowledgingConsumerAwareMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling a batch of incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
- BatchAcknowledgingMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling a batch of incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
- BatchConsumerAwareMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling a batch of incoming Kafka messages; the list is created from the consumer records object returned by a poll.
- BatchErrorHandler - Interface in org.springframework.kafka.listener
-
Handles errors thrown during the execution of a
BatchMessageListener
. - BatchInterceptor<K,V> - Interface in org.springframework.kafka.listener
-
An interceptor for batches of records.
- BatchListenerFailedException - Exception in org.springframework.kafka.listener
-
An exception thrown by user code to inform the framework which record in a batch has failed.
- BatchListenerFailedException(String, int) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
-
Construct an instance with the provided properties.
- BatchListenerFailedException(String, Throwable, int) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
-
Construct an instance with the provided properties.
- BatchListenerFailedException(String, Throwable, ConsumerRecord<?, ?>) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
-
Construct an instance with the provided properties.
- BatchListenerFailedException(String, ConsumerRecord<?, ?>) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
-
Construct an instance with the provided properties.
- BatchMessageConverter - Interface in org.springframework.kafka.support.converter
-
A Kafka-specific
Message
converter strategy. - BatchMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling a batch of incoming Kafka messages; the list is created from the consumer records object returned by a poll.
- BatchMessagingMessageConverter - Class in org.springframework.kafka.support.converter
-
A Messaging
MessageConverter
implementation used with a batch message listener; the consumer record values are extracted into a collection in the message payload. - BatchMessagingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Create an instance that does not convert the record values.
- BatchMessagingMessageConverter(RecordMessageConverter) - Constructor for class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Create an instance that converts record values using the supplied converter.
- BatchMessagingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
A
MessageListener
adapter that invokes a configurableHandlerAdapter
; used when the factory is configured for the listener to receive batches of messages. - BatchMessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Create an instance with the provided parameters.
- BatchMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Create an instance with the provided parameters.
- BatchToRecordAdapter<K,V> - Interface in org.springframework.kafka.listener.adapter
-
An adapter that adapts a batch listener to a record listener method.
- BatchToRecordAdapter.Callback<K,V> - Interface in org.springframework.kafka.listener.adapter
-
A callback for each message.
- BEAN_NAME - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- beanRef() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
A pseudo bean name used in SpEL expressions within this annotation to reference the current bean within which this listener is defined.
- before() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
- beforeAll(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
- beforeEach(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
- BEGINNING - org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
-
Seek to the beginning.
- beginningOffsets(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- beginTransaction() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- BETA - org.springframework.kafka.listener.ContainerProperties.EOSMode
-
Deprecated.in favor of
ContainerProperties.EOSMode.V2
. - BlockingRetriesConfigurer() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.BlockingRetriesConfigurer
- bootstrapServersProperty() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
The property name to set with the bootstrap server addresses instead of the default "spring.embedded.kafka.brokers".
- bounce(BrokerAddress) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- branch(Predicate<? super K, ? super V>, Consumer<? super KStream<K, V>>) - Method in class org.springframework.kafka.support.KafkaStreamBrancher
-
Defines a new branch.
- BROKER_LIST_PROPERTY - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the value of this property to a property name that should be set to the list of embedded broker addresses instead of "spring.embedded.kafka.brokers".
- BrokerAddress - Class in org.springframework.kafka.test.core
-
Encapsulates the address of a Kafka broker.
- BrokerAddress(String) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
- BrokerAddress(String, int) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
- BrokerAddress(BrokerEndPoint) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
- brokerListProperty(String) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the system property with this name to the list of broker addresses.
- brokerProperties() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Properties in form key=value that should be added to the broker config before runs.
- brokerProperties(Map<String, String>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Specify the properties to configure Kafka Broker before start, e.g.
- brokerProperties(Map<String, String>) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Specify the properties to configure Kafka Broker before start, e.g.
- brokerPropertiesLocation() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Spring
Resource
url specifying the location of properties that should be added to the broker config. - brokerProperty(String, Object) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Specify a broker property.
- brokerProperty(String, Object) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Specify a broker property.
- build() - Method in class org.springframework.kafka.config.TopicBuilder
- build() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Builds the Header Names, asserting that none of them is null.
- build(Map<String, ?>, boolean, String, Object, Pattern) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- buildConsumerRecordMetadata(Object) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
-
Build a
ConsumerRecordMetadata
from data which must be aConsumerRecord
. - buildConsumerRecordMetadataFromArray(Object...) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
-
Build a
ConsumerRecordMetadata
from the firstConsumerRecord
in data, if any. - buildDefault(Map<String, ?>, String, boolean, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- Builder() - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder
- ByteArrayJsonMessageConverter - Class in org.springframework.kafka.support.converter
-
JSON Message converter -
byte[]
on output, String, Bytes, or byte[] on input. - ByteArrayJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.ByteArrayJsonMessageConverter
- ByteArrayJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.ByteArrayJsonMessageConverter
- byteArrayToDeserializationException(LogAccessor, byte[]) - Static method in class org.springframework.kafka.listener.ListenerUtils
- byteArrayToDeserializationException(LogAccessor, Header) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
-
Convert a byte array containing a serialized
DeserializationException
to theDeserializationException
. - BytesJsonMessageConverter - Class in org.springframework.kafka.support.converter
-
JSON Message converter -
Bytes
on output, String, Bytes, or byte[] on input. - BytesJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.BytesJsonMessageConverter
- BytesJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.BytesJsonMessageConverter
C
- cancel(boolean) - Method in class org.springframework.kafka.requestreply.RequestReplyFuture.Completable
- cancel(boolean) - Method in class org.springframework.kafka.requestreply.RequestReplyMessageFuture.Completable
- CASE_SENSITIVE - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Set to false to make topic pattern matching case-insensitive.
- categories() - Method in annotation type org.springframework.kafka.test.condition.LogLevels
-
Category names representing Log4j or Logback categories to change.
- categories(String...) - Method in class org.springframework.kafka.test.rule.Log4j2LevelAdjuster
- ChainedKafkaTransactionManager<K,V> - Class in org.springframework.kafka.transaction
-
Deprecated.Refer to the
ChainedTransactionManager
javadocs. - ChainedKafkaTransactionManager(PlatformTransactionManager...) - Constructor for class org.springframework.kafka.transaction.ChainedKafkaTransactionManager
-
Deprecated.Construct an instance with the provided
PlatformTransactionManager
s. - checkBootstrap(Map<String, Object>) - Method in class org.springframework.kafka.core.KafkaResourceFactory
-
Enhance the properties by calling the
KafkaResourceFactory.setBootstrapServersSupplier(Supplier)
and replace the bootstrap servers properties. - checkDeserialization(ConsumerRecord<?, ?>, LogAccessor) - Static method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return a
DeserializationException
if either the key or value failed deserialization; null otherwise. - checkForErrors(ConsumerRecord<K, R>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Check for errors in a reply.
- checkGroupId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- checkTopics() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- childStopped(MessageListenerContainer, ConsumerStoppedEvent.Reason) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- childStopped(MessageListenerContainer, ConsumerStoppedEvent.Reason) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- childStopped(MessageListenerContainer, ConsumerStoppedEvent.Reason) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Notify a parent container that a child container has stopped.
- classes() - Method in annotation type org.springframework.kafka.test.condition.LogLevels
-
Classes representing Log4j categories to change.
- ClassMapper - Interface in org.springframework.kafka.support.mapping
-
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
- CleanupConfig - Class in org.springframework.kafka.core
-
Specifies time of
KafkaStreams.cleanUp()
execution. - CleanupConfig() - Constructor for class org.springframework.kafka.core.CleanupConfig
- CleanupConfig(boolean, boolean) - Constructor for class org.springframework.kafka.core.CleanupConfig
- cleanupOnStart() - Method in class org.springframework.kafka.core.CleanupConfig
- cleanupOnStop() - Method in class org.springframework.kafka.core.CleanupConfig
- clearConsumerGroupId() - Static method in class org.springframework.kafka.support.KafkaUtils
-
Clear the group id for the consumer bound to this thread.
- clearRetryListeners() - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
-
Clear the retry listeners.
- clearThreadState() - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
-
Optional method to clear thread state; will be called just before a consumer thread terminates.
- clearThreadState() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- clearThreadState() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Optional method to clear thread state; will be called just before a consumer thread terminates.
- clearThreadState() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- clearThreadState() - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
- clearThreadState() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
- clearThreadState() - Method in interface org.springframework.kafka.listener.GenericErrorHandler
-
Optional method to clear thread state; will be called just before a consumer thread terminates.
- clearThreadState() - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
-
Deprecated.
- clearThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- clearThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- clearThreadState(Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ThreadStateProcessor
-
Call to clear thread-bound resources which were set up in
ThreadStateProcessor.setupThreadState(Consumer)
. - clearTransactionIdSuffix() - Static method in class org.springframework.kafka.support.TransactionSupport
- clientIdPrefix() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
When provided, overrides the client id property in the consumer factory configuration.
- close() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- close() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- close() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- close() - Method in class org.springframework.kafka.streams.HeaderEnricher
- close() - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
- close() - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- close() - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- close() - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.JsonSerde
- close() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- close() - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- close() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- close(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- closeProducer(Producer<K, V>, boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
- closeProducerFor(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- closeProducerFor(String) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Remove the specified producer from the cache and close it.
- closeThreadBoundProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
When using
DefaultKafkaProducerFactory.setProducerPerThread(boolean)
(true), call this method to close and release this thread's producer. - closeThreadBoundProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
If the factory implementation uses thread-bound producers, call this method to close and release this thread's producer.
- commit() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- committed(Set<TopicPartition>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- commitTransaction() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- CommonContainerStoppingErrorHandler - Class in org.springframework.kafka.listener
-
A
CommonErrorHandler
that stops the container when an error occurs. - CommonContainerStoppingErrorHandler() - Constructor for class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
-
Construct an instance with a default
SimpleAsyncTaskExecutor
. - CommonContainerStoppingErrorHandler(Executor) - Constructor for class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
-
Construct an instance with the provided
Executor
. - CommonDelegatingErrorHandler - Class in org.springframework.kafka.listener
-
An error handler that delegates to different error handlers, depending on the exception type.
- CommonDelegatingErrorHandler(CommonErrorHandler) - Constructor for class org.springframework.kafka.listener.CommonDelegatingErrorHandler
-
Construct an instance with a default error handler that will be invoked if the exception has no matches.
- CommonErrorHandler - Interface in org.springframework.kafka.listener
-
Replacement for
ErrorHandler
andBatchErrorHandler
and their sub-interfaces. - commonHeaders(Acknowledgment, Consumer<?, ?>, Map<String, Object>, Object, Object, Object, Object, Object, Object) - Method in interface org.springframework.kafka.support.converter.MessageConverter
-
Set up the common headers.
- CommonLoggingErrorHandler - Class in org.springframework.kafka.listener
-
The
CommonErrorHandler
implementation for logging exceptions. - CommonLoggingErrorHandler() - Constructor for class org.springframework.kafka.listener.CommonLoggingErrorHandler
- CommonMixedErrorHandler - Class in org.springframework.kafka.listener
-
A
CommonErrorHandler
that delegates to differentCommonErrorHandler
s for record and batch listeners. - CommonMixedErrorHandler(CommonErrorHandler, CommonErrorHandler) - Constructor for class org.springframework.kafka.listener.CommonMixedErrorHandler
-
Construct an instance with the provided delegate
CommonErrorHandler
s. - compact() - Method in class org.springframework.kafka.config.TopicBuilder
-
Set the
TopicConfig.CLEANUP_POLICY_CONFIG
toTopicConfig.CLEANUP_POLICY_COMPACT
. - completableSendFuture - Variable in class org.springframework.kafka.requestreply.RequestReplyMessageFuture
- CompositeBatchInterceptor<K,V> - Class in org.springframework.kafka.listener
-
A
BatchInterceptor
that delegates to one or moreBatchInterceptor
s in order. - CompositeBatchInterceptor(BatchInterceptor<K, V>...) - Constructor for class org.springframework.kafka.listener.CompositeBatchInterceptor
-
Construct an instance with the provided delegates.
- CompositeKafkaStreamsCustomizer - Class in org.springframework.kafka.config
-
Composite
KafkaStreamsCustomizer
customizesKafkaStreams
by delegating to a list of providedKafkaStreamsCustomizer
. - CompositeKafkaStreamsCustomizer() - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- CompositeKafkaStreamsCustomizer(List<KafkaStreamsCustomizer>) - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- CompositeKafkaStreamsInfrastructureCustomizer - Class in org.springframework.kafka.config
-
Composite
KafkaStreamsInfrastructureCustomizer
customizesKafkaStreams
by delegating to a list of providedKafkaStreamsInfrastructureCustomizer
. - CompositeKafkaStreamsInfrastructureCustomizer(KafkaStreamsInfrastructureCustomizer...) - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
-
Construct an instance with the provided customizers.
- CompositeProducerListener<K,V> - Class in org.springframework.kafka.support
-
A
ProducerListener
that delegates to a collection of listeners. - CompositeProducerListener(ProducerListener<K, V>...) - Constructor for class org.springframework.kafka.support.CompositeProducerListener
- CompositeRecordInterceptor<K,V> - Class in org.springframework.kafka.listener
-
A
RecordInterceptor
that delegates to one or moreRecordInterceptor
s in order. - CompositeRecordInterceptor(RecordInterceptor<K, V>...) - Constructor for class org.springframework.kafka.listener.CompositeRecordInterceptor
-
Construct an instance with the provided delegates.
- concurrency() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Override the container factory's
concurrency
setting for this listener. - ConcurrentKafkaListenerContainerFactory<K,V> - Class in org.springframework.kafka.config
-
A
KafkaListenerContainerFactory
implementation to build aConcurrentMessageListenerContainer
. - ConcurrentKafkaListenerContainerFactory() - Constructor for class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
- ConcurrentMessageListenerContainer<K,V> - Class in org.springframework.kafka.listener
-
Creates 1 or more
KafkaMessageListenerContainer
s based onconcurrency
. - ConcurrentMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
Construct an instance with the supplied configuration properties.
- config(String, String) - Method in class org.springframework.kafka.config.TopicBuilder
-
Set a configuration option.
- Config - Class in org.springframework.kafka.jdocs.started.noboot
-
Code snippet for quick start.
- Config - Class in org.springframework.kafka.jdocs.topics
-
Snippet for Configuring Topics section.
- Config() - Constructor for class org.springframework.kafka.jdocs.started.noboot.Config
- Config() - Constructor for class org.springframework.kafka.jdocs.topics.Config
- configs(Map<String, String>) - Method in class org.springframework.kafka.config.TopicBuilder
-
Set the configs.
- configure(C) - Method in interface org.springframework.kafka.config.ContainerCustomizer
-
Configure the container.
- configure(Map<String, ?>) - Method in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerde
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- configure(StreamsBuilderFactoryBean) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanConfigurer
-
Configure the factory bean.
- configure(StreamsBuilderFactoryBean) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanCustomizer
-
Deprecated.Configure the factory bean.
- configureBlockingRetries(RetryTopicConfigurationSupport.BlockingRetriesConfigurer) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to configure blocking retries parameters such as exceptions to be retried and the
BackOff
to be used. - configureBuilder(StreamsBuilder) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
- configureBuilder(StreamsBuilder) - Method in interface org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer
-
Configure the builder.
- configureCustomizers(RetryTopicConfigurationSupport.CustomizersConfigurer) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to configure customizers for components created by non-blocking retries' configuration, such as
MessageListenerContainer
,DeadLetterPublishingRecoverer
andDefaultErrorHandler
. - configureDeadLetterPublishingContainerFactory() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to further configure the
DeadLetterPublishingRecovererFactory
. - configureDelegate(Map<String, ?>, boolean, Deserializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- configureDelegate(Map<String, ?>, boolean, Serializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- configureDelegate(Map<String, ?>, boolean, T) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Configure the delegate.
- configureDestinationTopicResolver() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to configure the
DestinationTopicResolver
. - configureKafkaListeners(KafkaListenerEndpointRegistrar) - Method in interface org.springframework.kafka.annotation.KafkaListenerConfigurer
-
Callback allowing a
KafkaListenerEndpointRegistry
and specificKafkaListenerEndpoint
instances to be registered against the givenKafkaListenerEndpointRegistrar
. - configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Create a
HandlerAdapter
for this listener adapter. - configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
- configureListenerContainerFactoryConfigurer() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to further configure the
ListenerContainerFactoryConfigurer
. - configureRetryTopicConfigurer() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method if you need to configure the
RetryTopicConfigurer
. - configureTopology(Topology) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
- configureTopology(Topology) - Method in interface org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer
-
Configure the topology.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Subscribe a consumer to all the embedded topics.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>, boolean) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Subscribe a consumer to all the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, boolean, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Subscribe a consumer to one of the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Subscribe a consumer to one of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, boolean, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Subscribe a consumer to one or more of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Subscribe a consumer to one or more of the embedded topics.
- CONSUMER - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for the
Consumer
object. - CONSUMER_AWARE - org.springframework.kafka.listener.ListenerType
-
Consumer aware.
- consumerAdded(String, Consumer<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory.Listener
-
A new consumer was created.
- consumerAdded(String, Consumer<K, V>) - Method in class org.springframework.kafka.core.MicrometerConsumerListener
- ConsumerAwareBatchErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler that has access to the consumer, for example to adjust offsets after an error.
- ConsumerAwareErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler that has access to the consumer, for example to adjust offsets after an error.
- ConsumerAwareListenerErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler that has access to the consumer.
- ConsumerAwareMessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling individual incoming Kafka messages.
- ConsumerAwareRebalanceListener - Interface in org.springframework.kafka.listener
-
A rebalance listener that provides access to the consumer object.
- ConsumerAwareRecordInterceptor<K,V> - Interface in org.springframework.kafka.listener
-
A
RecordInterceptor
that has access to theConsumer
. - ConsumerAwareRecordRecoverer - Interface in org.springframework.kafka.listener
-
A
ConsumerRecordRecoverer
that supports getting a reference to theConsumer
. - consumerFactory - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- consumerFactory() - Method in class org.springframework.kafka.jdocs.started.noboot.Config
- ConsumerFactory<K,V> - Interface in org.springframework.kafka.core
-
The strategy to produce a
Consumer
instance(s). - ConsumerFactory.Listener<K,V> - Interface in org.springframework.kafka.core
-
Called whenever a consumer is added or removed.
- ConsumerFailedToStartEvent - Class in org.springframework.kafka.event
-
An event published when a consumer fails to start.
- ConsumerFailedToStartEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerFailedToStartEvent
-
Construct an instance with the provided source and container.
- consumerGroupHeader(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 consumer group that failed to consume the original record.
- ConsumerPartitionPausedEvent - Class in org.springframework.kafka.event
-
An event published when a consumer partition is paused.
- ConsumerPartitionPausedEvent(Object, Object, TopicPartition) - Constructor for class org.springframework.kafka.event.ConsumerPartitionPausedEvent
-
Construct an instance with the provided source and partition.
- ConsumerPartitionResumedEvent - Class in org.springframework.kafka.event
-
An event published when a consumer partition is resumed.
- ConsumerPartitionResumedEvent(Object, Object, TopicPartition) - Constructor for class org.springframework.kafka.event.ConsumerPartitionResumedEvent
-
Construct an instance with the provided source and partition.
- ConsumerPausedEvent - Class in org.springframework.kafka.event
-
An event published when a consumer is paused.
- ConsumerPausedEvent(Object, Object, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerPausedEvent
-
Construct an instance with the provided source and partitions.
- ConsumerPausedEvent(Object, Object, Collection<TopicPartition>, String) - Constructor for class org.springframework.kafka.event.ConsumerPausedEvent
-
Construct an instance with the provided source and partitions.
- ConsumerPauseResumeEventPublisher - Interface in org.springframework.kafka.listener
-
Objects that can publish consumer pause/resume events.
- ConsumerPostProcessor<K,V> - Interface in org.springframework.kafka.core
-
Called by consumer factories to perform post processing on newly created consumers.
- ConsumerProperties - Class in org.springframework.kafka.listener
-
Common consumer properties.
- ConsumerProperties(String...) - Constructor for class org.springframework.kafka.listener.ConsumerProperties
-
Create properties for a container that will subscribe to the specified topics.
- ConsumerProperties(Pattern) - Constructor for class org.springframework.kafka.listener.ConsumerProperties
-
Create properties for a container that will subscribe to topics matching the specified pattern.
- ConsumerProperties(TopicPartitionOffset...) - Constructor for class org.springframework.kafka.listener.ConsumerProperties
-
Create properties for a container that will assign itself the provided topic partitions.
- consumerProps(String, String, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Set up test properties for an
<Integer, String>
consumer. - consumerProps(String, String, EmbeddedKafkaBroker) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Set up test properties for an
<Integer, String>
consumer. - ConsumerRecordKeyCondition(K) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyCondition
- ConsumerRecordKeyMatcher(K) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
- ConsumerRecordKeyValueCondition(K, V) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyValueCondition
- ConsumerRecordMetadata - Class in org.springframework.kafka.listener.adapter
-
Used to provide a listener method argument when the user supplies such a parameter.
- ConsumerRecordMetadata(RecordMetadata, TimestampType) - Constructor for class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- ConsumerRecordPartitionCondition(int) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordPartitionCondition
- ConsumerRecordPartitionMatcher(int) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
- ConsumerRecordRecoverer - Interface in org.springframework.kafka.listener
-
A
BiConsumer
extension for recovering consumer records. - ConsumerRecordTimestampCondition(TimestampType, long) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordTimestampCondition
- ConsumerRecordTimestampMatcher(TimestampType, long) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordTimestampMatcher
- ConsumerRecordValueCondition(V) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordValueCondition
- ConsumerRecordValueMatcher(V) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordValueMatcher
- consumerRemoved(String, Consumer<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory.Listener
-
An existing consumer was removed.
- consumerRemoved(String, Consumer<K, V>) - Method in class org.springframework.kafka.core.MicrometerConsumerListener
- ConsumerResumedEvent - Class in org.springframework.kafka.event
-
An event published when a consumer is resumed.
- ConsumerResumedEvent(Object, Object, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerResumedEvent
-
Construct an instance with the provided source and partitions.
- ConsumerSeekAware - Interface in org.springframework.kafka.listener
-
Listeners that implement this interface are provided with a
ConsumerSeekAware.ConsumerSeekCallback
which can be used to perform a seek operation. - ConsumerSeekAware.ConsumerSeekCallback - Interface in org.springframework.kafka.listener
-
A callback that a listener can invoke to seek to a specific offset.
- ConsumerStartedEvent - Class in org.springframework.kafka.event
-
An event published when a consumer has started.
- ConsumerStartedEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerStartedEvent
-
Construct an instance with the provided source and container.
- ConsumerStartingEvent - Class in org.springframework.kafka.event
-
An event published when a consumer is initializing.
- ConsumerStartingEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerStartingEvent
-
Construct an instance with the provided source and container.
- ConsumerStoppedEvent - Class in org.springframework.kafka.event
-
An event published when a consumer is stopped.
- ConsumerStoppedEvent(Object, Object, ConsumerStoppedEvent.Reason) - Constructor for class org.springframework.kafka.event.ConsumerStoppedEvent
-
Construct an instance with the provided source and container.
- ConsumerStoppedEvent.Reason - Enum in org.springframework.kafka.event
-
Reasons for stopping a consumer.
- ConsumerStoppingEvent - Class in org.springframework.kafka.event
-
An event published when a consumer is stopped.
- ConsumerStoppingEvent(Object, Object, Consumer<?, ?>, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerStoppingEvent
-
Construct an instance with the provided source, consumer and partitions.
- ContainerAwareBatchErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler that has access to the batch of records from the last poll the consumer, and the container.
- ContainerAwareErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler that has access to the unprocessed records from the last poll (including the failed record), the consumer, and the container.
- ContainerCustomizer<K,V,C extends AbstractMessageListenerContainer<K,V>> - Interface in org.springframework.kafka.config
-
Called by the container factory after the container is created and configured.
- containerFactory() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
The bean name of the
KafkaListenerContainerFactory
to use to create the message listener container responsible to serve this endpoint. - containerGroup() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
If provided, the listener container for this listener will be added to a bean with this value as its name, of type
Collection<MessageListenerContainer>
. - ContainerGroup - Class in org.springframework.kafka.listener
-
A group of listener containers.
- ContainerGroup(String) - Constructor for class org.springframework.kafka.listener.ContainerGroup
-
Construct an instance with the provided name.
- ContainerGroup(String, List<MessageListenerContainer>) - Constructor for class org.springframework.kafka.listener.ContainerGroup
-
Construct an instance with the provided name and containers.
- ContainerGroup(String, MessageListenerContainer...) - Constructor for class org.springframework.kafka.listener.ContainerGroup
-
Construct an instance with the provided name and containers.
- ContainerGroupSequencer - Class in org.springframework.kafka.listener
-
Sequence the starting of container groups when all containers in the previous group are idle.
- ContainerGroupSequencer(ListenerContainerRegistry, long, String...) - Constructor for class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set containers in each group to not auto start.
- ContainerPartitionPausingBackOffManager - Class in org.springframework.kafka.listener
-
A manager that backs off consumption for a given topic if the timestamp provided is not due.
- ContainerPartitionPausingBackOffManager(ListenerContainerRegistry, BackOffHandler) - Constructor for class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManager
-
Construct an instance with the provided registry and back off handler.
- ContainerPartitionPausingBackOffManagerFactory - Class in org.springframework.kafka.listener
-
A factory for
ContainerPartitionPausingBackOffManager
. - ContainerPartitionPausingBackOffManagerFactory(ListenerContainerRegistry, ApplicationContext) - Constructor for class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManagerFactory
-
Construct an instance with the provided properties.
- ContainerPausingBackOffHandler - Class in org.springframework.kafka.listener
-
A
BackOffHandler
that pauses the container for the backoff. - ContainerPausingBackOffHandler(ListenerContainerPauseService) - Constructor for class org.springframework.kafka.listener.ContainerPausingBackOffHandler
-
Create an instance with the provided
ListenerContainerPauseService
. - ContainerProperties - Class in org.springframework.kafka.listener
-
Contains runtime properties for a listener container.
- ContainerProperties(String...) - Constructor for class org.springframework.kafka.listener.ContainerProperties
-
Create properties for a container that will subscribe to the specified topics.
- ContainerProperties(Pattern) - Constructor for class org.springframework.kafka.listener.ContainerProperties
-
Create properties for a container that will subscribe to topics matching the specified pattern.
- ContainerProperties(TopicPartitionOffset...) - Constructor for class org.springframework.kafka.listener.ContainerProperties
-
Create properties for a container that will assign itself the provided topic partitions.
- ContainerProperties.AckMode - Enum in org.springframework.kafka.listener
-
The offset commit behavior enumeration.
- ContainerProperties.AssignmentCommitOption - Enum in org.springframework.kafka.listener
-
Offset commit behavior during assignment.
- ContainerProperties.EOSMode - Enum in org.springframework.kafka.listener
-
Mode for exactly once semantics.
- ContainerStoppedEvent - Class in org.springframework.kafka.event
-
An event published when a container is stopped.
- ContainerStoppedEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ContainerStoppedEvent
-
Construct an instance with the provided source and container.
- ContainerTestUtils - Class in org.springframework.kafka.test.utils
-
Utilities for testing listener containers.
- contains(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerGroup
-
Return true if the provided container is in this group.
- contentTypeConverter() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Set the bean name of a
SmartMessageConverter
(such as theCompositeMessageConverter
) to use in conjunction with theMessageHeaders.CONTENT_TYPE
header to perform the conversion to the required type. - Context(List<DestinationTopic.Properties>) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
- CONTEXT_ACKNOWLEDGMENT - Static variable in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
RetryContext
attribute key for an acknowledgment if the listener is capable of acknowledging. - CONTEXT_CONSUMER - Static variable in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
RetryContext
attribute key for the consumer if the listener is consumer-aware. - CONTEXT_RECORD - Static variable in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
RetryContext
attribute key for the record. - controlledShutdown() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
- CONVERSION_FAILURES - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing a list of conversion failures (for batch listeners only).
- ConversionException - Exception in org.springframework.kafka.support.converter
-
Exception for conversions.
- ConversionException(String, Throwable) - Constructor for exception org.springframework.kafka.support.converter.ConversionException
-
Construct an instance with the provided properties.
- ConversionException(String, List<ConsumerRecord<?, ?>>, Throwable) - Constructor for exception org.springframework.kafka.support.converter.ConversionException
-
Construct an instance with the provided properties.
- ConversionException(String, ConsumerRecord<?, ?>, Throwable) - Constructor for exception org.springframework.kafka.support.converter.ConversionException
-
Construct an instance with the provided properties.
- ConversionException(String, Message<?>, Throwable) - Constructor for exception org.springframework.kafka.support.converter.ConversionException
-
Construct an instance with the provided properties.
- convert(ConsumerRecord<?, ?>, Type, List<ConversionException>) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Convert the record value.
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.ByteArrayJsonMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.BytesJsonMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Subclasses can convert the payload; by default, it's sent unchanged to Kafka.
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.ProjectingMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.StringJsonMessageConverter
- copyWithConfigurationOverride(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Copy properties of the instance and the given properties to create a new producer factory.
- copyWithConfigurationOverride(Map<String, Object>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Copy the properties of the instance and the given properties to create a new producer factory.
- copyWithType(TypeReference<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Copies this deserializer with same configuration, except new target type reference is used.
- copyWithType(TypeReference<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Copies this serde with same configuration, except new target type reference is used.
- copyWithType(TypeReference<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Copies this serializer with same configuration, except new target type reference is used.
- copyWithType(JavaType) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Copies this deserializer with same configuration, except new target java type is used.
- copyWithType(JavaType) - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Copies this serde with same configuration, except new target java type is used.
- copyWithType(JavaType) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Copies this serializer with same configuration, except new target java type is used.
- copyWithType(Class<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Copies this deserializer with same configuration, except new target type is used.
- copyWithType(Class<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Copies this serde with same configuration, except new target type is used.
- copyWithType(Class<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Copies this serializer with same configuration, except new target type reference is used.
- CORRELATION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing information to correlate requests/replies.
- CorrelationKey - Class in org.springframework.kafka.requestreply
-
Wrapper for byte[] that can be used as a hash key.
- CorrelationKey(byte[]) - Constructor for class org.springframework.kafka.requestreply.CorrelationKey
- count() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
- COUNT - org.springframework.kafka.listener.ContainerProperties.AckMode
-
Commit pending offsets after
ackCount
has been exceeded. - COUNT_TIME - org.springframework.kafka.listener.ContainerProperties.AckMode
- create() - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- create() - Method in interface org.springframework.kafka.listener.KafkaBackOffManagerFactory
- create() - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- create(Headers, Exception, boolean, DeadLetterPublishingRecoverer.HeaderNames) - Method in interface org.springframework.kafka.listener.DeadLetterPublishingRecoverer.ExceptionHeadersCreator
-
Create exception headers.
- create(KafkaOperations<?, ?>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- createComponentFactory() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to provide a subclass of
RetryTopicComponentFactory
with different component implementations or subclasses. - createConsumer() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Create a consumer with the group id and client id as configured in the properties.
- createConsumer(String) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Create a consumer, appending the suffix to the
client.id
property, if present. - createConsumer(String, String) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Create a consumer with an explicit group id; in addition, the client id suffix is appended to the
client.id
property, if both are present. - createConsumer(String, String, String) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Create a consumer with an explicit group id; in addition, the client id suffix is appended to the clientIdPrefix which overrides the
client.id
property, if present. - createConsumer(String, String, String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createConsumer(String, String, String, Properties) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Create a consumer with an explicit group id; in addition, the client id suffix is appended to the clientIdPrefix which overrides the
client.id
property, if present. - createConsumer(String, String, String, Properties) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createContainer(String...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(String...) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
-
Create and configure a container without a listener; used to create containers that are not used for KafkaListener annotations.
- createContainer(Pattern) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(Pattern) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
-
Create and configure a container without a listener; used to create containers that are not used for KafkaListener annotations.
- createContainer(TopicPartitionOffset...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(TopicPartitionOffset...) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
-
Create and configure a container without a listener; used to create containers that are not used for KafkaListener annotations.
- createContainerInstance(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Create an empty container instance.
- createContainerInstance(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
- createContext(long, String, TopicPartition, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.KafkaConsumerBackoffManager
- createDefaultErrorHandlerInstance(DeadLetterPublishingRecoverer) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- createDelegates(String, Map<String, ?>, boolean) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- createDelegates(String, Map<String, ?>, boolean) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- createEndpointCustomizer() - Method in class org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- createEndpointCustomizer(EndpointHandlerMethod, DestinationTopic.Properties) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createErrorHandler(DeadLetterPublishingRecoverer, ListenerContainerFactoryConfigurer.Configuration) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- createHandlerMethodWith(Object, Method) - Static method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createHandlerMethodWith(Object, String) - Static method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createInstance() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- createInstanceAndConfigure(Map<String, ?>, boolean, Map<String, Deserializer<?>>, String, String) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- createInstanceAndConfigure(Map<String, ?>, boolean, Map<String, Serializer<?>>, String, String) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- createInternalRetryTopicClock() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create a
Clock
instance that will be used for all time-related operations in the retry topic processes. - createKafkaConsumer(String, String, String, Properties) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createKafkaConsumer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createKafkaProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Subclasses must return a raw producer which will be wrapped in a
DefaultKafkaProducerFactory.CloseSafeProducer
. - createListenerContainer(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createListenerContainer(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
-
Create a
MessageListenerContainer
for the givenKafkaListenerEndpoint
. - createListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Create and start a new
MessageListenerContainer
using the specified factory. - createManagerFor(Collection<T>, Collection<T>) - Static method in class org.springframework.kafka.support.AllowDenyCollectionManager
- createManagerFor(Collection<T>, Collection<T>, Collection<Predicate<T>>) - Static method in class org.springframework.kafka.support.AllowDenyCollectionManager
- createMappings(String) - Static method in class org.springframework.kafka.support.serializer.JsonSerializer
- createMessageListener(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Create a
MessageListener
that is able to serve this endpoint for the specified container. - createMessageListener(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- createMessageListenerInstance(MessageConverter) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Create an empty
MessagingMessageListenerAdapter
instance. - createMessagingErrorMessage(String, Object) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- createNewTopicBeans(Collection<String>, RetryTopicConfiguration.TopicCreation) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createNonTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createNonTransactionalProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Create a non-transactional producer.
- createOffsetAndMetadata(MessageListenerContainer, long) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Create a new
OffsetAndMetadata
using the given container and offset. - createOrModifyTopics(NewTopic...) - Method in class org.springframework.kafka.core.KafkaAdmin
- createOrModifyTopics(NewTopic...) - Method in interface org.springframework.kafka.core.KafkaAdminOperations
-
Create topics if they don't exist or increase the number of partitions if needed.
- createProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Create a producer which will be transactional if the factory is so configured.
- createProducer(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createProducer(String) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Create a producer with an overridden transaction id prefix.
- createProducerRecord(ConsumerRecord<?, ?>, TopicPartition, Headers, byte[], byte[]) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Subclasses can override this method to customize the producer record to send to the DLQ.
- createProperties() - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory
- createRawConsumer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Create a Consumer.
- createRawProducer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createRetryTopicNamesProvider(DestinationTopic.Properties) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory
- createRetryTopicNamesProvider(DestinationTopic.Properties) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory
- createSimpleLoggingConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return default implementation of
ConsumerRebalanceListener
instance. - createTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Subclasses must return a producer from the
DefaultKafkaProducerFactory.getCache()
or a new raw producer wrapped in aDefaultKafkaProducerFactory.CloseSafeProducer
. - createTransactionalProducer(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createTransactionalProducerForPartition() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createTransactionalProducerForPartition(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- customBackoff(SleepingBackOffPolicy<?>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- customize(KafkaStreams) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- customize(KafkaStreams) - Method in interface org.springframework.kafka.config.KafkaStreamsCustomizer
- customizeAndRegisterTopics(RetryTopicNamesProviderFactory.RetryTopicNamesProvider, MethodKafkaListenerEndpoint<?, ?>) - Method in class org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- customizeDeadLetterPublishingRecoverer(Consumer<DeadLetterPublishingRecoverer>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
-
Customize the
DeadLetterPublishingRecoverer
that will be used to forward the records to the retry topics and DLT. - customizeEndpointAndCollectTopics(MethodKafkaListenerEndpoint<?, ?>) - Method in interface org.springframework.kafka.retrytopic.EndpointCustomizer
-
Customize the endpoint and return the topic names generated for this endpoint.
- customizeErrorHandler(Consumer<DefaultErrorHandler>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
-
Customize the
CommonErrorHandler
instances that will be used for the feature. - customizeListenerContainer(Consumer<ConcurrentMessageListenerContainer<?, ?>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
-
Customize the
ConcurrentMessageListenerContainer
instances created for the retry and DLT consumers. - CustomizersConfigurer() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
D
- DeadLetterPublishingRecoverer - Class in org.springframework.kafka.listener
-
A
ConsumerRecordRecoverer
that publishes a failed record to a dead-letter topic. - DeadLetterPublishingRecoverer(Function<ProducerRecord<?, ?>, KafkaOperations<?, ?>>, boolean, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Create an instance with a template resolving function that receives the failed consumer record and the exception and returns a
KafkaOperations
and a flag on whether or not the publishing from this instance will be transactional or not. - DeadLetterPublishingRecoverer(Map<Class<?>, KafkaOperations<? extends Object, ? extends Object>>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Create an instance with the provided templates and a default destination resolving function that returns a TopicPartition based on the original topic (appended with ".DLT") from the failed record, and the same partition as the failed record.
- DeadLetterPublishingRecoverer(Map<Class<?>, KafkaOperations<? extends Object, ? extends Object>>, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Create an instance with the provided templates and destination resolving function, that receives the failed consumer record and the exception and returns a
TopicPartition
. - DeadLetterPublishingRecoverer(KafkaOperations<? extends Object, ? extends Object>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Create an instance with the provided template and a default destination resolving function that returns a TopicPartition based on the original topic (appended with ".DLT") from the failed record, and the same partition as the failed record.
- DeadLetterPublishingRecoverer(KafkaOperations<? extends Object, ? extends Object>, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Create an instance with the provided template and destination resolving function, that receives the failed consumer record and the exception and returns a
TopicPartition
. - DeadLetterPublishingRecoverer.ExceptionHeadersCreator - Interface in org.springframework.kafka.listener
-
Use this to provide a custom implementation to take complete control over exception header creation for the output record.
- DeadLetterPublishingRecoverer.HeaderNames - Class in org.springframework.kafka.listener
-
Container class for the name of the headers that will be added to the produced record.
- DeadLetterPublishingRecoverer.HeaderNames.Builder - Class in org.springframework.kafka.listener
-
Provides a convenient API for creating
DeadLetterPublishingRecoverer.HeaderNames
. - DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo - Class in org.springframework.kafka.listener
-
Headers for data relative to the exception thrown.
- DeadLetterPublishingRecoverer.HeaderNames.Builder.Original - Class in org.springframework.kafka.listener
-
Headers for data relative to the original record.
- DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo - Class in org.springframework.kafka.listener
-
Header names for exception headers.
- DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd - Enum in org.springframework.kafka.listener
-
Bits representing which headers to add.
- DeadLetterPublishingRecoverer.HeaderNames.Original - Class in org.springframework.kafka.listener
-
Header names for original record property headers.
- DeadLetterPublishingRecoverer.SingleRecordHeader - Class in org.springframework.kafka.listener
-
A
Header
that indicates that this header should replace any existing headers with this name, rather than being appended to the headers, which is the normal behavior. - deadLetterPublishingRecovererFactory(DestinationTopicResolver) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the
DeadLetterPublishingRecovererFactory
that will be used to create theDeadLetterPublishingRecoverer
to forward the records to a givenDestinationTopic
. - DeadLetterPublishingRecovererFactory - Class in org.springframework.kafka.retrytopic
-
Creates and configures the
DeadLetterPublishingRecoverer
that will be used to forward the messages using theDestinationTopicResolver
. - DeadLetterPublishingRecovererFactory(DestinationTopicResolver) - Constructor for class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- DEBUG - org.springframework.kafka.KafkaException.Level
-
Debug.
- DEBUG - org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Debug.
- decorateFactory(ConcurrentKafkaListenerContainerFactory<?, ?>, ListenerContainerFactoryConfigurer.Configuration) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Decorates the provided
ConcurrentKafkaListenerContainerFactory
. - decorateFactoryWithoutSettingContainerProperties(ConcurrentKafkaListenerContainerFactory<?, ?>, ListenerContainerFactoryConfigurer.Configuration) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Decorates the provided
ConcurrentKafkaListenerContainerFactory
. - DEFAULT_ADMIN_TIMEOUT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- DEFAULT_BACK_OFF - Static variable in class org.springframework.kafka.listener.SeekUtils
-
The default back off - a
FixedBackOff
with 0 interval andSeekUtils.DEFAULT_MAX_FAILURES
- 1 retry attempts. - DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Default header name for type information.
- DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
The default
Duration
of10 seconds
for close timeout. - DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.kafka.core.KafkaAdmin
-
The default close timeout duration as 10 seconds.
- DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.kafka.core.ProducerFactoryUtils
-
The default close timeout (5 seconds).
- DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Default header name for container object contents type information.
- DEFAULT_DLT_HANDLER - Static variable in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
-
The default method to handle messages in the DLT.
- DEFAULT_DLT_SUFFIX - Static variable in class org.springframework.kafka.retrytopic.RetryTopicConstants
-
Default suffix for dlt.
- DEFAULT_HEADER_ATTEMPTS - Static variable in class org.springframework.kafka.retrytopic.RetryTopicHeaders
-
The default header for the attempts.
- DEFAULT_HEADER_BACKOFF_TIMESTAMP - Static variable in class org.springframework.kafka.retrytopic.RetryTopicHeaders
-
The default header for the backoff duetimestamp.
- DEFAULT_HEADER_ORIGINAL_TIMESTAMP - Static variable in class org.springframework.kafka.retrytopic.RetryTopicHeaders
-
The default header for the original message's timestamp.
- DEFAULT_KAFKA_LISTENER_CONTAINER_FACTORY_BEAN_NAME - Static variable in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
The bean name of the default
KafkaListenerContainerFactory
. - DEFAULT_KAFKA_TEMPLATE_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
-
The bean name of the internally managed listener container factory.
- DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Default header name for map key type information.
- DEFAULT_LISTENER_CONTAINER_FACTORY_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
-
The bean name of the internally managed listener container factory.
- DEFAULT_MAX_ATTEMPTS - Static variable in class org.springframework.kafka.retrytopic.RetryTopicConstants
-
Default number of times the message processing should be attempted, including the first.
- DEFAULT_MAX_CONTENT_LOGGED - Static variable in class org.springframework.kafka.support.LoggingProducerListener
-
Default max content logged.
- DEFAULT_MAX_FAILURES - Static variable in class org.springframework.kafka.listener.SeekUtils
-
The number of times a topic/partition/offset can fail before being rejected.
- DEFAULT_MONITOR_INTERVAL - Static variable in class org.springframework.kafka.listener.ContainerProperties
-
The default
monitorInterval
(s). - DEFAULT_NO_POLL_THRESHOLD - Static variable in class org.springframework.kafka.listener.ContainerProperties
-
The default
noPollThreshold
. - DEFAULT_PHASE - Static variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
The default
SmartLifecycle
phase for listener containers 2147483547. - DEFAULT_PHYSICAL_CLOSE_TIMEOUT - Static variable in interface org.springframework.kafka.core.ProducerFactory
-
The default close timeout duration as 30 seconds.
- DEFAULT_POLL_TIMEOUT - Static variable in interface org.springframework.kafka.core.KafkaOperations
-
Default timeout for
KafkaOperations.receive(String, int, long)
. - DEFAULT_POLL_TIMEOUT - Static variable in interface org.springframework.kafka.core.KafkaOperations2
-
Default timeout for
KafkaOperations2.receive(String, int, long)
. - DEFAULT_POLL_TIMEOUT - Static variable in class org.springframework.kafka.listener.ConsumerProperties
-
The default
pollTimeout
(ms). - DEFAULT_PORT - Static variable in class org.springframework.kafka.test.core.BrokerAddress
- DEFAULT_RETRY_SUFFIX - Static variable in class org.springframework.kafka.retrytopic.RetryTopicConstants
-
Default suffix for retry topics.
- DEFAULT_RETRY_TOPIC_CONFIG_SUPPORT_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
-
The bean name of an internally managed retry topic configuration support, if needed.
- DEFAULT_SCHEDULER_WRAPPER_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
-
The bean name of the internally registered scheduler wrapper, if needed.
- DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class org.springframework.kafka.listener.ContainerProperties
-
The default
shutDownTimeout
(ms). - DEFAULT_STREAMS_BUILDER_BEAN_NAME - Static variable in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
-
The bean name for auto-configured default
StreamsBuilderFactoryBean
. - DEFAULT_STREAMS_CONFIG_BEAN_NAME - Static variable in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
-
The bean name for the
StreamsConfig
to be used for the defaultStreamsBuilderFactoryBean
bean definition. - DEFAULT_ZK_CONNECTION_TIMEOUT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- DefaultAfterRollbackProcessor<K,V> - Class in org.springframework.kafka.listener
-
Default implementation of
AfterRollbackProcessor
. - DefaultAfterRollbackProcessor() - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
-
Construct an instance with the default recoverer which simply logs the record after 10 (maxFailures) have occurred for a topic/partition/offset.
- DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
-
Construct an instance with the provided recoverer which will be called after 10 (maxFailures) have occurred for a topic/partition/offset.
- DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
-
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
- DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff, KafkaOperations<?, ?>, boolean) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
-
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
- DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff, BackOffHandler, KafkaOperations<?, ?>, boolean) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
-
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
- DefaultAfterRollbackProcessor(BackOff) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
-
Construct an instance with the default recoverer which simply logs the record after the backOff returns STOP for a topic/partition/offset.
- DefaultBackOffHandler - Class in org.springframework.kafka.listener
-
Default
BackOffHandler
; suspends the thread for the back off. - DefaultBackOffHandler() - Constructor for class org.springframework.kafka.listener.DefaultBackOffHandler
- DefaultBatchToRecordAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
The default
BatchToRecordAdapter
implementation; if the supplied recoverer throws an exception, the batch will be aborted; otherwise the next record will be processed. - DefaultBatchToRecordAdapter() - Constructor for class org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter
-
Construct an instance with the default recoverer which simply logs the failed record.
- DefaultBatchToRecordAdapter(ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter
-
Construct an instance with the provided recoverer.
- defaultBranch(Consumer<? super KStream<K, V>>) - Method in class org.springframework.kafka.support.KafkaStreamBrancher
-
Defines a default branch.
- DefaultDestinationTopicProcessor - Class in org.springframework.kafka.retrytopic
-
Default implementation of the
DestinationTopicProcessor
interface. - DefaultDestinationTopicProcessor(DestinationTopicResolver) - Constructor for class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- DefaultDestinationTopicResolver - Class in org.springframework.kafka.retrytopic
-
Default implementation of the
DestinationTopicResolver
interface. - DefaultDestinationTopicResolver() - Constructor for class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
-
Constructs an instance with a default clock.
- DefaultDestinationTopicResolver(Clock) - Constructor for class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
-
Constructs an instance with the given clock.
- DefaultDestinationTopicResolver(Clock, ApplicationContext) - Constructor for class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
-
Deprecated.
- DefaultDestinationTopicResolver.DestinationTopicHolder - Class in org.springframework.kafka.retrytopic
- DefaultErrorHandler - Class in org.springframework.kafka.listener
-
An error handler that, for record listeners, seeks to the current offset for each topic in the remaining records.
- DefaultErrorHandler() - Constructor for class org.springframework.kafka.listener.DefaultErrorHandler
-
Construct an instance with the default recoverer which simply logs the record after 10 (maxFailures) have occurred for a topic/partition/offset, with the default back off (9 retries, no delay).
- DefaultErrorHandler(ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.listener.DefaultErrorHandler
-
Construct an instance with the provided recoverer which will be called after 10 (maxFailures) have occurred for a topic/partition/offset.
- DefaultErrorHandler(ConsumerRecordRecoverer, BackOff) - Constructor for class org.springframework.kafka.listener.DefaultErrorHandler
-
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
- DefaultErrorHandler(ConsumerRecordRecoverer, BackOff, BackOffHandler) - Constructor for class org.springframework.kafka.listener.DefaultErrorHandler
-
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
- DefaultErrorHandler(BackOff) - Constructor for class org.springframework.kafka.listener.DefaultErrorHandler
-
Construct an instance with the default recoverer which simply logs the record after the backOff returns STOP for a topic/partition/offset.
- defaultFalse() - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
By default, unmatched types classify as true.
- defaultFatalExceptionsList() - Static method in class org.springframework.kafka.listener.ExceptionClassifier
-
Return a list of the framework default fatal exceptions.
- DefaultJackson2JavaTypeMapper - Class in org.springframework.kafka.support.mapping
-
Jackson 2 type mapper.
- DefaultJackson2JavaTypeMapper() - Constructor for class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- DefaultKafkaConsumerFactory<K,V> - Class in org.springframework.kafka.core
-
The
ConsumerFactory
implementation to produce newConsumer
instances for providedMap
configs
and optionalDeserializer
s on eachConsumerFactory.createConsumer()
invocation. - DefaultKafkaConsumerFactory(Map<String, Object>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Construct a factory with the provided configuration.
- DefaultKafkaConsumerFactory(Map<String, Object>, Supplier<Deserializer<K>>, Supplier<Deserializer<V>>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Construct a factory with the provided configuration and deserializer suppliers.
- DefaultKafkaConsumerFactory(Map<String, Object>, Supplier<Deserializer<K>>, Supplier<Deserializer<V>>, boolean) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Construct a factory with the provided configuration and deserializer suppliers.
- DefaultKafkaConsumerFactory(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Construct a factory with the provided configuration and deserializers.
- DefaultKafkaConsumerFactory(Map<String, Object>, Deserializer<K>, Deserializer<V>, boolean) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Construct a factory with the provided configuration and deserializers.
- DefaultKafkaHeaderMapper - Class in org.springframework.kafka.support
-
Default header mapper for Apache Kafka.
- DefaultKafkaHeaderMapper() - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Construct an instance with the default object mapper and default header patterns for outbound headers; all inbound headers are mapped.
- DefaultKafkaHeaderMapper(ObjectMapper) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Construct an instance with the provided object mapper and default header patterns for outbound headers; all inbound headers are mapped.
- DefaultKafkaHeaderMapper(ObjectMapper, String...) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Construct an instance with the provided object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
- DefaultKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Construct an instance with a default object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
- DefaultKafkaHeaderMapper.NonTrustedHeaderType - Class in org.springframework.kafka.support
-
Represents a header that could not be decoded due to an untrusted type.
- DefaultKafkaProducerFactory<K,V> - Class in org.springframework.kafka.core
- DefaultKafkaProducerFactory(Map<String, Object>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Construct a factory with the provided configuration.
- DefaultKafkaProducerFactory(Map<String, Object>, Supplier<Serializer<K>>, Supplier<Serializer<V>>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Construct a factory with the provided configuration and
Serializer
Suppliers. - DefaultKafkaProducerFactory(Map<String, Object>, Supplier<Serializer<K>>, Supplier<Serializer<V>>, boolean) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Construct a factory with the provided configuration and
Serializer
Suppliers. - DefaultKafkaProducerFactory(Map<String, Object>, Serializer<K>, Serializer<V>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Construct a factory with the provided configuration and
Serializer
s. - DefaultKafkaProducerFactory(Map<String, Object>, Serializer<K>, Serializer<V>, boolean) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Construct a factory with the provided configuration and
Serializer
s. - DefaultKafkaProducerFactory.CloseSafeProducer<K,V> - Class in org.springframework.kafka.core
-
A wrapper class for the delegate.
- defaultKafkaStreamsBuilder(ObjectProvider<KafkaStreamsConfiguration>, ObjectProvider<StreamsBuilderFactoryBeanConfigurer>) - Method in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
-
Bean for the default
StreamsBuilderFactoryBean
. - defaultPropertyOverrides() - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Return a
Properties
object equal to the default consumer property overrides. - delay() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- delegate - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- delegateType - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- DelegatingByTopicDeserializer - Class in org.springframework.kafka.support.serializer
-
A
Deserializer
that delegates to other deserializers based on the topic name. - DelegatingByTopicDeserializer() - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
-
Construct an instance that will be configured in
DelegatingByTopicDeserializer.configure(Map, boolean)
with consumer properties. - DelegatingByTopicDeserializer(Map<Pattern, Deserializer<?>>, Deserializer<?>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
-
Construct an instance with the supplied mapping of topic name patterns to delegate deserializers.
- DelegatingByTopicSerialization<T extends java.io.Closeable> - Class in org.springframework.kafka.support.serializer
-
Base class with common code for delegating by topic serialization.
- DelegatingByTopicSerialization() - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- DelegatingByTopicSerialization(Map<Pattern, T>, T) - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- DelegatingByTopicSerializer - Class in org.springframework.kafka.support.serializer
-
A
Serializer
that delegates to other serializers based on a topic pattern. - DelegatingByTopicSerializer() - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
-
Construct an instance that will be configured in
DelegatingByTopicSerializer.configure(Map, boolean)
with producer propertiesDelegatingByTopicSerialization.VALUE_SERIALIZATION_TOPIC_CONFIG
andDelegatingByTopicSerialization.KEY_SERIALIZATION_TOPIC_CONFIG
. - DelegatingByTopicSerializer(Map<Pattern, Serializer<?>>, Serializer<?>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
-
Construct an instance with the supplied mapping of topic patterns to delegate serializers.
- DelegatingByTypeSerializer - Class in org.springframework.kafka.support.serializer
-
Delegates to a serializer based on type.
- DelegatingByTypeSerializer(Map<Class<?>, Serializer>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
-
Construct an instance with the map of delegates; keys matched exactly.
- DelegatingByTypeSerializer(Map<Class<?>, Serializer>, boolean) - Constructor for class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
-
Construct an instance with the map of delegates; keys matched exactly or if the target object is assignable to the key, depending on the assignable argument.
- DelegatingDeserializer - Class in org.springframework.kafka.support.serializer
-
A
Deserializer
that delegates to other deserializers based on a serialization selector header. - DelegatingDeserializer() - Constructor for class org.springframework.kafka.support.serializer.DelegatingDeserializer
-
Construct an instance that will be configured in
DelegatingDeserializer.configure(Map, boolean)
with consumer propertiesDelegatingSerializer.KEY_SERIALIZATION_SELECTOR_CONFIG
andDelegatingSerializer.VALUE_SERIALIZATION_SELECTOR_CONFIG
. - DelegatingDeserializer(Map<String, Deserializer<?>>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingDeserializer
-
Construct an instance with the supplied mapping of selectors to delegate deserializers.
- DelegatingInvocableHandler - Class in org.springframework.kafka.listener.adapter
-
Delegates to an
InvocableHandlerMethod
based on the message payload type. - DelegatingInvocableHandler(List<InvocableHandlerMethod>, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
- DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
- DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext, BeanFactory, Validator) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Construct an instance with the supplied handlers for the bean.
- DelegatingMessageListener<T> - Interface in org.springframework.kafka.listener
-
Classes implementing this interface allow containers to determine the type of the ultimate listener.
- DelegatingSerializer - Class in org.springframework.kafka.support.serializer
-
A
Serializer
that delegates to other serializers based on a serialization selector header. - DelegatingSerializer() - Constructor for class org.springframework.kafka.support.serializer.DelegatingSerializer
-
Construct an instance that will be configured in
DelegatingSerializer.configure(Map, boolean)
with producer propertiesDelegatingSerializer.VALUE_SERIALIZATION_SELECTOR_CONFIG
andDelegatingSerializer.KEY_SERIALIZATION_SELECTOR_CONFIG
. - DelegatingSerializer(Map<String, Serializer<?>>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingSerializer
-
Construct an instance with the supplied mapping of selectors to delegate serializers.
- DELIVERY_ATTEMPT - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
For inbound messages, when container retries are enabled the delivery attempt.
- deliveryAttempt(TopicPartitionOffset) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
- deliveryAttempt(TopicPartitionOffset) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- deliveryAttempt(TopicPartitionOffset) - Method in interface org.springframework.kafka.listener.DeliveryAttemptAware
-
Return the next delivery attempt for the topic/partition/offset.
- deliveryAttempt(TopicPartitionOffset) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
- DeliveryAttemptAware - Interface in org.springframework.kafka.listener
-
A component implementing this interface can provide the next delivery attempt.
- deliveryAttemptHeader() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Return true if this error handler supports delivery attempts headers.
- deliveryAttemptHeader() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- deliveryAttemptHeader() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
- describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
- describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordTimestampMatcher
- describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordValueMatcher
- describeTopics(String...) - Method in class org.springframework.kafka.core.KafkaAdmin
- describeTopics(String...) - Method in interface org.springframework.kafka.core.KafkaAdminOperations
-
Obtain
TopicDescription
s for these topics. - deserializationException(Headers, byte[], Exception, boolean) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
-
Populate the record headers with a serialized
DeserializationException
. - DeserializationException - Exception in org.springframework.kafka.support.serializer
-
Exception returned in the consumer record value or key when a deserialization failure occurs.
- DeserializationException(String, byte[], boolean, Throwable) - Constructor for exception org.springframework.kafka.support.serializer.DeserializationException
-
Construct an instance with the provided properties.
- deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
- deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
- deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
- deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
- deserializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
- deserializer() - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
- DESERIALIZER_EXCEPTION_HEADER_PREFIX - Static variable in class org.springframework.kafka.support.serializer.SerializationUtils
-
Header name for deserialization exceptions.
- DESTINATION_TOPIC_RESOLVER_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
-
The bean name of the internally managed destination topic resolver.
- destinationsByTopicMap - Variable in class org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
- DestinationTopic - Class in org.springframework.kafka.retrytopic
-
Representation of a Destination Topic to which messages can be forwarded, such as retry topics and dlt.
- DestinationTopic(String, DestinationTopic.Properties) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic
- DestinationTopic(String, DestinationTopic, String, DestinationTopic.Type) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic
- DestinationTopic.Properties - Class in org.springframework.kafka.retrytopic
- DestinationTopicContainer - Interface in org.springframework.kafka.retrytopic
-
Provides methods to store and retrieve
DestinationTopic
instances. - destinationTopicProcessor(DestinationTopicResolver) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the
DestinationTopicProcessor
that will be used to process theDestinationTopic
instances and store them in the providedDestinationTopicResolver
. - DestinationTopicProcessor - Interface in org.springframework.kafka.retrytopic
-
The
DestinationTopicProcessor
creates and registers theDestinationTopic
instances in the providedDestinationTopicProcessor.Context
, also providing callback interfaces to be called upon the context properties. - DestinationTopicProcessor.Context - Class in org.springframework.kafka.retrytopic
- DestinationTopicPropertiesFactory - Class in org.springframework.kafka.retrytopic
-
Creates a list of
DestinationTopic.Properties
based on the provided configurations. - DestinationTopicPropertiesFactory(String, String, List<Long>, BinaryExceptionClassifier, int, KafkaOperations<?, ?>, FixedDelayStrategy, DltStrategy, TopicSuffixingStrategy, long) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory
- DestinationTopicPropertiesFactory.DestinationTopicSuffixes - Class in org.springframework.kafka.retrytopic
- destinationTopicResolver() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the instance of
DestinationTopicResolver
that will be used to store theDestinationTopic
instance and resolve which a given record should be forwarded to. - destinationTopicResolver() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Return a global
DestinationTopicResolver
for resolving theDestinationTopic
to which a givenConsumerRecord
should be sent for retry. - DestinationTopicResolver - Interface in org.springframework.kafka.retrytopic
-
Provides methods for resolving the destination to which a message that failed to be processed should be forwarded to.
- DestinationTopicSuffixes(String, String) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory.DestinationTopicSuffixes
- destroy() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- destroy() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- destroy() - Method in class org.springframework.kafka.core.KafkaTemplate
- destroy() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- destroy() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
- destroy() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- destroy() - Method in class org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper
- destroy() - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- destroy() - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Remove the timers.
- destroy() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- determineInferredType(Method) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Subclasses can override this method to use a different mechanism to determine the target type of the payload conversion.
- determineListenerType(Object) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Determine the type of the listener.
- determineSendTimeout(Map<String, Object>, long, long) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Return the timeout to use when sending records.
- determineSendTimeout(KafkaOperations<?, ?>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Determine the send timeout based on the template's producer factory and
DeadLetterPublishingRecoverer.setWaitForSendResultTimeout(Duration)
. - DLT_EXCEPTION_CAUSE_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception cause class name for a record published sent to a dead-letter topic.
- DLT_EXCEPTION_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception class name for a record published sent to a dead-letter topic.
- DLT_EXCEPTION_MESSAGE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception message for a record published to a dead-letter topic.
- DLT_EXCEPTION_STACKTRACE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception stack trace for a record published to a dead-letter topic.
- DLT_KEY_EXCEPTION_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception class name for a record published sent to a dead-letter topic with a key deserialization exception.
- DLT_KEY_EXCEPTION_MESSAGE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception message for a record published to a dead-letter topic with a key deserialization exception.
- DLT_KEY_EXCEPTION_STACKTRACE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception stack trace for a record published to a dead-letter topic with a key deserialization exception.
- DLT_ORIGINAL_CONSUMER_GROUP - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Consumer group that failed to consumer a record published to a dead-letter topic.
- DLT_ORIGINAL_OFFSET - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Original offset for a record published to a dead-letter topic.
- DLT_ORIGINAL_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Original partition for a record published to a dead-letter topic.
- DLT_ORIGINAL_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Original timestamp for a record published to a dead-letter topic.
- DLT_ORIGINAL_TIMESTAMP_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Original timestamp type for a record published to a dead-letter topic.
- DLT_ORIGINAL_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Original topic for a record published to a dead-letter topic.
- DltHandler - Annotation Type in org.springframework.kafka.annotation
-
Annotation to determine the method the should process the DLT topic message.
- dltHandlerMethod(Class<?>, String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Deprecated.
- dltHandlerMethod(String, String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure a DLT handler method.
- dltHandlerMethod(EndpointHandlerMethod) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- dltProcessingFailureStrategy(DltStrategy) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- dltStrategy() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Whether or not create a DLT, and redeliver to the DLT if delivery fails or just give up.
- DltStrategy - Enum in org.springframework.kafka.retrytopic
-
Strategies for handling DLT processing.
- dltSuffix(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- dltTopicSuffix() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The suffix that will be appended to the main topic in order to generate the dlt topic.
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doCleanupAfterCompletion(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doCommit(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doCreateManager(ListenerContainerRegistry) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- doCreateManager(ListenerContainerRegistry) - Method in class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManagerFactory
- doGetTransaction() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doHandle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- doInKafka(Producer<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations.ProducerCallback
- doInOperations(KafkaOperations<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations.OperationsCallback
- doNotAutoCreateRetryTopics() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- doNotConfigureDlt() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- doNotRetryOnDltFailure() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- dontRemoveTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Don't remove type information headers.
- dontRemoveTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Don't remove type information headers after deserialization.
- doOnConsumer(Function<Consumer<K, V>, ? extends T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- doOnProducer(Function<Producer<K, V>, ? extends T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- doResume(Object, Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doRollback(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doSeeks(List<ConsumerRecord<?, ?>>, Consumer<?, ?>, Exception, boolean, BiPredicate<ConsumerRecord<?, ?>, Exception>, LogAccessor) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Seek records to earliest position, optionally skipping the first.
- doSeeks(List<ConsumerRecord<?, ?>>, Consumer<?, ?>, Exception, boolean, RecoveryStrategy, MessageListenerContainer, LogAccessor) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Seek records to earliest position, optionally skipping the first.
- doSend(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Send the producer record.
- doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doStart() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- doStart() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- doStart() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- doStop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- doStop(Runnable, boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Stop the container normally or abnormally.
- doStop(Runnable, boolean) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- doStop(Runnable, boolean) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- doSuspend(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- doWithAdmin(Consumer<AdminClient>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Create an
AdminClient
; invoke the callback and reliably close the admin. - doWithAdminFunction(Function<AdminClient, T>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Create an
AdminClient
; invoke the callback and reliably close the admin.
E
- EmbeddedKafka - Annotation Type in org.springframework.kafka.test.context
-
Annotation that can be specified on a test class that runs Spring for Apache Kafka based tests.
- EmbeddedKafkaBroker - Class in org.springframework.kafka.test
-
An embedded Kafka Broker(s) and Zookeeper manager.
- EmbeddedKafkaBroker(int) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker
- EmbeddedKafkaBroker(int, boolean, int, String...) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Create embedded Kafka brokers listening on random ports.
- EmbeddedKafkaBroker(int, boolean, String...) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Create embedded Kafka brokers.
- EmbeddedKafkaBroker.EmbeddedZookeeper - Class in org.springframework.kafka.test
-
Ported from scala to allow setting the port.
- EmbeddedKafkaCondition - Class in org.springframework.kafka.test.condition
-
JUnit5 condition for an embedded broker.
- EmbeddedKafkaCondition() - Constructor for class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- EmbeddedKafkaRule - Class in org.springframework.kafka.test.rule
-
A
TestRule
wrapper around anEmbeddedKafkaBroker
. - EmbeddedKafkaRule(int) - Constructor for class org.springframework.kafka.test.rule.EmbeddedKafkaRule
- EmbeddedKafkaRule(int, boolean, int, String...) - Constructor for class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Create embedded Kafka brokers listening on random ports.
- EmbeddedKafkaRule(int, boolean, String...) - Constructor for class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Create embedded Kafka brokers.
- EmbeddedZookeeper(int) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- EnableKafka - Annotation Type in org.springframework.kafka.annotation
-
Enable Kafka listener annotated endpoints that are created under the covers by a
AbstractListenerContainerFactory
. - EnableKafkaRetryTopic - Annotation Type in org.springframework.kafka.annotation
-
Enables the non-blocking topic-based delayed retries feature.
- EnableKafkaStreams - Annotation Type in org.springframework.kafka.annotation
-
Enable default Kafka Streams components.
- END - org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
-
Seek to the end.
- endOffsets(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- EndpointCustomizer - Interface in org.springframework.kafka.retrytopic
-
Customizes main, retry and DLT endpoints in the Retry Topic functionality and returns the resulting topic names.
- EndpointCustomizer.TopicNamesHolder - Class in org.springframework.kafka.retrytopic
- EndpointCustomizerFactory - Class in org.springframework.kafka.retrytopic
-
Creates the
EndpointCustomizer
that will be used by theRetryTopicConfigurer
to customize the main, retry and DLT endpoints. - EndpointCustomizerFactory(DestinationTopic.Properties, EndpointHandlerMethod, BeanFactory, RetryTopicNamesProviderFactory) - Constructor for class org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- EndpointHandlerMethod - Class in org.springframework.kafka.support
-
Handler method for retrying endpoints.
- EndpointHandlerMethod(Object, Method) - Constructor for class org.springframework.kafka.support.EndpointHandlerMethod
- EndpointHandlerMethod(Object, String) - Constructor for class org.springframework.kafka.support.EndpointHandlerMethod
- enhancedObjectMapper() - Static method in class org.springframework.kafka.support.JacksonUtils
-
Factory for
ObjectMapper
instances with registered well-known modules and disabledMapperFeature.DEFAULT_VIEW_INCLUSION
andDeserializationFeature.FAIL_ON_UNKNOWN_PROPERTIES
features. - enhancedObjectMapper(ClassLoader) - Static method in class org.springframework.kafka.support.JacksonUtils
-
Deprecated.since 2.7.5 in favor of
JacksonUtils.enhancedObjectMapper()
- equals(Object) - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- equals(Object) - Method in class org.springframework.kafka.requestreply.CorrelationKey
- equals(Object) - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- equals(Object) - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- equals(Object) - Method in class org.springframework.kafka.support.TopicPartitionOffset
- equals(Object) - Method in class org.springframework.kafka.test.core.BrokerAddress
- ERROR - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
A
Error
was thrown. - ERROR - org.springframework.kafka.KafkaException.Level
-
Error.
- ERROR - org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Error.
- errorHandler() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Set an
KafkaListenerErrorHandler
bean name to invoke if the listener method throws an exception. - ErrorHandler - Interface in org.springframework.kafka.listener
-
Handles errors thrown during the execution of a
MessageListener
. - ErrorHandlingDeserializer<T> - Class in org.springframework.kafka.support.serializer
-
Delegating key/value deserializer that catches exceptions, returning them in the headers as serialized java objects.
- ErrorHandlingDeserializer() - Constructor for class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- ErrorHandlingDeserializer(Deserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- ErrorHandlingUtils - Class in org.springframework.kafka.listener
-
Utilities for error handling.
- evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
- EX_CAUSE - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The exception cause class name.
- EX_MSG - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The exception message.
- EX_STACKTRACE - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The exception stack trace.
- exception() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
-
Returns the exception builder.
- EXCEPTION - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The exception class name.
- EXCEPTION_CAUSE_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception class name for a record published sent to another topic.
- EXCEPTION_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception class name for a record published sent to another topic.
- EXCEPTION_MESSAGE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception message for a record published to another topic.
- EXCEPTION_STACKTRACE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception stack trace for a record published to another topic.
- exceptionCauseFqcn(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the exceptionCauseFqcn of the original record.
- ExceptionClassifier - Class in org.springframework.kafka.listener
-
Supports exception classification.
- ExceptionClassifier() - Constructor for class org.springframework.kafka.listener.ExceptionClassifier
-
Construct the instance.
- exceptionFqcn(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the exceptionFqcn of the original record.
- ExceptionInfo() - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
- exceptionMessage(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the exceptionMessage of the original record.
- exceptionStacktrace(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the exceptionStacktrace of the original record.
- exchange(Message<?>) - Method in interface org.springframework.kafka.streams.messaging.MessagingFunction
- exclude() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The exception types that should not be retried.
- excludeHeader(DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd...) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Clear the header inclusion bit for the header name.
- excludeNames() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The exception class names that should not be retried.
- excludeTopic(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- excludeTopics(List<String>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- execute(KafkaOperations.ProducerCallback<Object, Object, T>) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- execute(KafkaOperations.ProducerCallback<K, V, T>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Execute some arbitrary operation(s) on the producer and return the result.
- execute(KafkaOperations.ProducerCallback<K, V, T>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Execute some arbitrary operation(s) on the producer and return the result.
- execute(KafkaOperations.ProducerCallback<K, V, T>) - Method in class org.springframework.kafka.core.KafkaTemplate
- executeInTransaction(KafkaOperations.OperationsCallback<Object, Object, T>) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- executeInTransaction(KafkaOperations.OperationsCallback<K, V, T>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Execute some arbitrary operation(s) on the operations and return the result.
- executeInTransaction(KafkaOperations.OperationsCallback<K, V, T>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Execute some arbitrary operation(s) on the operations and return the result.
- executeInTransaction(KafkaOperations.OperationsCallback<K, V, T>) - Method in class org.springframework.kafka.core.KafkaTemplate
- exponentialBackoff(long, double, long) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- exponentialBackoff(long, double, long, boolean) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- ExponentialBackOffWithMaxRetries - Class in org.springframework.kafka.support
-
Subclass of
ExponentialBackOff
that allows the specification of the maximum number of retries rather than the maximum elapsed time. - ExponentialBackOffWithMaxRetries(int) - Constructor for class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
-
Construct an instance that will calculate the
ExponentialBackOffWithMaxRetries.setMaxElapsedTime(long)
from the maxRetries. - extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Subclasses can convert the value; by default, it's returned as provided by Kafka unless a
RecordMessageConverter
has been provided. - extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
- extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Subclasses can convert the value; by default, it's returned as provided by Kafka unless there is a
SmartMessageConverter
that can convert it. - extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.ProjectingMessageConverter
F
- FAIL_ON_ERROR - org.springframework.kafka.retrytopic.DltStrategy
-
Fail if DLT processing throws an error.
- FailedBatchProcessor - Class in org.springframework.kafka.listener
-
Subclass of
FailedRecordProcessor
that can process (and recover) a batch. - FailedBatchProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff, BackOffHandler, CommonErrorHandler) - Constructor for class org.springframework.kafka.listener.FailedBatchProcessor
-
Construct an instance with the provided properties.
- FailedBatchProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff, CommonErrorHandler) - Constructor for class org.springframework.kafka.listener.FailedBatchProcessor
-
Construct an instance with the provided properties.
- failedDelivery(ConsumerRecord<?, ?>, Exception, int) - Method in interface org.springframework.kafka.listener.RetryListener
-
Called after a delivery failed for a record.
- failedDelivery(ConsumerRecords<?, ?>, Exception, int) - Method in interface org.springframework.kafka.listener.RetryListener
-
Called after a delivery failed for batch records.
- FailedDeserializationInfo - Class in org.springframework.kafka.support.serializer
-
Class containing all the contextual information around a deserialization error.
- FailedDeserializationInfo(String, Headers, byte[], boolean, Exception) - Constructor for class org.springframework.kafka.support.serializer.FailedDeserializationInfo
-
Construct an instance with the contextual information.
- FailedRecordProcessor - Class in org.springframework.kafka.listener
-
Common super class for classes that deal with failing to consume a consumer record.
- FailedRecordProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.FailedRecordProcessor
- FailedRecordProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff, BackOffHandler) - Constructor for class org.springframework.kafka.listener.FailedRecordProcessor
- failure(Object, String) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Record failure.
- failure(Object, String, Object) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Record failure.
- failure(ConsumerRecord<K, V>, Exception, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- failure(ConsumerRecord<K, V>, Exception, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
-
Called after the listener throws an exception.
- failure(ConsumerRecords<K, V>, Exception, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
-
Called after the listener throws an exception.
- failure(ConsumerRecords<K, V>, Exception, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- FATAL - org.springframework.kafka.KafkaException.Level
-
Fatal.
- FATAL - org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Fatal.
- FENCED - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
The transactional producer was fenced and the container
stopContainerWhenFenced
property is true. - filter() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Set an
RecordFilterStrategy
bean name to override the strategy configured on the container factory. - filter(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener
- filter(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.adapter.RecordFilterStrategy
-
Return true if the record should be discarded.
- filterBatch(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.adapter.RecordFilterStrategy
-
Filter an entire batch of records; to filter all records, return an empty list, not null.
- FilteringBatchMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
A
BatchMessageListener
adapter that implements filter logic via aRecordFilterStrategy
. - FilteringBatchMessageListenerAdapter(BatchMessageListener<K, V>, RecordFilterStrategy<K, V>) - Constructor for class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
-
Create an instance with the supplied strategy and delegate listener.
- FilteringBatchMessageListenerAdapter(BatchMessageListener<K, V>, RecordFilterStrategy<K, V>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
-
Create an instance with the supplied strategy and delegate listener.
- FilteringMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
A
MessageListener
adapter that implements filter logic via aRecordFilterStrategy
. - FilteringMessageListenerAdapter(MessageListener<K, V>, RecordFilterStrategy<K, V>) - Constructor for class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
-
Create an instance with the supplied strategy and delegate listener.
- FilteringMessageListenerAdapter(MessageListener<K, V>, RecordFilterStrategy<K, V>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
-
Create an instance with the supplied strategy and delegate listener.
- findDelegate(Object, Map<Class<?>, Serializer>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
-
Determine the serializer for the data type.
- findDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Determine the delegate for the topic.
- findHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
- findRetryConfigurationFor(String[], Method, Object) - Method in class org.springframework.kafka.annotation.RetryTopicConfigurationProvider
- fixedBackOff(int) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- fixedBackOff(long) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- FixedDelayStrategy - Enum in org.springframework.kafka.retrytopic
-
Defines the topic strategy to handle fixed delays.
- fixedDelayTopicStrategy() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Whether to use a single or multiple topics when using a fixed delay.
- flush() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- flush() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Flush the producer.
- flush() - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Flush the producer.
- flush() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Flush the producer.
- flush() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
-
Deprecated.- flush does not make sense in the context of a reactive flow since, the send completion signal is a send result, which implies that a flush is redundant. If you use this method with reactor-kafka 1.3 or later, it must be scheduled to avoid a deadlock; see https://issues.apache.org/jira/browse/KAFKA-10790 (since 2.7).
- flush() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- forContainerFactoryConfigurer() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- forContainerFactoryResolver() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- forInboundOnlyWithMatchers(ObjectMapper, String...) - Static method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Create an instance for inbound mapping only with pattern matching.
- forInboundOnlyWithMatchers(String...) - Static method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Create an instance for inbound mapping only with pattern matching.
- forInboundOnlyWithMatchers(String...) - Static method in class org.springframework.kafka.support.SimpleKafkaHeaderMapper
-
Create an instance for inbound mapping only with pattern matching.
- forKafkaTopicAutoCreation() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- forKeys() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Designate this deserializer for deserializing keys (default is values); only applies if the default type mapper is used.
- forKeys() - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Designate this Serde for serializing/deserializing keys (default is values).
- forKeys() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Designate this serializer for serializing keys (default is values); only applies if the default type mapper is used.
- format(ConsumerRecord<?, ?>) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Format the
ConsumerRecord
for logging; defaulttopic-partition@offset
. - format(ConsumerRecord<?, ?>, boolean) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Deprecated.in favor of
KafkaUtils.format(ConsumerRecord)
. - format(ProducerRecord<?, ?>) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Format the
ProducerRecord
for logging; defaultProducerRecord
Object.toString()
. - fromAddress(String) - Static method in class org.springframework.kafka.test.core.BrokerAddress
- fromClass(Class<?>, Headers) - Method in interface org.springframework.kafka.support.mapping.ClassMapper
- fromClass(Class<?>, Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- fromHeaders(MessageHeaders, Headers) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
- fromHeaders(MessageHeaders, Headers) - Method in interface org.springframework.kafka.support.KafkaHeaderMapper
-
Map from the given
MessageHeaders
to the specified target headers. - fromHeaders(MessageHeaders, Headers) - Method in class org.springframework.kafka.support.SimpleKafkaHeaderMapper
- fromJavaType(JavaType, Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- fromJavaType(JavaType, Headers) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- fromMessage(Message<?>, String) - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
-
Convert a message to a producer record.
- fromMessage(Message<?>, String) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- fromMessage(Message<?>, String) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
- fromMessage(Message<?>, String) - Method in interface org.springframework.kafka.support.converter.RecordMessageConverter
-
Convert a message to a producer record.
G
- generateValues() - Method in class org.springframework.kafka.retrytopic.BackOffValuesGenerator
- GenericErrorHandler<T> - Interface in org.springframework.kafka.listener
-
A generic error handler.
- GenericMessageListener<T> - Interface in org.springframework.kafka.listener
-
Top level interface for listeners.
- GenericMessageListenerContainer<K,V> - Interface in org.springframework.kafka.listener
-
Generic message listener container; adds parameters.
- get() - Method in class org.springframework.kafka.core.ABSwitchCluster
- get() - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture.Completable
- get() - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture
- get(long, TimeUnit) - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture.Completable
- get(long, TimeUnit) - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture
- getAckCount() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAckMode() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAckTime() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAdviceChain() - Method in class org.springframework.kafka.listener.ContainerProperties
-
A chain of listener
Advice
s. - getAfterRollbackProcessor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return the currently configured
AfterRollbackProcessor
. - getAllListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return all
MessageListenerContainer
instances including those managed by this registry and those declared as beans in the application context. - getAllListenerContainers() - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return all
MessageListenerContainer
instances including those managed by this registry and those declared as beans in the application context. - getApplicationContext() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getApplicationEventPublisher() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Get the event publisher.
- getAssignedPartitions() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getAssignedPartitions() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Return the
TopicPartition
s currently assigned to this container, either explicitly or by Kafka; may be null if not assigned yet. - getAssignedPartitions() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the assigned topics/partitions for this container.
- getAssignedReplyTopicPartitions() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return the topics/partitions assigned to the replying listener container.
- getAssignmentCommitOption() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAssignmentsByClientId() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getAssignmentsByClientId() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- getAssignmentsByClientId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the assigned topics/partitions for this container, by client.id.
- getAuthExceptionRetryInterval() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Get the authentication/authorization retry interval.
- getAuthorizationExceptionRetryInterval() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Deprecated.in favor of
ConsumerProperties.getAuthExceptionRetryInterval()
. - getAutoStartup() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getAutoStartup() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the autoStartup for this endpoint's container.
- getBatchInterceptor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the current batch listener flag for this endpoint, or null if not explicitly set.
- getBatchListener() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the current batch listener flag for this endpoint, or null if not explicitly set.
- getBatchMessageConverter() - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Return the
BatchMessagingMessageConverter
for this listener, being able to convertMessage
. - getBatchToRecordAdapter() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBean() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- getBean() - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Return the bean for this handler.
- getBean() - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
- getBean(String, Class<T>) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- getBeanExpressionContext() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBeanFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBeanName() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return the bean name.
- getBeanResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBootstrapServers() - Method in class org.springframework.kafka.core.KafkaResourceFactory
- getBroker() - Static method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- getBrokerAddress(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getBrokerAddresses() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getBrokersAsString() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getCache() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getCache(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getCallbacksAndTopics() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Return the currently registered callbacks and their associated
TopicPartition
(s). - getCharset() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
- getCharset() - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Get the configured charset.
- getCharset() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Get the configured charset.
- getClassIdFieldName() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getClassifier() - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Return the exception classifier.
- getClassLoader() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getClientId() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the client id.
- getClientIdPrefix() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getClientIdPrefix() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the client id prefix for the container; it will be suffixed by '-n' to provide a unique id when concurrency is used.
- getClientIdPrefix(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the clientId prefix that will override the endpoint's clientId prefix.
- getClientIdPrefix(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getCommitCallback() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the commit callback.
- getCommitLogLevel() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
The level at which to log offset commits.
- getCommitRetries() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
The number of retries allowed when a
RetriableCommitFailedException
is thrown by the consumer when usingConsumerProperties.setSyncCommits(boolean)
set to true. - getCommonErrorHandler() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Get the
CommonErrorHandler
. - getConcurrency() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getConcurrency() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the concurrency for this endpoint's container.
- getConcurrency() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getConfigurationProperties() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConfigurationProperties() - Method in class org.springframework.kafka.core.KafkaAdmin
- getConfigurationProperties() - Method in interface org.springframework.kafka.core.KafkaAdminOperations
-
Get an unmodifiable copy of this admin's configuration.
- getConfigurationProperties() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConsumer() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
Retrieve the consumer.
- getConsumerFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- getConsumerForTimingAdjustment() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getConsumerGroup() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the consumer group.
- getConsumerGroupId() - Static method in class org.springframework.kafka.support.KafkaUtils
-
Get the group id for the consumer bound to this thread.
- getConsumerProperties() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getConsumerProperties() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Get the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- getConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the rebalance listener.
- getConsumerStartTimeout() - Method in class org.springframework.kafka.listener.ContainerProperties
- getConsumerStartTimout() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Deprecated.
- getConsumerTaskExecutor() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Deprecated.in favor of
ContainerProperties.getListenerTaskExecutor()
. - getContainer(Class<T>) - Method in class org.springframework.kafka.event.KafkaEvent
-
Get the container for which the event was published, which will be the parent container if the source that emitted the event is a child container, or the source itself otherwise.
- getContainerFor(String, int) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getContainerFor(String, int) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
If this container has child containers, return the child container that is assigned the topic/partition.
- getContainerProperties() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Obtain the properties template for this factory - set properties as needed and they will be copied to a final properties instance for the endpoint.
- getContainerProperties() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getContainerProperties() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the container properties for this container.
- getContainers() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
Return the list of
KafkaMessageListenerContainer
s created by this container. - getContentClassIdFieldName() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getContext() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
- getCorrelationHeaderName() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return the correlation header name.
- getCorrelationId() - Method in class org.springframework.kafka.requestreply.CorrelationKey
- getCreateOrModifyTopic() - Method in class org.springframework.kafka.core.KafkaAdmin
-
Return the predicate used to determine whether a
NewTopic
should be considered for creation or modification. - getCurrentOffset(String, String, String, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Get the current offset and metadata for the provided group/topic/partition.
- getCurrentOffset(AdminClient, String, String, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Get the current offset and metadata for the provided group/topic/partition.
- getCustomMethodArgumentResolvers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Return the list of
HandlerMethodArgumentResolver
. - getData() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
Get the data that failed deserialization (value or key).
- getData() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getDefaultPredicate(Collection<T>, Collection<T>) - Method in class org.springframework.kafka.support.AllowDenyCollectionManager
- getDefaultReplyTimeout() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return the reply timeout used if no replyTimeout is provided in the
ReplyingKafkaTemplate.sendAndReceive(ProducerRecord, Duration)
call. - getDefaultReplyTopicExpression() - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
-
Return the default expression when no SendTo value is present.
- getDefaultTopic() - Method in class org.springframework.kafka.core.KafkaTemplate
-
The default topic for send methods where a topic is not provided.
- getDelegate() - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- getDelegate() - Method in interface org.springframework.kafka.listener.DelegatingMessageListener
-
Return the delegate.
- getDelegates() - Method in class org.springframework.kafka.support.CompositeProducerListener
- getDestinationDelay() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationName() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationPartitions() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationTimeout() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationTopicByName(String) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- getDestinationTopicByName(String) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Returns the
DestinationTopic
instance registered for that topic. - getDestinationTopicProperties() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- getDltFor(String) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- getDltFor(String) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Returns the
DestinationTopic
instance registered as DLT for the given topic, or null if none is found. - getDltHandlerMethod() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- getDltSuffix() - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory.DestinationTopicSuffixes
- getDueTimestamp() - Method in exception org.springframework.kafka.listener.KafkaBackoffException
- getDueTimestamp() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getEmbeddedKafka() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Return an underlying delegator
EmbeddedKafkaBroker
instance. - getEndOffsets(Consumer<?, ?>, String, Integer...) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Return the end offsets of the requested topic/partitions
- getEndpointDescription() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return a description for this endpoint.
- getEndpointDescription() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- getEndpointHandlerMethod(MethodKafkaListenerEndpoint<?, ?>, RetryTopicConfiguration, DestinationTopic.Properties) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- getEndpointId(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the endpoint id that will override the endpoint's current id.
- getEndpointId(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getEndpointRegistrar() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Return the
KafkaListenerEndpointRegistrar
. - getEndpointRegistry() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Return the
KafkaListenerEndpointRegistry
instance for this registrar, may benull
. - getEosMode() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Get the exactly once semantics mode.
- getException() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getExceptionCauseFqcn() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the exception cause.
- getExceptionFqcn() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the value exception class.
- getExceptionFromHeader(ConsumerRecord<?, ?>, String, LogAccessor) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Deprecated.
- getExceptionFromHeader(ConsumerRecord<?, ?>, String, LogAccessor) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
-
Extract a
DeserializationException
from the supplied header name, if present. - getExceptionInfo() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames
-
The header names for the exception headers.
- getExceptionMessage() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the exception message.
- getExceptionStacktrace() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the exception stack trace.
- getFailedProducerRecord() - Method in exception org.springframework.kafka.core.KafkaProducerException
-
Return the failed producer record.
- getFailureTracker() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Return the failed record tracker.
- getFallbackBatchHandler() - Method in class org.springframework.kafka.listener.FailedBatchProcessor
-
Return the fallback batch error handler.
- getGenericErrorHandler() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated.
- getGroup() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getGroup() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the group of this endpoint or null if not in a group.
- getGroup(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the group that will override the endpoint's group.
- getGroup(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getGroupId() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getGroupId() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the groupId of this endpoint - if present, overrides the
group.id
property of the consumer factory. - getGroupId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getGroupId() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the container's group id.
- getGroupId() - Method in exception org.springframework.kafka.listener.ListenerExecutionFailedException
-
Return the consumer group.id property of the container that threw this exception.
- getGroupId() - Method in interface org.springframework.kafka.listener.ListenerMetadata
-
Return the group id.
- getGroupId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the
group.id
property for this container whether specifically set on the container or via a consumer property on the consumer factory. - getGroupId() - Static method in interface org.springframework.kafka.support.converter.MessageConverter
-
Get the thread bound group id.
- getGroupId(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the groupId that will override the endpoint's groupId.
- getGroupId(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Determine the
InvocableHandlerMethod
for the provided type. - getHeaderNames() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Override this if you want different header names to be used in the sent record.
- getHeaders() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
Get the headers.
- getHeaders() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getHeaderValue() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- getHost() - Method in class org.springframework.kafka.test.core.BrokerAddress
- getId() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getId() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the id of this endpoint.
- getId() - Method in class org.springframework.kafka.jdocs.dynamic.MyPojo
- getIdClassMapping() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getIdleBeforeDataMultiplier() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Multiply the
ContainerProperties.setIdleEventInterval(Long)
by this value until at least one record is received. - getIdleBetweenPolls() - Method in class org.springframework.kafka.listener.ContainerProperties
- getIdleEventInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the idle event interval.
- getIdlePartitionEventInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the idle partition event interval.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
How long the container has been idle.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
How long the container was idle.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
How long the partition has been idle.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
How long the partition was idle.
- getIndex() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
-
Return the index in the batch of the failed record.
- getKafkaConsumerProperties() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Get the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- getKafkaOperations() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getKafkaServer(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getKafkaServers() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getKafkaStreams() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Get a managed by this
StreamsBuilderFactoryBean
KafkaStreams
instance. - getKey() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
- getKeyClassIdFieldName() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getKeyDeserializer() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return the configured key deserializer (if provided as an object instead of a class name in the properties).
- getKeyDeserializer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getKeyExceptionFqcn() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the key exception class.
- getKeyExceptionMessage() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the key exception message.
- getKeyExceptionStacktrace() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the key exception stack trace.
- getKeySerializer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getKeySerializer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the configured key serializer (if provided as an object instead of a class name in the properties).
- getKeySerializerSupplier() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getKeySerializerSupplier() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return a supplier for a key serializer.
- getListenerContainer(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return the
MessageListenerContainer
with the specified id ornull
if no such container exists. - getListenerContainer(String) - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the
MessageListenerContainer
with the specified id ornull
if no such container exists. - getListenerContainerIds() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return the ids of the managed
MessageListenerContainer
instance(s). - getListenerContainerIds() - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the ids of the managed
MessageListenerContainer
instance(s). - getListenerContainerRegistry() - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- getListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return the managed
MessageListenerContainer
instance(s). - getListenerContainers() - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the managed
MessageListenerContainer
instance(s). - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getListenerId() - Method in exception org.springframework.kafka.listener.KafkaBackoffException
- getListenerId() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getListenerId() - Method in interface org.springframework.kafka.listener.ListenerMetadata
-
Return the listener id.
- getListenerId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
The 'id' attribute of a
@KafkaListener
or the bean name for spring-managed containers. - getListenerIds() - Method in class org.springframework.kafka.listener.ContainerGroup
-
Return the listener ids of the containers in this group.
- getListenerInfo() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getListenerInfo() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Get the listener info to insert in the record header.
- getListenerInfo() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getListenerInfo() - Method in interface org.springframework.kafka.listener.ListenerMetadata
-
Return the listener info.
- getListenerInfo() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Get arbitrary static information that will be added to the
KafkaHeaders.LISTENER_INFO
header of all records. - getListeners() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Get the current list of listeners.
- getListeners() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Get the current list of listeners.
- getListeners() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Get the current list of listeners.
- getListeners() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Get the current list of listeners.
- getListeners() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Get the current list of listeners.
- getListenerTaskExecutor() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the consumer task executor.
- getLogDir() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- getLogLevel() - Method in class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
-
Set the level at which the exception thrown by this handler is logged.
- getMaxAttemps(int) - Method in class org.springframework.kafka.retrytopic.BackOffValuesGenerator
- getMaxRetries() - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
-
Get the max retries.
- getMessage() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
- getMessageConverter() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the message converter.
- getMessageConverter() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Return the
MessagingMessageConverter
for this listener, being able to convertMessage
. - getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Return the configured handler factory.
- getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Return the custom
MessageHandlerMethodFactory
to use, if any. - getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Return the
MessageHandlerMethodFactory
. - getMessageListener() - Method in class org.springframework.kafka.listener.ContainerProperties
- getMessagingConverter() - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
- getMethod() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- getMethod() - Method in class org.springframework.kafka.support.EndpointHandlerMethod
-
Return the method.
- getMethodAsString(Object) - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
- getMethodName() - Method in class org.springframework.kafka.support.EndpointHandlerMethod
-
Return the method name.
- getMethodNameFor(Object) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Return a string representation of the method that will be invoked for this payload.
- getMicrometerTags() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return static Micrometer tags.
- getMicrometerTagsProvider() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the Micrometer tags provider.
- getMicrometerTagsProvider() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the Micrometer tags provider.
- getMode() - Method in enum org.springframework.kafka.listener.ContainerProperties.EOSMode
-
Deprecated.aliases will be removed in 3.0
- getMonitorInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
- getMsg() - Method in exception org.springframework.kafka.support.converter.ConversionException
-
Return the
Message
, if available. - getName() - Method in class org.springframework.kafka.listener.ContainerGroup
-
Return the group name.
- getNextDestination() - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver.DestinationTopicHolder
- getNextDestinationTopicFor(String) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- getNextDestinationTopicFor(String) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Returns the
DestinationTopic
instance registered as the next destination topic in the chain for the given topic. - getNoPollThreshold() - Method in class org.springframework.kafka.listener.ContainerProperties
- getObjectMapper() - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
-
Return the object mapper.
- getObjectMapper() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Return the object mapper.
- getObjectType() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- getOffset() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getOffsetAndMetadataProvider() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the offset and metadata provider.
- getOffsetHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the offset.
- getOneRecord(String, String, String, int, boolean, boolean, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Deprecated.
- getOneRecord(String, String, String, int, boolean, boolean, Duration) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Get a single record for the group from the topic/partition.
- getOrder() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- getOrder() - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanConfigurer
- getOriginal() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames
-
The header names for the original record headers.
- getParser() - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Get the configured parser function.
- getPartition() - Method in class org.springframework.kafka.event.ConsumerPartitionResumedEvent
- getPartition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getPartitionHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the partition.
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerPartitionPausedEvent
-
Return the paused partition.
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerPausedEvent
-
Return the paused partitions.
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerResumedEvent
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
- getPartitionsPerTopic() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getPhase() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- getPhase() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- getPhase() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getPhase() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- getPhase() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- getPhysicalCloseTimeout() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Get the physical close timeout.
- getPhysicalCloseTimeout() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Get the physical close timeout.
- getPollTimeout() - Method in class org.springframework.kafka.listener.ConsumerProperties
- getPollTimeoutWhilePaused() - Method in class org.springframework.kafka.listener.ContainerProperties
-
The poll timeout to use while paused; usually a lower number than
pollTimeout
. - getPort() - Method in class org.springframework.kafka.test.core.BrokerAddress
- getPort() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- getPosition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getPostProcessors() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Get the current list of post processors.
- getPostProcessors() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getPostProcessors() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getPostProcessors() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Get the current list of post processors.
- getProducer() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- getProducerConfigs() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return the configuration of a producer.
- getProducerFactory() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Return the producer factory used by this template.
- getProducerFactory() - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Return the producer factory used by this template.
- getProducerFactory() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the producer factory used by this template.
- getProducerFactory() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- getProducerFactory() - Method in class org.springframework.kafka.transaction.ChainedKafkaTransactionManager
-
Deprecated.
- getProducerFactory() - Method in interface org.springframework.kafka.transaction.KafkaAwareTransactionManager
-
Get the producer factory.
- getProducerFactory() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
-
Get the producer factory.
- getProducerFactory(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the producer factory used by this template based on the topic.
- getProducerFactory(String) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- getProducerRecord() - Method in class org.springframework.kafka.support.SendResult
- getPropertyValue(Object, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Uses nested
DirectFieldAccessor
s to obtain a property using dotted notation to traverse fields; e.g. - getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
A typed version of
getPropertyValue(Object, String)
. - getRawHeaders() - Method in class org.springframework.kafka.support.converter.KafkaMessageHeaders
- getReason() - Method in class org.springframework.kafka.event.ConsumerStoppedEvent
-
Return the reason why the consumer was stopped.
- getRecord() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
-
Return the failed record.
- getRecord() - Method in exception org.springframework.kafka.support.converter.ConversionException
-
Return the consumer record, if available.
- getRecordFilterStrategy() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getRecordFilterStrategy() - Method in class org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener
- getRecordInterceptor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getRecordMessageConverter() - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
-
Return the record converter used by this batch converter, if configured, or null.
- getRecordMessageConverter() - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- getRecordMetadata() - Method in class org.springframework.kafka.support.SendResult
- getRecords() - Method in exception org.springframework.kafka.support.converter.ConversionException
-
Return the consumer record, if available.
- getRecords(Consumer<K, V>) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer for records.
- getRecords(Consumer<K, V>, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Deprecated.in favor of
getRecords(Consumer, Duration)
- getRecords(Consumer<K, V>, long, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Deprecated.in favor of {#
getRecords(Consumer, Duration, int)
} - getRecords(Consumer<K, V>, Duration) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer for records.
- getRecords(Consumer<K, V>, Duration, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer for records.
- getRecoveryCallback() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- getRecoveryCallback() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
- getRecoveryStrategy(List<ConsumerRecord<?, ?>>, Exception) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Deprecated.- no longer used.
- getRecoveryStrategy(List<ConsumerRecord<?, ?>>, Consumer<?, ?>, Exception) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Deprecated.- no longer used.
- getReplyHeadersConfigurer() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Return the reply configurer.
- getReplyTemplate() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getRequest() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- getResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getResult() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- getResult() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- getRetryListeners() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
- getRetrySuffix() - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory.DestinationTopicSuffixes
- getRetryTemplate() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Deprecated.
- getRetryTemplate() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
- getScheduler() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the task scheduler, if present.
- getScheduler() - Method in class org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper
- getSeekCallbackFor(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Return the callback for the specified topic/partition.
- getSeekCallbacks() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
The map of callbacks for all currently assigned partitions.
- getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyFuture.Completable
-
Return the send future as a
CompletableFuture
. - getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
-
Return the send future.
- getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyMessageFuture.Completable
-
Return the send future as a
CompletableFuture
. - getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyMessageFuture
-
Return the send future.
- getSendTo() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- getShutdownTimeout() - Method in class org.springframework.kafka.listener.ContainerProperties
- getSingleRecord(Consumer<K, V>, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer, expecting a single record for the specified topic.
- getSingleRecord(Consumer<K, V>, String, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Deprecated.in favor of
getSingleRecord(Consumer, String, Duration)
- getSingleRecord(Consumer<K, V>, String, Duration) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer, expecting a single record for the specified topic.
- getSnapshotDir() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- getSource() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- getSource(Class<T>) - Method in class org.springframework.kafka.event.KafkaEvent
-
Get the container (source) that published the event.
- getSourceDestination() - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver.DestinationTopicHolder
- getStreamsConfiguration() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- getStreamsUncaughtExceptionHandler() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Retrieves the current
StreamsUncaughtExceptionHandler
set on this factory bean. - getSubBatchPerPartition() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return whether to split batches by partition; null if not set.
- getSyncCommitTimeout() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the sync commit timeout.
- getTheProducer(String) - Method in class org.springframework.kafka.core.KafkaTemplate
- getThingProp() - Method in class org.springframework.kafka.jdocs.requestreply.Application.Thing
- getTimeoutBuffer() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
The number of milliseconds to add to the producer configuration
delivery.timeout.ms
property to avoid timing out before the Kafka producer. - getTimeSinceLastPoll() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
How long since the last poll.
- getTimestamp() - Method in exception org.springframework.kafka.listener.TimestampedException
- getTimestampHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the timestamp.
- getTimestampTypeHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the timestamp type.
- getTopic() - Method in class org.springframework.kafka.jdocs.dynamic.MyPojo
- getTopic() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getTopic() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getTopicHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the topic.
- getTopicName(String) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the tropic name that will override the base topic name.
- getTopicName(String) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getTopicPartition() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
The idle TopicPartition.
- getTopicPartition() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
The idle TopicPartition.
- getTopicPartition() - Method in exception org.springframework.kafka.listener.KafkaBackoffException
- getTopicPartition() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getTopicPartition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
The TopicPartitions the container is listening to.
- getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
The TopicPartitions the container is listening to.
- getTopicPartitions() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
The TopicPartitions the container is listening to.
- getTopicPartitions() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the configured
TopicPartitionOffset
s. - getTopicPartitionsToAssign() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the topicPartitions for this endpoint.
- getTopicPartitionsToAssign() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the topicPartitions for this endpoint.
- getTopicPattern() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the topicPattern for this endpoint.
- getTopicPattern() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the topicPattern for this endpoint.
- getTopicPattern() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the configured topic pattern.
- getTopics() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the topics for this endpoint.
- getTopics() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the topics for this endpoint.
- getTopics() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the configured topics.
- getTopics() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getTopology() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Providing access to the associated
Topology
of thisStreamsBuilderFactoryBean
. - getToStringClasses() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Provide direct access to the toString() classes by subclasses.
- getTransactionalResourceHolder(ProducerFactory<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
-
Obtain a Producer that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder(ProducerFactory<K, V>, String, Duration) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
-
Obtain a Producer that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder(ProducerFactory<K, V>, Duration) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
-
Obtain a Producer that is synchronized with the current transaction, if any.
- getTransactionDefinition() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Get the transaction definition.
- getTransactionIdPrefix() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getTransactionIdPrefix() - Method in class org.springframework.kafka.core.KafkaTemplate
- getTransactionIdPrefix() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the transaction id prefix.
- getTransactionIdSuffix() - Static method in class org.springframework.kafka.support.TransactionSupport
- getTransactionManager() - Method in class org.springframework.kafka.listener.ContainerProperties
- getTrustedPackages() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Provide direct access to the trusted packages set for subclasses.
- getTxProducerConfigs(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return the configuration of a transactional producer.
- getType() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Returns the inferred type for conversion or, if null, the
fallbackType
. - getTypeMapper() - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
- getTypeMapper() - Method in class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
-
Return the type mapper.
- getTypeMapper() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- getTypeMapper() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- getTypePrecedence() - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
-
Return the precedence.
- getTypePrecedence() - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- getUnregisteredListenerContainer(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- getUnregisteredListenerContainer(String) - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the
MessageListenerContainer
with the specified id ornull
if no such container exists. - getUntrustedType() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- getValidator() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Get the validator, if supplied.
- getValue() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
- getValueDeserializer() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return the configured value deserializer (if provided as an object instead of a class name in the properties).
- getValueDeserializer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getValueSerializer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getValueSerializer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the configured value serializer (if provided as an object instead of a class name in the properties).
- getValueSerializerSupplier() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getValueSerializerSupplier() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return a supplier for a value serializer.
- getZkPort() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Get the port that the embedded Zookeeper is running on or will run on.
- getZookeeper() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getZooKeeperClient() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Return the ZooKeeperClient.
- getZookeeperConnectionString() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- GROUP - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The consumer group that received the failed record.
- GROUP_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
For inbound messages, the container's
group.id
consumer property. - groupId() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Override the
group.id
property for the consumer factory with this value for this listener only.
H
- handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ContainerAwareErrorHandler
- handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
-
Handle the exception.
- handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
- handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ContainerAwareErrorHandler
- handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ErrorHandler
-
Handle the exception.
- handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
- handle(Exception, ConsumerRecord<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
- handle(Exception, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.LoggingErrorHandler
-
Deprecated.
- handle(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
- handle(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
- handle(Exception, ConsumerRecords<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.BatchErrorHandler
-
Handle the exception.
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
-
Deprecated.
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.BatchErrorHandler
-
Handle the exception.
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
-
Handle the exception.
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler
- handle(Exception, T) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
-
Handle the exception.
- handle(Exception, T, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
-
Handle the exception.
- handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- handleBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- handleBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- handleBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Handle the exception for a batch listener.
- handleBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
- handleBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- handleBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- handleBatchAndReturnRemaining(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Handle the exception for a batch listener.
- handleBatchAndReturnRemaining(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- handleError(Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.kafka.listener.ConsumerAwareListenerErrorHandler
- handleError(Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.kafka.listener.KafkaListenerErrorHandler
-
Handle the error.
- handleError(Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.kafka.listener.ManualAckListenerErrorHandler
- handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareListenerErrorHandler
- handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.KafkaListenerErrorHandler
-
Handle the error.
- handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>, Acknowledgment) - Method in interface org.springframework.kafka.listener.KafkaListenerErrorHandler
-
Handle the error.
- handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>, Acknowledgment) - Method in interface org.springframework.kafka.listener.ManualAckListenerErrorHandler
- handleOne(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Handle the exception for a record listener when
CommonErrorHandler.remainingRecords()
returns false. - handleOne(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
- handleOne(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- handleOne(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- handleOtherException(Exception, Consumer<?, ?>, MessageListenerContainer, boolean) - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- handleOtherException(Exception, Consumer<?, ?>, MessageListenerContainer, boolean) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- handleOtherException(Exception, Consumer<?, ?>, MessageListenerContainer, boolean) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Called when an exception is thrown with no records available, e.g.
- handleOtherException(Exception, Consumer<?, ?>, MessageListenerContainer, boolean) - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
- handleOtherException(Exception, Consumer<?, ?>, MessageListenerContainer, boolean) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- handleOtherException(Exception, Consumer<?, ?>, MessageListenerContainer, boolean) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- HandlerAdapter - Class in org.springframework.kafka.listener.adapter
-
A wrapper for either an
InvocableHandlerMethod
orDelegatingInvocableHandler
. - HandlerAdapter(DelegatingInvocableHandler) - Constructor for class org.springframework.kafka.listener.adapter.HandlerAdapter
-
Construct an instance with the provided delegating handler.
- HandlerAdapter(InvocableHandlerMethod) - Constructor for class org.springframework.kafka.listener.adapter.HandlerAdapter
-
Construct an instance with the provided method.
- handleRecord(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Deprecated.
- handleRemaining(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- handleRemaining(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- handleRemaining(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Handle the exception for a record listener when
CommonErrorHandler.remainingRecords()
returns true. - handleRemaining(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- handleRemaining(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- handleResult(Object, Object, Object) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Handle the given result object returned from the listener method, sending a response message to the SendTo topic.
- handleTimeout(CorrelationKey, RequestReplyFuture<K, V, Collection<ConsumerRecord<K, R>>>) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
- handleTimeout(CorrelationKey, RequestReplyFuture<K, V, R>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Used to inform subclasses that a request has timed out so they can clean up state and, optionally, complete the future.
- hasConfigurationForTopics(String[]) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- hasDefaultHandler() - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
- hashCode() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- hashCode() - Method in class org.springframework.kafka.requestreply.CorrelationKey
- hashCode() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- hashCode() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- hashCode() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- hashCode() - Method in class org.springframework.kafka.test.core.BrokerAddress
- hasKey(K) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
- hasNoRestrictions() - Method in class org.springframework.kafka.support.AllowDenyCollectionManager
- hasOffset() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- hasPartition(int) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
- hasTimestamp() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- hasTimestamp(long) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
-
Matcher testing the timestamp of a
ConsumerRecord
assuming the topic has been set withCreateTime
. - hasTimestamp(TimestampType, long) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
-
Matcher testing the timestamp of a
ConsumerRecord
- hasValue(V) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
- HeaderEnricher<K,V> - Class in org.springframework.kafka.streams
-
Manipulate the headers.
- HeaderEnricher(Map<String, Expression>) - Constructor for class org.springframework.kafka.streams.HeaderEnricher
- HeaderEnricher.Container<K,V> - Class in org.springframework.kafka.streams
-
Container object for SpEL evaluation.
- headerValueToAddIn(Header) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Check if the header value should be mapped to a String, if so configured.
- headerValueToAddOut(String, Object) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Check if the value is a String and convert to byte[], if so configured.
I
- id() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
The unique identifier of the container for this listener.
- idIsGroup() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
- ignoreTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Ignore type information headers and use the configured target class.
- ignoreTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Ignore type information headers and use the configured target class.
- include() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The exception types that should be retried.
- includeHeader(DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd...) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set the header inclusion bit for the header name.
- includeNames() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The exception class names that should be retried.
- includeTopic(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- includeTopics(List<String>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- INFERRED - org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
-
The type is inferred from the destination method.
- info() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Static information that will be added as a header with key
KafkaHeaders.LISTENER_INFO
. - INFO - org.springframework.kafka.KafkaException.Level
-
Info.
- INFO - org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Info.
- init(ProcessorContext) - Method in class org.springframework.kafka.streams.HeaderEnricher
- init(ProcessorContext) - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
- initialize() - Method in class org.springframework.kafka.core.KafkaAdmin
-
Call this method to check/add topics; this might be needed if the broker was not available when the application context was initialized, and
fatalIfBrokerNotAvailable
is false, orautoCreate
was set to false. - initialize() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- initializeContainer(C, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Further initialize the specified container.
- initializeContainer(ConcurrentMessageListenerContainer<K, V>, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
- initialOffset() - Method in annotation type org.springframework.kafka.annotation.PartitionOffset
-
The initial offset of the
PartitionOffset.partition()
. - initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
- initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Subclasses can populate additional headers before they are mapped.
- initTransactions() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- INSTANCE - Static variable in class org.springframework.kafka.support.JavaUtils
-
The singleton instance of this utility class.
- INSTANCE - Static variable in class org.springframework.kafka.support.KafkaNull
-
Instance of KafkaNull.
- instantiateAndConfigure(Map<String, ?>, boolean, Map<String, Deserializer<?>>, String, Class<?>) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- instantiateAndConfigure(Map<String, ?>, boolean, Map<String, Serializer<?>>, String, Class<?>) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- instantiateAndConfigure(Map<String, ?>, boolean, Map<Pattern, T>, Pattern, Class<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- intercept(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRecordInterceptor
- intercept(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
-
Deprecated.in favor of
RecordInterceptor.intercept(ConsumerRecord, Consumer)
which will become the required method in a future release. - intercept(ConsumerRecord<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- intercept(ConsumerRecord<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRecordInterceptor
- intercept(ConsumerRecord<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
-
Perform some action on the record or return a different one.
- intercept(ConsumerRecords<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
-
Perform some action on the records or return a different one.
- intercept(ConsumerRecords<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- internalRetryTopicClock() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Return the
Clock
instance that will be used for all time-related operations in the retry topic processes. - inTransaction() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Return true if the template is currently running in a transaction on the calling thread.
- inTransaction() - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Return true if the template is currently running in a transaction on the calling thread.
- inTransaction() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return true if the template is currently running in a transaction on the calling thread.
- InvocationResult - Class in org.springframework.kafka.listener.adapter
-
The result of a method invocation.
- InvocationResult(Object, Expression, boolean) - Constructor for class org.springframework.kafka.listener.adapter.InvocationResult
- invoke(Object, Acknowledgment, Consumer<?, ?>, Message<?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
- invoke(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>, Message<?>) - Method in interface org.springframework.kafka.listener.adapter.BatchToRecordAdapter.Callback
-
Handle each message.
- invoke(Message<?>, Object...) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Invoke the method with the given message.
- invoke(Message<?>, Object...) - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
- invokeHandler(Object, Acknowledgment, Message<?>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Invoke the handler, wrapping any exception to a
ListenerExecutionFailedException
with a dedicated error message. - isAckAfterHandle() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- isAckAfterHandle() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Return true if the offset should be committed for a handled error (no exception thrown).
- isAckAfterHandle() - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
- isAckAfterHandle() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- isAckAfterHandle() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- isAckAfterHandle() - Method in interface org.springframework.kafka.listener.GenericErrorHandler
-
Return true if the offset should be committed for a handled error (no exception thrown).
- isAckDiscarded() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Get the addTypeInfo property.
- isAllowed(T) - Method in class org.springframework.kafka.support.AllowDenyCollectionManager
- isAllowNonTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Return true if this template, when transactional, allows non-transactional operations.
- isAllowNonTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Return true if this template, when transactional, allows non-transactional operations.
- isAllowNonTransactional() - Method in class org.springframework.kafka.core.KafkaTemplate
- isAlwaysRetryOnDltFailure() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- isAssignable() - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
-
Returns true if
DelegatingByTypeSerializer.findDelegate(Object, Map)
should consider assignability to the key rather than an exact match. - isAsyncAcks() - Method in class org.springframework.kafka.listener.ContainerProperties
-
When true, async manual acknowledgments are supported.
- isAutoCommit() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return true if consumers created by this factory use auto commit.
- isAutoCommit() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- isAutoStartup() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- isAutoStartup() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- isAutoStartup() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isAutoStartup() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- isAutoStartup() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- isBackoffException(Exception) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Return true if the exception is a
KafkaBackoffException
. - isBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Return true if this endpoint creates a batch listener.
- isBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return true if this endpoint creates a batch listener.
- isCheckDeserExWhenKeyNull() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Always check for a deserialization exception header with a null key.
- isCheckDeserExWhenValueNull() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Always check for a deserialization exception header with a null value.
- isChildRunning() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- isChildRunning() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
If this container has child containers, return true if at least one child is running.
- isCommitRecovered() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Whether the offset for a recovered record should be committed.
- isConfigureSerializers() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
If true (default), programmatically provided serializers (via constructor or setters) will be configured using the producer configuration.
- isConsumerRecordList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- isConsumerRecords() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- isContainerPaused() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- isContainerPaused() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- isContainerPaused() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return true if
MessageListenerContainer.pause()
has been called; and all consumers in this container have actually paused. - isContextRefreshed() - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
-
Return true if the application context is refreshed.
- isConversionNeeded() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- isDefault() - Method in annotation type org.springframework.kafka.annotation.KafkaHandler
-
When true, designate that this is the default fallback method if the payload type matches no other
KafkaHandler
method. - isDeliveryAttemptHeader() - Method in class org.springframework.kafka.listener.ContainerProperties
- isDltTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- isDltTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- isEmptyPayload(Object) - Method in class org.springframework.kafka.annotation.KafkaNullAwarePayloadArgumentResolver
- isEncodeStrings() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
- isExistingTransaction(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
- isFailIfSendResultIsError() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
If true, wait for the send result and throw an exception if it fails.
- isFixTxOffsets() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Whether or not to correct terminal transactional offsets.
- isForKey() - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- isForKey() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- isInExpectedState() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- isInExpectedState() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- isInExpectedState() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return true if the container is running, has never been started, or has been stopped.
- isInstance(Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- isInstance(Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Return true if this object is an instance of T.
- isInstance(Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- isInterceptBeforeTx() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isJackson2Present() - Static method in class org.springframework.kafka.support.JacksonPresent
- isKey() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
True if deserialization of the key failed, otherwise deserialization of the value failed.
- isLogContainerConfig() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Log the container configuration if true (INFO).
- isMainEndpoint() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- isMainTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- isMessageList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- isMessageReturnType() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- isMicrometerEnabled() - Method in class org.springframework.kafka.listener.ContainerProperties
- isMissingTopicsFatal() - Method in class org.springframework.kafka.listener.ContainerProperties
-
If true, the container won't start if any of the configured topics are not present on the broker.
- isNegated() - Method in interface org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
-
Return true if this matcher is a negative matcher.
- isNegated() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
- isNegated() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
- isNoOpsTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- isOnlyLogRecordMetadata() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Deprecated.
- isPartitionPaused(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- isPartitionPaused(TopicPartition) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- isPartitionPaused(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Whether or not this topic's partition is currently paused.
- isPartitionPauseRequested(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isPartitionPauseRequested(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Whether or not this topic's partition pause has been requested.
- isPaused() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
Return true if the consumer was paused at the time the idle event was published.
- isPaused() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
Return true if the consumer was paused at the time the idle event was published.
- isPaused() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isPauseImmediate() - Method in class org.springframework.kafka.listener.ContainerProperties
-
When pausing the container with a record listener, whether the pause takes effect immediately, when the current record has been processed, or after all records from the previous poll have been processed.
- isPauseRequested() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isPauseRequested() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return true if
MessageListenerContainer.pause()
has been called; the container might not have actually paused yet. - isPending(CorrelationKey) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return true if this correlation id is still active.
- isPrimary() - Method in class org.springframework.kafka.core.ABSwitchCluster
-
Get whether or not the primary cluster is active.
- isProcessInTransaction() - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
-
Return true to invoke
AfterRollbackProcessor.process(List, Consumer, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode)
in a new transaction. - isProcessInTransaction() - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
- isProducerPerConsumerPartition() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return the producerPerConsumerPartition.
- isProducerPerConsumerPartition() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the producerPerConsumerPartition.
- isProducerPerThread() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- isProducerPerThread() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return true when there is a producer per thread.
- isRelativeToCurrent() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- isRestartAfterAuthExceptions() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Restart the container if stopped due to an auth exception.
- isRunning() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- isRunning() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- isRunning() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isRunning() - Method in class org.springframework.kafka.listener.ContainerGroup
- isRunning() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- isRunning() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- isSeekAfterError() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Return whether to seek after an exception is handled.
- isSingleTopicRetry() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- isSplitIterables() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- isSplitIterables() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
When true,
Iterable
return results will be split into discrete records. - isSplitIterables() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
When true,
Iterable
return results will be split into discrete records. - isStatefulRetry() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- isStopContainerWhenFenced() - Method in class org.springframework.kafka.listener.ContainerProperties
-
When true, the container will stop after a
ProducerFencedException
. - isStopImmediate() - Method in class org.springframework.kafka.listener.ContainerProperties
-
When true, the container will be stopped immediately after processing the current record.
- isStoppedNormally() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- isSubBatchPerPartition() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return whether to split batches by partition.
- isSyncCommits() - Method in class org.springframework.kafka.listener.ConsumerProperties
- isTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Return true if the implementation supports transactions (has a transaction-capable producer factory).
- isTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Return true if the implementation supports transactions (has a transaction-capable producer factory).
- isTransactional() - Method in class org.springframework.kafka.core.KafkaTemplate
- isTransactional() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
True if publishing should run in a transaction.
J
- Jackson2JavaTypeMapper - Interface in org.springframework.kafka.support.mapping
-
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
- Jackson2JavaTypeMapper.TypePrecedence - Enum in org.springframework.kafka.support.mapping
-
The precedence for type conversion - inferred from the method parameter or message headers.
- JacksonMimeTypeModule - Class in org.springframework.kafka.support
-
A
SimpleModule
extension forMimeType
serialization. - JacksonMimeTypeModule() - Constructor for class org.springframework.kafka.support.JacksonMimeTypeModule
- JacksonPresent - Class in org.springframework.kafka.support
-
The utility to check if Jackson JSON processor is present in the classpath.
- JacksonUtils - Class in org.springframework.kafka.support
-
The utilities for Jackson
ObjectMapper
instances. - JavaUtils - Class in org.springframework.kafka.support
-
Chained utility methods to simplify some Java repetitive code.
- JSON_TYPES - Static variable in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Header name for java types of other headers.
- JsonDeserializer<T> - Class in org.springframework.kafka.support.serializer
-
Generic
Deserializer
for receiving JSON from Kafka and return Java objects. - JsonDeserializer() - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with a default
ObjectMapper
. - JsonDeserializer(TypeReference<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and a default
ObjectMapper
. - JsonDeserializer(TypeReference<? super T>, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and useHeadersIfPresent with a default
ObjectMapper
. - JsonDeserializer(TypeReference<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and
ObjectMapper
. - JsonDeserializer(TypeReference<? super T>, ObjectMapper, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type,
ObjectMapper
and useHeadersIfPresent. - JsonDeserializer(JavaType) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and a default
ObjectMapper
. - JsonDeserializer(JavaType, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and useHeadersIfPresent with a default
ObjectMapper
. - JsonDeserializer(JavaType, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and
ObjectMapper
. - JsonDeserializer(JavaType, ObjectMapper, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type,
ObjectMapper
and useHeadersIfPresent. - JsonDeserializer(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided
ObjectMapper
. - JsonDeserializer(Class<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and a default
ObjectMapper
. - JsonDeserializer(Class<? super T>, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and useHeadersIfPresent with a default
ObjectMapper
. - JsonDeserializer(Class<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type, and
ObjectMapper
. - JsonDeserializer(Class<? super T>, ObjectMapper, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
-
Construct an instance with the provided target type,
ObjectMapper
and useHeadersIfPresent. - JsonMessageConverter - Class in org.springframework.kafka.support.converter
-
Base class for JSON message converters; on the consumer side, it can handle
byte[]
,Bytes
andString
record values. - JsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.JsonMessageConverter
- JsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.JsonMessageConverter
- JsonSerde<T> - Class in org.springframework.kafka.support.serializer
-
A
Serde
that provides serialization and deserialization in JSON format. - JsonSerde() - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(TypeReference<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(TypeReference<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(JavaType) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(JavaType, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(Class<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(Class<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerde(JsonSerializer<T>, JsonDeserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
- JsonSerializer<T> - Class in org.springframework.kafka.support.serializer
-
Generic
Serializer
for sending Java objects to Kafka as JSON. - JsonSerializer() - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
- JsonSerializer(TypeReference<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
- JsonSerializer(TypeReference<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
- JsonSerializer(JavaType, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
- JsonSerializer(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
- JsonTypeResolver - Interface in org.springframework.kafka.support.serializer
-
Determine the
JavaType
from the topic/data/headers. - JUnitUtils - Class in org.springframework.kafka.test.utils
-
Utility methods for JUnit rules and conditions.
- JUnitUtils.LevelsContainer - Class in org.springframework.kafka.test.utils
K
- KAFKA_CLIENT_CONTEXT_NAME - Static variable in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
-
The key for the kafka client configuration entry.
- KAFKA_CONSUMER_BACK_OFF_MANAGER_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
-
The bean name of the internally managed Kafka consumer back off manager.
- KAFKA_LISTENER_ANNOTATION_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
-
The bean name of the internally managed Kafka listener annotation processor.
- KAFKA_LISTENER_ENDPOINT_REGISTRY_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
-
The bean name of the internally managed Kafka listener endpoint registry.
- KafkaAdmin - Class in org.springframework.kafka.core
-
An admin that delegates to an
AdminClient
to create topics defined in the application context. - KafkaAdmin(Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaAdmin
-
Create an instance with an
AdminClient
based on the supplied configuration. - KafkaAdmin.NewTopics - Class in org.springframework.kafka.core
-
Wrapper for a collection of
NewTopic
to facilitate declaring multiple topics as a single bean. - KafkaAdminOperations - Interface in org.springframework.kafka.core
-
Provides a number of convenience methods wrapping
AdminClient
. - KafkaAwareTransactionManager<K,V> - Interface in org.springframework.kafka.transaction
-
A transaction manager that can provide a
ProducerFactory
. - KafkaBackoffAwareMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
A
AcknowledgingConsumerAwareMessageListener
implementation that looks for a backoff dueTimestamp header and invokes aKafkaConsumerBackoffManager
instance that will back off if necessary. - KafkaBackoffAwareMessageListenerAdapter(MessageListener<K, V>, KafkaConsumerBackoffManager, String, String, Clock) - Constructor for class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
-
The configuration for this listener adapter.
- KafkaBackoffAwareMessageListenerAdapter(MessageListener<K, V>, KafkaConsumerBackoffManager, String, Clock) - Constructor for class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
- KafkaBackoffException - Exception in org.springframework.kafka.listener
-
Exception thrown when the consumer should not yet consume the message due to backOff.
- KafkaBackoffException(String, TopicPartition, String, long) - Constructor for exception org.springframework.kafka.listener.KafkaBackoffException
-
Constructor with data from the BackOff event.
- kafkaBackOffManagerFactory(ListenerContainerRegistry, ApplicationContext) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the
KafkaBackOffManagerFactory
that will be used to create theKafkaConsumerBackoffManager
instance used to back off the partitions. - KafkaBackOffManagerFactory - Interface in org.springframework.kafka.listener
-
Creates a
KafkaBackOffManagerFactory
instance. - KafkaBootstrapConfiguration - Class in org.springframework.kafka.annotation
-
An
ImportBeanDefinitionRegistrar
class that registers aKafkaListenerAnnotationBeanPostProcessor
bean capable of processing Spring's @KafkaListener
annotation. - KafkaBootstrapConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
- KafkaConditions - Class in org.springframework.kafka.test.assertj
-
AssertJ custom
Condition
s. - KafkaConditions.ConsumerRecordKeyCondition<K> - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordKeyValueCondition<K,V> - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordPartitionCondition - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordTimestampCondition - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordValueCondition<V> - Class in org.springframework.kafka.test.assertj
- kafkaConsumerBackoffManager(ApplicationContext, ListenerContainerRegistry, RetryTopicSchedulerWrapper, TaskScheduler) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Create the
KafkaConsumerBackoffManager
instance that will be used to back off partitions. - KafkaConsumerBackoffManager - Interface in org.springframework.kafka.listener
-
Interface for backing off a
MessageListenerContainer
until a given dueTimestamp, if such timestamp is in the future. - KafkaConsumerBackoffManager.Context - Class in org.springframework.kafka.listener
-
Provides the state that will be used for backing off.
- KafkaEvent - Class in org.springframework.kafka.event
-
Base class for events.
- KafkaEvent(Object, Object) - Constructor for class org.springframework.kafka.event.KafkaEvent
- KafkaException - Exception in org.springframework.kafka
-
The Spring for Apache Kafka specific
NestedRuntimeException
implementation. - KafkaException(String) - Constructor for exception org.springframework.kafka.KafkaException
-
Construct an instance with the provided properties.
- KafkaException(String, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
-
Construct an instance with the provided properties.
- KafkaException(String, KafkaException.Level, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
-
Construct an instance with the provided properties.
- KafkaException.Level - Enum in org.springframework.kafka
-
The log level for
KafkaException
. - KafkaExceptionLogLevelAware - Class in org.springframework.kafka.listener
-
A top level abstract class for classes that can be configured with a
KafkaException.Level
. - KafkaExceptionLogLevelAware() - Constructor for class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
- KafkaFailureCallback<K,V> - Interface in org.springframework.kafka.core
-
Deprecated.as of 2.9.1, in favor of
CompletableFuture.whenComplete(BiConsumer)
- KafkaHandler - Annotation Type in org.springframework.kafka.annotation
-
Annotation that marks a method to be the target of a Kafka message listener within a class that is annotated with
KafkaListener
. - KafkaHeaderMapper - Interface in org.springframework.kafka.support
-
Header mapper for Apache Kafka.
- KafkaHeaders - Class in org.springframework.kafka.support
-
The Kafka specific message headers constants.
- KafkaHeaders() - Constructor for class org.springframework.kafka.support.KafkaHeaders
- KafkaJaasLoginModuleInitializer - Class in org.springframework.kafka.security.jaas
-
Contains properties for setting up an
AppConfigurationEntry
that can be used for the Kafka client. - KafkaJaasLoginModuleInitializer() - Constructor for class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- KafkaJaasLoginModuleInitializer.ControlFlag - Enum in org.springframework.kafka.security.jaas
-
Control flag values for login configuration.
- KafkaListener - Annotation Type in org.springframework.kafka.annotation
-
Annotation that marks a method to be the target of a Kafka message listener on the specified topics.
- KafkaListenerAnnotationBeanPostProcessor<K,V> - Class in org.springframework.kafka.annotation
-
Bean post-processor that registers methods annotated with
KafkaListener
to be invoked by a Kafka message listener container created under the covers by aKafkaListenerContainerFactory
according to the parameters of the annotation. - KafkaListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- KafkaListenerAnnotationBeanPostProcessor.AnnotationEnhancer - Interface in org.springframework.kafka.annotation
-
Post processes each set of annotation attributes.
- KafkaListenerConfigurationSelector - Class in org.springframework.kafka.annotation
-
A
DeferredImportSelector
implementation with the lowest order to import aKafkaBootstrapConfiguration
as late as possible. - KafkaListenerConfigurationSelector() - Constructor for class org.springframework.kafka.annotation.KafkaListenerConfigurationSelector
- KafkaListenerConfigurer - Interface in org.springframework.kafka.annotation
-
Optional interface to be implemented by Spring managed bean willing to customize how Kafka listener endpoints are configured.
- KafkaListenerConfigUtils - Class in org.springframework.kafka.config
-
Configuration constants for internal sharing across subpackages.
- KafkaListenerConfigUtils() - Constructor for class org.springframework.kafka.config.KafkaListenerConfigUtils
- KafkaListenerContainerFactory<C extends MessageListenerContainer> - Interface in org.springframework.kafka.config
-
Factory for
MessageListenerContainer
s. - KafkaListenerEndpoint - Interface in org.springframework.kafka.config
-
Model for a Kafka listener endpoint.
- KafkaListenerEndpointRegistrar - Class in org.springframework.kafka.config
-
Helper bean for registering
KafkaListenerEndpoint
with aKafkaListenerEndpointRegistry
. - KafkaListenerEndpointRegistrar() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- KafkaListenerEndpointRegistry - Class in org.springframework.kafka.config
-
Creates the necessary
MessageListenerContainer
instances for the registered endpoints. - KafkaListenerEndpointRegistry() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- KafkaListenerErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler which is called when a
@KafkaListener
method throws an exception. - KafkaListeners - Annotation Type in org.springframework.kafka.annotation
-
Container annotation that aggregates several
KafkaListener
annotations. - KafkaMatchers - Class in org.springframework.kafka.test.hamcrest
-
Hamcrest
Matcher
s utilities. - KafkaMatchers.ConsumerRecordKeyMatcher<K> - Class in org.springframework.kafka.test.hamcrest
- KafkaMatchers.ConsumerRecordPartitionMatcher - Class in org.springframework.kafka.test.hamcrest
- KafkaMatchers.ConsumerRecordTimestampMatcher - Class in org.springframework.kafka.test.hamcrest
- KafkaMatchers.ConsumerRecordValueMatcher<V> - Class in org.springframework.kafka.test.hamcrest
- KafkaMessageHeaders - Class in org.springframework.kafka.support.converter
-
Overload of message headers configurable for adding id and timestamp headers.
- KafkaMessageListenerContainer<K,V> - Class in org.springframework.kafka.listener
-
Single-threaded Message listener container using the Java
Consumer
supporting auto-partition assignment or user-configured assignment. - KafkaMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Construct an instance with the supplied configuration properties.
- KafkaNull - Class in org.springframework.kafka.support
-
This class represents NULL Kafka payload.
- KafkaNullAwarePayloadArgumentResolver - Class in org.springframework.kafka.annotation
- KafkaOperations<K,V> - Interface in org.springframework.kafka.core
-
The basic Kafka operations contract returning
ListenableFuture
s. - KafkaOperations.OperationsCallback<K,V,T> - Interface in org.springframework.kafka.core
-
A callback for executing arbitrary operations on the
KafkaOperations
. - KafkaOperations.ProducerCallback<K,V,T> - Interface in org.springframework.kafka.core
-
A callback for executing arbitrary operations on the
Producer
. - KafkaOperations2<K,V> - Interface in org.springframework.kafka.core
-
The basic Kafka operations contract returning
CompletableFuture
s. - kafkaPorts(int...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set explicit ports on which the kafka brokers will listen.
- kafkaPorts(int...) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Set explicit ports on which the kafka brokers will listen.
- KafkaProducerException - Exception in org.springframework.kafka.core
-
Exceptions when producing.
- KafkaProducerException(ProducerRecord<?, ?>, String, Throwable) - Constructor for exception org.springframework.kafka.core.KafkaProducerException
-
Construct an instance with the provided properties.
- KafkaReplyTimeoutException - Exception in org.springframework.kafka.requestreply
-
Exception when a reply is not received within a timeout.
- KafkaReplyTimeoutException(String) - Constructor for exception org.springframework.kafka.requestreply.KafkaReplyTimeoutException
- KafkaResourceFactory - Class in org.springframework.kafka.core
-
Base class for consumer/producer/admin creators.
- KafkaResourceFactory() - Constructor for class org.springframework.kafka.core.KafkaResourceFactory
- KafkaResourceHolder<K,V> - Class in org.springframework.kafka.core
-
Kafka resource holder, wrapping a Kafka producer.
- KafkaResourceHolder(Producer<K, V>, Duration) - Constructor for class org.springframework.kafka.core.KafkaResourceHolder
-
Construct an instance for the producer.
- KafkaSendCallback<K,V> - Interface in org.springframework.kafka.core
-
Deprecated.as of 2.9.1, in favor of
CompletableFuture.whenComplete(BiConsumer)
- KafkaStreamBrancher<K,V> - Class in org.springframework.kafka.support
-
Provides a method-chaining way to build
branches
in Kafka Streams processor topology. - KafkaStreamBrancher() - Constructor for class org.springframework.kafka.support.KafkaStreamBrancher
- KafkaStreamsConfiguration - Class in org.springframework.kafka.config
-
Wrapper for
StreamsBuilder
properties. - KafkaStreamsConfiguration(Map<String, Object>) - Constructor for class org.springframework.kafka.config.KafkaStreamsConfiguration
- KafkaStreamsCustomizer - Interface in org.springframework.kafka.config
-
Callback interface that can be used to configure
KafkaStreams
directly. - KafkaStreamsDefaultConfiguration - Class in org.springframework.kafka.annotation
-
@Configuration
class that registers aStreamsBuilderFactoryBean
ifStreamsConfig
with the nameKafkaStreamsDefaultConfiguration.DEFAULT_STREAMS_CONFIG_BEAN_NAME
is present in the application context. - KafkaStreamsDefaultConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
- KafkaStreamsInfrastructureCustomizer - Interface in org.springframework.kafka.config
-
A customizer for infrastructure components such as the
StreamsBuilder
andTopology
. - KafkaStreamsMicrometerListener - Class in org.springframework.kafka.streams
-
Creates a
KafkaStreamsMetrics
for theKafkaStreams
. - KafkaStreamsMicrometerListener(MeterRegistry) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
-
Construct an instance with the provided registry.
- KafkaStreamsMicrometerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
-
Construct an instance with the provided registry and tags.
- kafkaTemplate() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The bean name of the
KafkaTemplate
bean that will be used to forward the message to the retry and Dlt topics. - kafkaTemplate(ProducerFactory<Integer, String>) - Method in class org.springframework.kafka.jdocs.started.noboot.Config
- KafkaTemplate<K,V> - Class in org.springframework.kafka.core
-
A template for executing high-level operations.
- KafkaTemplate(ProducerFactory<K, V>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
-
Create an instance using the supplied producer factory and autoFlush false.
- KafkaTemplate(ProducerFactory<K, V>, boolean) - Constructor for class org.springframework.kafka.core.KafkaTemplate
-
Create an instance using the supplied producer factory and autoFlush setting.
- KafkaTemplate(ProducerFactory<K, V>, boolean, Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
-
Create an instance using the supplied producer factory and autoFlush setting.
- KafkaTemplate(ProducerFactory<K, V>, Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
-
Create an instance using the supplied producer factory and properties, with autoFlush false.
- KafkaTestUtils - Class in org.springframework.kafka.test.utils
-
Kafka testing utilities.
- KafkaTransactionManager<K,V> - Class in org.springframework.kafka.transaction
-
PlatformTransactionManager
implementation for a single KafkaProducerFactory
. - KafkaTransactionManager(ProducerFactory<K, V>) - Constructor for class org.springframework.kafka.transaction.KafkaTransactionManager
-
Create a new KafkaTransactionManager, given a ProducerFactory.
- KafkaUtils - Class in org.springframework.kafka.support
-
Utility methods.
- key(K) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the record key when sending data to Kafka.
- KEY_DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Default header name for key type information.
- KEY_DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Default header name for key container object contents type information.
- KEY_DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Default header name for key map key type information.
- KEY_DEFAULT_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property for the default key type if no header.
- KEY_DESERIALIZER_CLASS - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Property name for the delegate key deserializer.
- KEY_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Deprecated.in favor of
SerializationUtils.KEY_DESERIALIZER_EXCEPTION_HEADER
. - KEY_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.SerializationUtils
-
Header name for deserialization exceptions.
- KEY_DESERIALIZER_EXCEPTION_HEADER_PREFIX - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Deprecated.
- KEY_EXCEPTION_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception class name for a record published sent to another topic with a key deserialization exception.
- KEY_EXCEPTION_MESSAGE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception message for a record published to another topic with a key deserialization exception.
- KEY_EXCEPTION_STACKTRACE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Exception stack trace for a record published to another topic with a key deserialization exception.
- KEY_FUNCTION - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Supplier for a T when deserialization fails.
- KEY_PARSER - Static variable in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Property for the key parser method.
- KEY_SERIALIZATION_SELECTOR - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
-
Name of the header containing the serialization selector for keys.
- KEY_SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
-
Name of the configuration property containing the serialization selector map for keys with format
selector:class,...
. - KEY_SERIALIZATION_TOPIC_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Name of the configuration property containing the serialization topic pattern map for keys with format
pattern:class,...
. - KEY_SERIALIZATION_TOPIC_DEFAULT - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Name of the default delegate for keys when no topic name match is fount.
- KEY_TYPE - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Header for the type of key.
- KEY_TYPE_METHOD - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
A method name to determine the
JavaType
to deserialize the key to: 'com.Foo.deserialize'. - keyDeserializer(boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Set to true if this deserializer is to be used as a key deserializer when configuring outside of Kafka.
- keyExceptionFqcn(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the keyExceptionFqcn of the original record.
- keyExceptionMessage(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the keyExceptionMessage of the original record.
- keyExceptionStacktrace(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
-
Sets the name of the header that will be used to store the keyExceptionStacktrace of the original record.
- keyValue(K, V) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- KSTREAM_DESERIALIZATION_RECOVERER - Static variable in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
-
Property name for configuring the recoverer using properties.
L
- LATEST_ONLY - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
-
Commit the current offset during partition assignment when auto.offset.reset is 'latest'; transactional if so configured.
- LATEST_ONLY_NO_TX - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
-
Commit the current offset during partition assignment when auto.offset.reset is 'latest'; use consumer commit even when transactions are being used.
- level() - Method in annotation type org.springframework.kafka.test.condition.LogLevels
-
The Log4j level name to switch the categories to during the test.
- LevelsContainer(Map<Class<?>, Level>, Map<String, Level>) - Constructor for class org.springframework.kafka.test.utils.JUnitUtils.LevelsContainer
- lifecycleMonitor - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- listen(String) - Method in class org.springframework.kafka.jdocs.dynamic.MyPojo
- listen(String) - Method in class org.springframework.kafka.jdocs.requestreply.Application
- listen(String) - Method in class org.springframework.kafka.jdocs.started.consumer.Application
- listen1(String) - Method in class org.springframework.kafka.jdocs.started.noboot.Listener
- listener() - Method in class org.springframework.kafka.jdocs.started.noboot.Config
- Listener - Class in org.springframework.kafka.jdocs.started.noboot
-
Code snippet for quick start.
- Listener() - Constructor for class org.springframework.kafka.jdocs.started.noboot.Listener
- LISTENER_INFO - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Arbitrary static information about the listener receiving this record.
- listenerContainerFactory() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The bean name of the
ConcurrentKafkaListenerContainerFactory
that will be used to create the consumers for the retry and dlt topics. - listenerContainerFactoryConfigurer(KafkaConsumerBackoffManager, DeadLetterPublishingRecovererFactory, Clock) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create a
ListenerContainerFactoryConfigurer
that will be used to configure theKafkaListenerContainerFactory
resolved by theListenerContainerFactoryResolver
. - ListenerContainerFactoryConfigurer - Class in org.springframework.kafka.retrytopic
-
Decorates the provided
ConcurrentKafkaListenerContainerFactory
to add aDefaultErrorHandler
and theDeadLetterPublishingRecoverer
created by theDeadLetterPublishingRecovererFactory
. - ListenerContainerFactoryConfigurer(KafkaConsumerBackoffManager, DeadLetterPublishingRecovererFactory, Clock) - Constructor for class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- listenerContainerFactoryResolver(BeanFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the
ListenerContainerFactoryResolver
that will be used to resolve the appropriateKafkaListenerContainerFactory
for a given topic. - ListenerContainerFactoryResolver - Class in org.springframework.kafka.retrytopic
-
Resolves a
ConcurrentKafkaListenerContainerFactory
to be used by theRetryTopicConfiguration
. - ListenerContainerFactoryResolver(BeanFactory) - Constructor for class org.springframework.kafka.retrytopic.ListenerContainerFactoryResolver
- ListenerContainerIdleEvent - Class in org.springframework.kafka.event
-
An event that is emitted when a container is idle if the container is configured to do so.
- ListenerContainerIdleEvent(Object, Object, long, String, Collection<TopicPartition>, Consumer<?, ?>, boolean) - Constructor for class org.springframework.kafka.event.ListenerContainerIdleEvent
-
Construct an instance with the provided arguments.
- ListenerContainerNoLongerIdleEvent - Class in org.springframework.kafka.event
-
An event that is emitted when a container is no longer idle if configured to publish idle events.
- ListenerContainerNoLongerIdleEvent(Object, Object, long, String, Collection<TopicPartition>, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
Construct an instance with the provided arguments.
- ListenerContainerPartitionIdleEvent - Class in org.springframework.kafka.event
-
An event that is emitted when a container partition is idle if the container is configured to do so.
- ListenerContainerPartitionIdleEvent(Object, Object, long, String, TopicPartition, Consumer<?, ?>, boolean) - Constructor for class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
Construct an instance with the provided arguments.
- ListenerContainerPartitionNoLongerIdleEvent - Class in org.springframework.kafka.event
-
An event that is emitted when a partition is no longer idle if configured to publish idle events.
- ListenerContainerPartitionNoLongerIdleEvent(Object, Object, long, String, TopicPartition, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
Construct an instance with the provided arguments.
- ListenerContainerPauseService - Class in org.springframework.kafka.listener
-
Service for pausing and resuming of
MessageListenerContainer
. - ListenerContainerPauseService(ListenerContainerRegistry, TaskScheduler) - Constructor for class org.springframework.kafka.listener.ListenerContainerPauseService
-
Create an instance with the provided registry and scheduler.
- ListenerContainerRegistry - Interface in org.springframework.kafka.listener
-
A registry for listener containers.
- ListenerExecutionFailedException - Exception in org.springframework.kafka.listener
-
The listener specific
KafkaException
extension. - ListenerExecutionFailedException(String) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
-
Construct an instance with the provided properties.
- ListenerExecutionFailedException(String, String, Throwable) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
-
Construct an instance with the provided properties.
- ListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
-
Construct an instance with the provided properties.
- listenerFactory(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- listenerFactory(ConcurrentKafkaListenerContainerFactory<?, ?>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- ListenerInvokingBatchErrorHandler - Interface in org.springframework.kafka.listener
-
A batch error handler that is capable of invoking the listener during error handling.
- ListenerMetadata - Interface in org.springframework.kafka.listener
-
Metadata associated to a
KafkaListener
. - ListenerType - Enum in org.springframework.kafka.listener
-
Defines the listener type.
- ListenerUtils - Class in org.springframework.kafka.listener
-
Listener utilities.
- listTopics() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- log(Supplier<CharSequence>) - Method in class org.springframework.kafka.support.LogIfLevelEnabled
- log(Supplier<CharSequence>, Throwable) - Method in class org.springframework.kafka.support.LogIfLevelEnabled
- Log4j2LevelAdjuster - Class in org.springframework.kafka.test.rule
-
A JUnit method @Rule that changes the logger level for a set of classes while a test method is running.
- Log4j2LevelAdjuster(Level, Class<?>...) - Constructor for class org.springframework.kafka.test.rule.Log4j2LevelAdjuster
- logger - Variable in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- logger - Variable in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- logger - Variable in class org.springframework.kafka.core.KafkaTemplate
- logger - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- logger - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- logger - Variable in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- logger - Variable in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
- logger - Variable in class org.springframework.kafka.listener.FailedRecordProcessor
- logger - Variable in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
- logger - Variable in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- logger - Variable in class org.springframework.kafka.support.converter.MessagingMessageConverter
- logger - Variable in class org.springframework.kafka.support.LoggingProducerListener
- LOGGER - Static variable in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
-
LogAccessor
for use in default methods. - LoggingCommitCallback - Class in org.springframework.kafka.listener
-
Logs commit results at DEBUG level for success and ERROR for failures.
- LoggingCommitCallback() - Constructor for class org.springframework.kafka.listener.LoggingCommitCallback
- LoggingErrorHandler - Class in org.springframework.kafka.listener
-
Deprecated.- use the
CommonLoggingErrorHandler
instead. - LoggingErrorHandler() - Constructor for class org.springframework.kafka.listener.LoggingErrorHandler
-
Deprecated.
- LoggingProducerListener<K,V> - Class in org.springframework.kafka.support
-
The
ProducerListener
that logs exceptions thrown when sending messages. - LoggingProducerListener() - Constructor for class org.springframework.kafka.support.LoggingProducerListener
- LogIfLevelEnabled - Class in org.springframework.kafka.support
-
Wrapper for a commons-logging Log supporting configurable logging levels.
- LogIfLevelEnabled(LogAccessor, LogIfLevelEnabled.Level) - Constructor for class org.springframework.kafka.support.LogIfLevelEnabled
- LogIfLevelEnabled.Level - Enum in org.springframework.kafka.support
-
Logging levels.
- logLateArrival(ConsumerRecord<K, R>, CorrelationKey) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- LogLevels - Annotation Type in org.springframework.kafka.test.condition
-
Test classes annotated with this will change logging levels between tests.
- LogLevelsCondition - Class in org.springframework.kafka.test.condition
-
JUnit condition that adjusts and reverts log levels before/after each test.
- LogLevelsCondition() - Constructor for class org.springframework.kafka.test.condition.LogLevelsCondition
M
- main(String[]) - Static method in class org.springframework.kafka.jdocs.dynamic.Application
- main(String[]) - Static method in class org.springframework.kafka.jdocs.requestreply.Application
- main(String[]) - Static method in class org.springframework.kafka.jdocs.started.consumer.Application
- main(String[]) - Static method in class org.springframework.kafka.jdocs.started.noboot.Sender
- main(String[]) - Static method in class org.springframework.kafka.jdocs.started.producer.Application
- manageNonBlockingFatalExceptions(List<Class<? extends Throwable>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Override this method to manage non-blocking retries fatal exceptions.
- MANUAL - org.springframework.kafka.listener.ContainerProperties.AckMode
-
Listener is responsible for acking - use a
AcknowledgingMessageListener
; acks will be queued and offsets will be committed when all the records returned by the previous poll have been processed by the listener. - MANUAL_IMMEDIATE - org.springframework.kafka.listener.ContainerProperties.AckMode
-
Listener is responsible for acking - use a
AcknowledgingMessageListener
; the commit will be performed immediately if theAcknowledgment
is acknowledged on the calling consumer thread; otherwise, the acks will be queued and offsets will be committed when all the records returned by the previous poll have been processed by the listener; results will be indeterminate if you sometimes acknowledge on the calling thread and sometimes not. - ManualAckListenerErrorHandler - Interface in org.springframework.kafka.listener
-
A
KafkaListenerErrorHandler
that supports manual acks. - MappingJacksonParameterizedConverter - Class in org.springframework.kafka.support.converter
-
Subclass of
MappingJackson2MessageConverter
that can handle parameterized (generic) types. - MappingJacksonParameterizedConverter() - Constructor for class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
-
Construct a
MappingJacksonParameterizedConverter
supporting theapplication/json
MIME type withUTF-8
character set. - MappingJacksonParameterizedConverter(MimeType...) - Constructor for class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
-
Construct a
MappingJacksonParameterizedConverter
supporting one or more custom MIME types. - matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
- matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
- matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordTimestampMatcher
- matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordValueMatcher
- matches(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
- matches(String, Object) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
- matches(ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordPartitionCondition
- matches(ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordTimestampCondition
- matches(ConsumerRecord<?, V>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordValueCondition
- matches(ConsumerRecord<K, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyCondition
- matches(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyValueCondition
- matchesForInbound(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Matches header names for inbound mapping when configured as an inbound mapper.
- matchHandlerMethod(Class<? extends Object>, InvocableHandlerMethod) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
- matchHeader(String) - Method in interface org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
-
Return true if the header matches.
- matchHeader(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
- matchHeader(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
- maxAttempts(int) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- maybeAddTo(String) - Method in class org.springframework.kafka.support.Suffixer
- maybeAddTo(Collection<String>) - Method in class org.springframework.kafka.support.Suffixer
- MESSAGE_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Deprecated.in favor of
KafkaHeaders.KEY
. - MessageConverter - Interface in org.springframework.kafka.support.converter
-
A top level interface for message converters.
- MessageListener<K,V> - Interface in org.springframework.kafka.listener
-
Listener for handling individual incoming Kafka messages.
- MessageListenerContainer - Interface in org.springframework.kafka.listener
-
Internal abstraction used by the framework representing a message listener container.
- MessagingFunction - Interface in org.springframework.kafka.streams.messaging
-
A function that receives a spring-messaging
Message
and returns aMessage
. - MessagingMessageConverter - Class in org.springframework.kafka.support.converter
-
A Messaging
MessageConverter
implementation for a message listener that receives individual messages. - MessagingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.MessagingMessageConverter
- MessagingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
An abstract
MessageListener
adapter providing the necessary infrastructure to extract the payload of aMessage
. - MessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- MessagingMessageListenerAdapter.ReplyExpressionRoot - Class in org.springframework.kafka.listener.adapter
-
Root object for reply expression evaluation.
- MessagingTransformer<K,V,R> - Class in org.springframework.kafka.streams.messaging
-
A
Transformer
implementation that invokes aMessagingFunction
converting to/from spring-messagingMessage
. - MessagingTransformer(MessagingFunction, MessagingMessageConverter) - Constructor for class org.springframework.kafka.streams.messaging.MessagingTransformer
-
Construct an instance with the provided function and converter.
- MethodKafkaListenerEndpoint<K,V> - Class in org.springframework.kafka.config
-
A
KafkaListenerEndpoint
providing the method to invoke to process an incoming message for this endpoint. - MethodKafkaListenerEndpoint() - Constructor for class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- metrics() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- metrics() - Method in interface org.springframework.kafka.core.KafkaOperations
-
See
Producer.metrics()
. - metrics() - Method in interface org.springframework.kafka.core.KafkaOperations2
-
See
Producer.metrics()
. - metrics() - Method in class org.springframework.kafka.core.KafkaTemplate
- metrics() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- metrics() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- metrics() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- metrics() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return metrics kept by this container's consumer(s), grouped by
client-id
. - metricsFromConsumer() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- metricsFromProducer() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- MICROMETER_PRESENT - Static variable in class org.springframework.kafka.support.KafkaUtils
-
True if micrometer is on the class path.
- MicrometerConsumerListener<K,V> - Class in org.springframework.kafka.core
-
A consumer factory listener that manages
KafkaClientMetrics
. - MicrometerConsumerListener(MeterRegistry) - Constructor for class org.springframework.kafka.core.MicrometerConsumerListener
-
Construct an instance with the provided registry.
- MicrometerConsumerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.core.MicrometerConsumerListener
-
Construct an instance with the provided registry and tags.
- MicrometerHolder - Class in org.springframework.kafka.support.micrometer
-
A wrapper for micrometer timers when available on the class path.
- MicrometerHolder(ApplicationContext, String, String, String, Function<Object, Map<String, String>>) - Constructor for class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Create an instance with the provided properties.
- MicrometerHolder(ApplicationContext, String, String, String, Map<String, String>) - Constructor for class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Deprecated.
- MicrometerProducerListener<K,V> - Class in org.springframework.kafka.core
-
A producer factory listener that manages
KafkaClientMetrics
. - MicrometerProducerListener(MeterRegistry) - Constructor for class org.springframework.kafka.core.MicrometerProducerListener
-
Construct an instance with the provided registry.
- MicrometerProducerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.core.MicrometerProducerListener
-
Construct an instance with the provided registry and tags.
- MultiMethodKafkaListenerEndpoint<K,V> - Class in org.springframework.kafka.config
-
The
MethodKafkaListenerEndpoint
extension for several POJO methods based on theKafkaHandler
. - MultiMethodKafkaListenerEndpoint(List<Method>, Method, Object) - Constructor for class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
-
Construct an instance for the provided methods, default method and bean.
- MULTIPLE_TOPICS - org.springframework.kafka.retrytopic.FixedDelayStrategy
-
Uses one separate topic per retry attempt.
- MyListener - Class in org.springframework.kafka.jdocs.dynamic
-
MessageListener
for dynamic containers. - MyListener() - Constructor for class org.springframework.kafka.jdocs.dynamic.MyListener
- MyPojo - Class in org.springframework.kafka.jdocs.dynamic
-
Pojo for dynamic listener creation.
- MyPojo(String, String) - Constructor for class org.springframework.kafka.jdocs.dynamic.MyPojo
N
- nack(int, long) - Method in interface org.springframework.kafka.support.Acknowledgment
-
Deprecated.in favor of
Acknowledgment.nack(int, Duration)
- nack(int, Duration) - Method in interface org.springframework.kafka.support.Acknowledgment
-
Negatively acknowledge the record at an index in a batch - commit the offset(s) of records before the index and re-seek the partitions so that the record at the index and subsequent records will be redelivered after the sleep duration.
- nack(long) - Method in interface org.springframework.kafka.support.Acknowledgment
-
Deprecated.in favor of
Acknowledgment.nack(Duration)
- nack(Duration) - Method in interface org.springframework.kafka.support.Acknowledgment
-
Negatively acknowledge the current record - discard remaining records from the poll and re-seek all partitions so that this record will be redelivered after the sleep duration.
- name(String) - Static method in class org.springframework.kafka.config.TopicBuilder
-
Create a TopicBuilder with the supplied name.
- NATIVE_HEADERS - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for holding the native headers of the consumer record; only provided if no header mapper is present.
- NEVER - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
-
Never commit the current offset during partition assignment.
- neverLogListenerException() - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Never logs the listener exception.
- NeverMatchHeaderMatcher(String...) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
- newInstance() - Static method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Create a new instance of the builder.
- newTopics() - Method in class org.springframework.kafka.core.KafkaAdmin
-
Return a collection of
NewTopic
s to create or modify. - NewTopics(NewTopic...) - Constructor for class org.springframework.kafka.core.KafkaAdmin.NewTopics
-
Construct an instance with the
NewTopic
s. - NO_DLT - org.springframework.kafka.retrytopic.DltStrategy
-
Don't create a DLT.
- NO_OFFSET - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
No offset found for a partition and no reset policy.
- noBackoff() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- noBeanFoundMessage(Object, String, String, Class<?>) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- NonResponsiveConsumerEvent - Class in org.springframework.kafka.event
-
An event that is emitted when a consumer is not responding to the poll; with early versions of the kafka-clients, this was a possible indication that the broker is down.
- NonResponsiveConsumerEvent(Object, Object, long, String, Collection<TopicPartition>, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
Construct an instance with the provided properties.
- NonTrustedHeaderType() - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- NORMAL - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
The consumer was stopped because the container was stopped.
- NOT_SET - Static variable in class org.springframework.kafka.retrytopic.RetryTopicConstants
-
Constant to represent that the integer property is not set.
- notRetryable(Stream<Class<? extends Exception>>) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Subclasses can override this to receive notification of configuration of not retryable exceptions.
- notRetryable(Stream<Class<? extends Exception>>) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- notRetryOn(Class<? extends Throwable>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- notRetryOn(List<Class<? extends Throwable>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- noTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Configure the serializer to not add type information.
- noTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Do not include type info headers.
- NULL_MESSAGE - Static variable in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Message used when no conversion is needed.
- numPartitions() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The number of partitions for the automatically created topics.
- numPartitions() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Return the number of partitions the retry topics should be created with.
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 - 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
- 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.
- onFailure(Throwable) - Method in interface org.springframework.kafka.core.KafkaFailureCallback
-
Deprecated.
- onFailure(KafkaProducerException) - Method in interface org.springframework.kafka.core.KafkaFailureCallback
-
Deprecated.Called when the send fails.
- 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<String, String>) - Method in class org.springframework.kafka.jdocs.dynamic.MyListener
- 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 class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
- 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 class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
- 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) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
- 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
-
Kafka
AcknowledgingConsumerAwareMessageListener
entry point. - onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.
- 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 ofConsumerRecord
. - 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.CommonErrorHandler
-
Deprecated.
- 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. - 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 - 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.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.jdocs.dynamic - package org.springframework.kafka.jdocs.dynamic
- org.springframework.kafka.jdocs.requestreply - package org.springframework.kafka.jdocs.requestreply
- org.springframework.kafka.jdocs.started.consumer - package org.springframework.kafka.jdocs.started.consumer
- org.springframework.kafka.jdocs.started.noboot - package org.springframework.kafka.jdocs.started.noboot
- org.springframework.kafka.jdocs.started.producer - package org.springframework.kafka.jdocs.started.producer
- org.springframework.kafka.jdocs.topics - package org.springframework.kafka.jdocs.topics
- 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.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.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.
P
- parentOrThis() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return this or a parent container if this has a parent.
- parentOrThis() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- parseBooleanProperty(String) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
-
Return the parsed value if the provided property exists in the environment or system properties.
- PARSER_CONTEXT - Static variable in class org.springframework.kafka.listener.adapter.AdapterUtils
-
Parser context for runtime SpEL using ! as the template prefix.
- ParseStringDeserializer<T> - Class in org.springframework.kafka.support.serializer
-
Generic
Deserializer
for deserialization of entity from itsString
representation received from Kafka (a.k.a parsing). - ParseStringDeserializer() - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Construct an instance with no parser function; a static method name must be provided in the consumer config
ParseStringDeserializer.KEY_PARSER
orParseStringDeserializer.VALUE_PARSER
properties. - ParseStringDeserializer(BiFunction<String, Headers, T>) - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Construct an instance with the supplied parser function.
- ParseStringDeserializer(Function<String, T>) - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Construct an instance with the supplied parser function.
- PARTIAL_RESULTS_AFTER_TIMEOUT_TOPIC - Static variable in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Pseudo topic name for the "outer"
ConsumerRecord
that has the aggregated results in its value after a timeout. - partition() - Method in annotation type org.springframework.kafka.annotation.PartitionOffset
-
The partition within the topic to listen on.
- partition() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- partition(int) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- PARTITION - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The partition from which the failed record was received.
- PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the topic partition when sending data to Kafka.
- PARTITION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Deprecated.in favor of
KafkaHeaders.PARTITION
. - partitionHeader(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 partition of the original record.
- PartitionOffset - Annotation Type in org.springframework.kafka.annotation
-
Used to add partition/initial offset information to a
KafkaListener
. - partitionOffsets() - Method in annotation type org.springframework.kafka.annotation.TopicPartition
-
The partitions with initial offsets within the topic.
- partitions() - Method in annotation type org.springframework.kafka.annotation.TopicPartition
-
The partitions within the topic.
- partitions() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
- partitions(int) - Method in class org.springframework.kafka.config.TopicBuilder
-
Set the number of partitions (default broker 'num.partitions').
- partitionsFor(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- partitionsFor(String) - Method in interface org.springframework.kafka.core.KafkaOperations
-
See
Producer.partitionsFor(String)
. - partitionsFor(String) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
See
Producer.partitionsFor(String)
. - partitionsFor(String) - Method in class org.springframework.kafka.core.KafkaTemplate
- partitionsFromConsumerFor(String) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- partitionsFromProducerFor(String) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- pause() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- pause() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- pause() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- pause() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Pause this container before the next poll().
- pause(String, Duration) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Pause the listener by given id.
- pause(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- pause(MessageListenerContainer, Duration) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Pause the listener by given container instance.
- paused() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- pausePartition(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- pausePartition(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- pausePartition(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Pause this partition before the next poll().
- pausePartition(MessageListenerContainer, TopicPartition, Duration) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Pause consumption from a given partition for the duration.
- ports() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Set explicit ports on which the kafka brokers will listen.
- position(TopicPartition) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- postProcessAfterInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- postProcessBeforeInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- PREFIX - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The prefix for Kafka headers.
- primary() - Method in class org.springframework.kafka.core.ABSwitchCluster
-
Use the primary cluster.
- process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
-
Process the remaining records.
- process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
- process(MethodKafkaListenerEndpoint<?, ?>) - Method in interface org.springframework.kafka.retrytopic.RetryTopicConfigurer.EndpointProcessor
- processAnnotation(String[], Method, RetryableTopic, Object) - Method in class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
- processDestinationTopicProperties(Consumer<DestinationTopic.Properties>, DestinationTopicProcessor.Context) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- processDestinationTopicProperties(Consumer<DestinationTopic.Properties>, DestinationTopicProcessor.Context) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicProcessor
-
Process the destination properties.
- processKafkaListener(KafkaListener, Method, Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- processListener(MethodKafkaListenerEndpoint<?, ?>, KafkaListener, Object, String, String[], TopicPartitionOffset[]) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- processMainAndRetryListeners(RetryTopicConfigurer.EndpointProcessor, MethodKafkaListenerEndpoint<?, ?>, RetryTopicConfiguration, KafkaListenerEndpointRegistrar, KafkaListenerContainerFactory<?>, String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
-
Entrypoint for creating and configuring the retry and dlt endpoints, as well as the container factory that will create the corresponding listenerContainer.
- processRegisteredDestinations(Consumer<Collection<String>>, DestinationTopicProcessor.Context) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- processRegisteredDestinations(Consumer<Collection<String>>, DestinationTopicProcessor.Context) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicProcessor
-
Process the registered destinations.
- producerAdded(String, Producer<K, V>) - Method in class org.springframework.kafka.core.MicrometerProducerListener
- producerAdded(String, Producer<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory.Listener
-
A new producer was created.
- producerFactory() - Method in class org.springframework.kafka.jdocs.started.noboot.Config
- ProducerFactory<K,V> - Interface in org.springframework.kafka.core
-
The strategy to produce a
Producer
instance(s). - ProducerFactory.Listener<K,V> - Interface in org.springframework.kafka.core
-
Called whenever a producer is added or removed.
- ProducerFactoryUtils - Class in org.springframework.kafka.core
-
Helper class for managing a Spring based Kafka
DefaultKafkaProducerFactory
in particular for obtaining transactional Kafka resources for a given ProducerFactory. - ProducerListener<K,V> - Interface in org.springframework.kafka.support
-
Listener for handling outbound Kafka messages.
- ProducerPostProcessor<K,V> - Interface in org.springframework.kafka.core
-
Called by producer factories to perform post processing on newly created producers.
- producerProps(String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Set up test properties for an
<Integer, String>
producer. - producerProps(EmbeddedKafkaBroker) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Set up test properties for an
<Integer, String>
producer. - producerRemoved(String, Producer<K, V>) - Method in class org.springframework.kafka.core.MicrometerProducerListener
- producerRemoved(String, Producer<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory.Listener
-
An existing producer was removed.
- ProjectingMessageConverter - Class in org.springframework.kafka.support.converter
-
A
MessageConverter
implementation that uses a Spring DataProjectionFactory
to bind incoming messages to projection interfaces. - ProjectingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using aJacksonUtils.enhancedObjectMapper()
by default. - ProjectingMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using the givenObjectMapper
. - ProjectingMessageConverter(ObjectMapper, MessagingMessageConverter) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using the givenObjectMapper
. - ProjectingMessageConverter(MessagingMessageConverter) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using the givenObjectMapper
. - properties - Variable in class org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
- properties() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
Kafka consumer properties; they will supersede any properties with the same name defined in the consumer factory (if the consumer factory supports property overrides).
- Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties with the DLT container starting automatically (if the container factory is so configured).
- Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long, Boolean) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties.
- Properties(DestinationTopic.Properties, String, DestinationTopic.Type) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties with the DLT container starting automatically.
- propertiesFromConsumerPropertyOverrides() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Make any default consumer override properties explicit properties.
- propertyToMethodInvokingFunction(String, Class<P>, ClassLoader) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
-
Convert a property value (FQCN.methodName) to a
BiFunction
that takes a payload and headers and returns some value. - provide(ListenerMetadata, long) - Method in interface org.springframework.kafka.listener.OffsetAndMetadataProvider
-
Provide an offset and metadata object for the given listener metadata and offset.
- publish(ProducerRecord<Object, Object>, KafkaOperations<Object, Object>, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Override this if you want more than just logging of the send result.
- publishConsumerPausedEvent(Collection<TopicPartition>, String) - Method in interface org.springframework.kafka.listener.ConsumerPauseResumeEventPublisher
-
Publish a consumer paused event.
- publishConsumerPausedEvent(Collection<TopicPartition>, String) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- publishConsumerResumedEvent(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerPauseResumeEventPublisher
-
Publish a consumer resumed event.
- publishConsumerResumedEvent(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- publishContainerStoppedEvent() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
R
- RAW_DATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the raw data received from Kafka (
ConsumerRecord
orConsumerRecords
). - ReactiveKafkaConsumerTemplate<K,V> - Class in org.springframework.kafka.core.reactive
-
Reactive kafka consumer operations implementation.
- ReactiveKafkaConsumerTemplate(ReceiverOptions<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- ReactiveKafkaProducerTemplate<K,V> - Class in org.springframework.kafka.core.reactive
-
Reactive kafka producer operations implementation.
- ReactiveKafkaProducerTemplate(SenderOptions<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- ReactiveKafkaProducerTemplate(SenderOptions<K, V>, RecordMessageConverter) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- receive() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- receive(String, int, long) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Receive a single record with the default poll timeout (5 seconds).
- receive(String, int, long) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Receive a single record with the default poll timeout (5 seconds).
- receive(String, int, long, Duration) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Receive a single record.
- receive(String, int, long, Duration) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Receive a single record.
- receive(String, int, long, Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
- receive(Collection<TopicPartitionOffset>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Receive a multiple records with the default poll timeout (5 seconds).
- receive(Collection<TopicPartitionOffset>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Receive a multiple records with the default poll timeout (5 seconds).
- receive(Collection<TopicPartitionOffset>, Duration) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Receive multiple records.
- receive(Collection<TopicPartitionOffset>, Duration) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Receive multiple records.
- receive(Collection<TopicPartitionOffset>, Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
- receiveAtMostOnce() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- receiveAutoAck() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- RECEIVED - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The prefix for Kafka headers containing 'received' values.
- RECEIVED_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the record key from the received message.
- RECEIVED_MESSAGE_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Deprecated.in favor of
KafkaHeaders.RECEIVED_KEY
. - RECEIVED_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the topic partition from the received message.
- RECEIVED_PARTITION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
Deprecated.in favor of
KafkaHeaders.RECEIVED_PARTITION
. - RECEIVED_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for holding the timestamp of the consumer record.
- RECEIVED_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the topic from which the message was received.
- receiveExactlyOnce(TransactionManager) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
-
Returns a
Flux
of consumer record batches that may be used for exactly once delivery semantics. - RECORD - org.springframework.kafka.listener.ContainerProperties.AckMode
-
Commit the offset after each record is processed by the listener.
- RECORD_METADATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the
RecordMetadata
object after successful send to the topic. - RecordFilterStrategy<K,V> - Interface in org.springframework.kafka.listener.adapter
-
Implementations of this interface can signal that a record about to be delivered to a message listener should be discarded instead of being delivered.
- RecordInterceptor<K,V> - Interface in org.springframework.kafka.listener
-
An interceptor for
ConsumerRecord
invoked by the listener container before and after invoking the listener. - RecordMessageConverter - Interface in org.springframework.kafka.support.converter
-
A Kafka-specific
Message
converter strategy. - RecordMessagingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
A
MessageListener
adapter that invokes a configurableHandlerAdapter
; used when the factory is configured for the listener to receive individual messages. - RecordMessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
- RecordMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
- recordsToString(ConsumerRecords<?, ?>) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
-
Represent the records as a comma-delimited String of
topic-part@offset
. - recordToString(ConsumerRecord<?, ?>) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Deprecated.in favor of
KafkaUtils.format(ConsumerRecord)
. - recordToString(ConsumerRecord<?, ?>, boolean) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Deprecated.in favor of
KafkaUtils.format(ConsumerRecord)
. - recovered(ConsumerRecord<?, ?>, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
-
Called after a failing record was successfully recovered.
- recovered(ConsumerRecord<?, ?>, Exception, MessageListenerContainer, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RecoveryStrategy
-
Return true if the record should be skipped because it was successfully recovered.
- recovered(ConsumerRecords<?, ?>, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
-
Called after a failing record was successfully recovered.
- RecoveringDeserializationExceptionHandler - Class in org.springframework.kafka.streams
-
A
DeserializationExceptionHandler
that calls aConsumerRecordRecoverer
. - RecoveringDeserializationExceptionHandler() - Constructor for class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- RecoveringDeserializationExceptionHandler(ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- recoveryFailed(ConsumerRecord<?, ?>, Exception, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
-
Called after a recovery attempt failed.
- recoveryFailed(ConsumerRecords<?, ?>, Exception, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
-
Called after a recovery attempt failed.
- RecoveryStrategy - Interface in org.springframework.kafka.listener
-
Called to determine whether a record should be skipped.
- registerAllEndpoints() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
- registerDestinationTopic(String, String, DestinationTopic.Properties, DestinationTopicProcessor.Context) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- registerDestinationTopic(String, String, DestinationTopic.Properties, DestinationTopicProcessor.Context) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicProcessor
-
Register the destination topic.
- registerEndpoint(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Register a new
KafkaListenerEndpoint
using the defaultKafkaListenerContainerFactory
to create the underlying container. - registerEndpoint(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Register a new
KafkaListenerEndpoint
alongside theKafkaListenerContainerFactory
to use to create the underlying container. - registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Create a message listener container for the given
KafkaListenerEndpoint
. - registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>, boolean) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Create a message listener container for the given
KafkaListenerEndpoint
. - registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
-
Register the callback to use when seeking at some arbitrary time.
- relativeToCurrent() - Method in annotation type org.springframework.kafka.annotation.PartitionOffset
-
By default, positive
PartitionOffset.initialOffset()
is absolute, negative is relative to the current topic end. - releaseResources(KafkaResourceHolder<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
- remainingRecords() - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
-
Deprecated.
- remainingRecords() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- remainingRecords() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Deprecated.in favor of
CommonErrorHandler.seeksAfterHandling()
. - remainingRecords() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- remainingRecords() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
-
Deprecated.
- RemainingRecordsErrorHandler - Interface in org.springframework.kafka.listener
-
An error handler that has access to the unprocessed records from the last poll (including the failed record) and the consumer, for example to adjust offsets after an error.
- REMOVE_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property for removing type headers (default true).
- removeClassification(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Remove an exception type from the configured list.
- removeClassification(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- removeConfig(String) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Remove the specified key from the configuration map.
- removeConfig(String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- removeConfig(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- removeConfig(String) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Remove the specified key from the configuration map.
- removeContainer(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerGroup
-
Remove a container from the group.
- removeDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- removeDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- removeDelegate(Pattern) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- removeDelegate(ProducerListener<K, V>) - Method in class org.springframework.kafka.support.CompositeProducerListener
- removeHeaders(Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- removeHeaders(Headers) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
-
Remove the type information headers.
- removeListener(StreamsBuilderFactoryBean.Listener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Remove a listener.
- removeListener(ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Remove a listener.
- removeListener(ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Remove a listener.
- removeListener(ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Remove a listener.
- removeListener(ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Remove a listener.
- removeNotRetryableException(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Deprecated.in favor of
ExceptionClassifier.removeClassification(Class)
- removeNotRetryableException(Class<? extends Exception>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Remove an exception type from the configured list.
- removePostProcessor(ConsumerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Remove a post processor.
- removePostProcessor(ConsumerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- removePostProcessor(ProducerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- removePostProcessor(ProducerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Remove a post processor.
- removeProducer(DefaultKafkaProducerFactory.CloseSafeProducer<K, V>, Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Remove the single shared producer and a thread-bound instance if present.
- renderProperties() - Method in class org.springframework.kafka.listener.ConsumerProperties
- replicas(int) - Method in class org.springframework.kafka.config.TopicBuilder
-
Set the number of replicas (default broker 'default.replication.factor').
- replicasAssignments(Map<Integer, List<Integer>>) - Method in class org.springframework.kafka.config.TopicBuilder
-
Set the replica assignments.
- replicationFactor() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The replication factor for the automatically created topics.
- REPLY_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing a partition number on which to send the reply.
- REPLY_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the default reply topic.
- ReplyExpressionRoot(Object, Object, Object) - Constructor for class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- ReplyHeadersConfigurer - Interface in org.springframework.kafka.listener.adapter
-
A strategy for configuring which headers, if any, should be set in a reply message.
- ReplyingKafkaOperations<K,V,R> - Interface in org.springframework.kafka.requestreply
-
Request/reply operations.
- ReplyingKafkaTemplate<K,V,R> - Class in org.springframework.kafka.requestreply
-
A KafkaTemplate that implements request/reply semantics.
- ReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Constructor for class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- ReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>, boolean) - Constructor for class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- RequestReplyFuture<K,V,R> - Class in org.springframework.kafka.requestreply
-
A listenable future for requests/replies.
- RequestReplyFuture() - Constructor for class org.springframework.kafka.requestreply.RequestReplyFuture
- RequestReplyFuture.Completable - Class in org.springframework.kafka.requestreply
-
A
CompletableFuture
version. - RequestReplyMessageFuture<K,V> - Class in org.springframework.kafka.requestreply
-
A listenable future for
Message
replies. - RequestReplyMessageFuture.Completable - Class in org.springframework.kafka.requestreply
-
A
CompletableFuture
version. - RequestReplyTypedMessageFuture<K,V,P> - Class in org.springframework.kafka.requestreply
-
A listenable future for
Message
replies with a specific payload type. - RequestReplyTypedMessageFuture.Completable - Class in org.springframework.kafka.requestreply
-
A
CompletableFuture
version. - REQUIRED - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
-
Required - The
LoginModule
is required to succeed. - REQUISITE - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
-
Requisite - The
LoginModule
is required to succeed. - reset() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Close the
Producer
(s) and clear the cache of transactionalProducer
(s). - reset() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Reset any state in the factory, if supported.
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.kafka.annotation.KafkaNullAwarePayloadArgumentResolver
- resolveBean(BeanFactory) - Method in class org.springframework.kafka.support.EndpointHandlerMethod
- resolveDestinationTopic(String, Integer, Exception, long) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- resolveDestinationTopic(String, Integer, Exception, long) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicResolver
-
Resolves the destination topic for the failed message.
- resolveParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- resolveTopicPartition(ConsumerRecord<?, ?>, DestinationTopic) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Creates and returns the
TopicPartition
, where the original record should be forwarded. - resolveType(String, byte[], Headers) - Method in interface org.springframework.kafka.support.serializer.JsonTypeResolver
-
Determine the type.
- restart(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- resume() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- resume() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- resume() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- resume() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Resume this container, if paused, after the next poll().
- resume(String) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Resume the listener container by given id.
- resume(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- resume(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Resume the listener container.
- resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- resumePartition(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Resume this partition, if paused, after the next poll().
- retrieveHeader(Headers, String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- retrieveHeaderAsString(Headers, String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- RETRY_TOPIC_CONFIGURER_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
-
The bean name of the internally managed retry topic configurer.
- RetryableTopic - Annotation Type in org.springframework.kafka.annotation
-
Annotation to create the retry and dlt topics for a
KafkaListener
annotated listener. - RetryableTopicAnnotationProcessor - Class in org.springframework.kafka.annotation
-
Processes the provided
RetryableTopic
annotation returning anRetryTopicConfiguration
. - RetryableTopicAnnotationProcessor(BeanFactory) - Constructor for class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
-
Construct an instance using the provided parameters and default resolver, expression context.
- RetryableTopicAnnotationProcessor(BeanFactory, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
-
Construct an instance using the provided parameters.
- retryBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable, BackOff, CommonErrorHandler, BiConsumer<ConsumerRecords<?, ?>, Exception>, LogAccessor, KafkaException.Level) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
- retryBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable, BackOff, CommonErrorHandler, BiConsumer<ConsumerRecords<?, ?>, Exception>, LogAccessor, KafkaException.Level, List<RetryListener>, BinaryExceptionClassifier) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
- retryBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable, BackOff, CommonErrorHandler, BiConsumer<ConsumerRecords<?, ?>, Exception>, LogAccessor, KafkaException.Level, List<RetryListener>, BinaryExceptionClassifier, boolean) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
-
Retry a complete batch by pausing the consumer and then, in a loop, poll the consumer, wait for the next back off, then call the listener.
- RetryingDeserializer<T> - Class in org.springframework.kafka.support.serializer
-
A deserialzer configured with a delegate and a
RetryOperations
to retry deserialization in case of transient errors. - RetryingDeserializer(Deserializer<T>, RetryOperations) - Constructor for class org.springframework.kafka.support.serializer.RetryingDeserializer
- RetryingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.Construct an instance with the provided template and delegate.
- RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate, RecoveryCallback<? extends Object>) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.Construct an instance with the provided template, callback and delegate.
- RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate, RecoveryCallback<? extends Object>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
-
Deprecated.Construct an instance with the provided template, callback and delegate.
- RetryListener - Interface in org.springframework.kafka.listener
-
A listener for retry activity.
- retryOn(Class<? extends Exception>...) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.BlockingRetriesConfigurer
-
Set the exceptions that should be retried by the blocking retry mechanism.
- retryOn(Class<? extends Throwable>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- retryOn(List<Class<? extends Throwable>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- RetryTopicBeanNames - Class in org.springframework.kafka.retrytopic
-
The bean names for the non-blocking topic-based delayed retries feature.
- RetryTopicComponentFactory - Class in org.springframework.kafka.retrytopic
-
Provide the component instances that will be used with
RetryTopicConfigurationSupport
. - RetryTopicComponentFactory() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- RetryTopicConfiguration - Class in org.springframework.kafka.retrytopic
-
Contains the provided configuration for the retryable topics.
- RetryTopicConfigurationBuilder - Class in org.springframework.kafka.retrytopic
-
Builder class to create
RetryTopicConfiguration
instances. - RetryTopicConfigurationBuilder() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- RetryTopicConfigurationProvider - Class in org.springframework.kafka.annotation
-
Attempts to provide an instance of
RetryTopicConfiguration
by either creating one from aRetryableTopic
annotation, or from the bean container if no annotation is available. - RetryTopicConfigurationProvider(BeanFactory) - Constructor for class org.springframework.kafka.annotation.RetryTopicConfigurationProvider
-
Construct an instance using the provided bean factory and default resolver and bean expression context.
- RetryTopicConfigurationProvider(BeanFactory, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.annotation.RetryTopicConfigurationProvider
-
Construct an instance using the provided parameters.
- RetryTopicConfigurationSupport - Class in org.springframework.kafka.retrytopic
-
This is the main class providing the configuration behind the non-blocking, topic-based delayed retries feature.
- RetryTopicConfigurationSupport() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- RetryTopicConfigurationSupport.BlockingRetriesConfigurer - Class in org.springframework.kafka.retrytopic
-
Configure blocking retries to be used along non-blocking.
- RetryTopicConfigurationSupport.CustomizersConfigurer - Class in org.springframework.kafka.retrytopic
-
Configure customizers for components instantiated by the retry topics feature.
- retryTopicConfigurer(KafkaConsumerBackoffManager, DestinationTopicResolver, BeanFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
-
Return a global
RetryTopicConfigurer
for configuring retry topics forKafkaListenerEndpoint
instances with a correspondingRetryTopicConfiguration
. - retryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryConfigurer, ListenerContainerFactoryResolver, RetryTopicNamesProviderFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the
RetryTopicConfigurer
that will serve as an entry point for configuring non-blocking topic-based delayed retries for a givenKafkaListenerEndpoint
, by processing the appropriateRetryTopicConfiguration
. - RetryTopicConfigurer - Class in org.springframework.kafka.retrytopic
-
Configures main, retry and DLT topics based on a main endpoint and provided configurations to acomplish a distributed retry / DLT pattern in a non-blocking fashion, at the expense of ordering guarantees.
- RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, BeanFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurer
-
Deprecated.
- RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, BeanFactory, RetryTopicNamesProviderFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurer
-
Deprecated.
- RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, RetryTopicNamesProviderFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurer
-
Create an instance with the provided properties.
- RetryTopicConfigurer.EndpointProcessor - Interface in org.springframework.kafka.retrytopic
- RetryTopicConstants - Class in org.springframework.kafka.retrytopic
-
Constants for the RetryTopic functionality.
- RetryTopicConstants() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConstants
- RetryTopicHeaders - Class in org.springframework.kafka.retrytopic
-
Contains the headers that will be used in the forwarded messages.
- RetryTopicHeaders() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicHeaders
- retryTopicNamesProviderFactory() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
-
Create the
RetryTopicNamesProviderFactory
instance that will be used to provide the property names for the retry topics'KafkaListenerEndpoint
. - RetryTopicNamesProviderFactory - Interface in org.springframework.kafka.retrytopic
-
Handles the naming related to the retry and dead letter topics.
- RetryTopicNamesProviderFactory.RetryTopicNamesProvider - Interface in org.springframework.kafka.retrytopic
- RetryTopicSchedulerWrapper - Class in org.springframework.kafka.retrytopic
-
A wrapper class for a
TaskScheduler
to use for scheduling container resumption when a partition has been paused for a retry topic. - RetryTopicSchedulerWrapper(TaskScheduler) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper
-
Create a wrapper for the supplied scheduler.
- retryTopicSuffix() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The suffix that will be appended to the main topic in order to generate the retry topics.
- retryTopicSuffix(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- returnTypeMessageOrCollectionOf(Method) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Return true if the method return type is
Message
orCollection<Message<?>>
. - revertLevels(String, JUnitUtils.LevelsContainer) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
- rollback() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- RoutingKafkaTemplate - Class in org.springframework.kafka.core
-
A
KafkaTemplate
that routes messages based on the topic name. - RoutingKafkaTemplate(Map<Pattern, ProducerFactory<Object, Object>>) - Constructor for class org.springframework.kafka.core.RoutingKafkaTemplate
-
Construct an instance with the provided properties.
- runner(KafkaTemplate<String, String>) - Method in class org.springframework.kafka.jdocs.started.producer.Application
- runner1(ApplicationContext) - Method in class org.springframework.kafka.jdocs.dynamic.Application
S
- secondary() - Method in class org.springframework.kafka.core.ABSwitchCluster
-
Use the secondary cluster.
- seek(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek operation.
- seek(TopicPartition, long) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- seekOrRecover(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer, boolean, BiPredicate<ConsumerRecord<?, ?>, Exception>, LogAccessor, KafkaException.Level) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Seek the remaining records, optionally recovering the first.
- seekOrRecover(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer, boolean, RecoveryStrategy, LogAccessor, KafkaException.Level) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Seek the remaining records, optionally recovering the first.
- seekPartitions(Consumer<?, ?>, Map<TopicPartition, Long>, LogAccessor) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Perform seek operations on each partition.
- seekRelative(String, int, long, boolean) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek relative to the start, end, or current position.
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- seeksAfterHandling() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Return true if this error handler performs seeks on the failed record and remaining records (or just the remaining records after a failed record is recovered).
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- seekToBeginning() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Seek all assigned partitions to the beginning.
- seekToBeginning(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to beginning operation.
- seekToBeginning(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to beginning operation.
- seekToBeginning(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- SeekToCurrentBatchErrorHandler - Class in org.springframework.kafka.listener
-
Deprecated.with no replacement - use
DefaultErrorHandler
with an infiniteBackOff
. - SeekToCurrentBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
-
Deprecated.
- seekToEnd() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Seek all assigned partitions to the end.
- seekToEnd(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to end operation.
- seekToEnd(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to end operation.
- seekToEnd(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- seekToTimestamp(long) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Seek all assigned partitions to the offset represented by the timestamp.
- seekToTimestamp(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to the first offset greater than or equal to the time stamp.
- seekToTimestamp(Collection<TopicPartition>, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to the first offset greater than or equal to the time stamp.
- SeekUtils - Class in org.springframework.kafka.listener
-
Seek utilities.
- selectImports(AnnotationMetadata) - Method in class org.springframework.kafka.annotation.KafkaListenerConfigurationSelector
- selfLog(String, LogAccessor) - Method in exception org.springframework.kafka.KafkaException
-
Log this exception at its log level.
- send(String, int) - Method in class org.springframework.kafka.jdocs.started.noboot.Sender
- send(String, int, long, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, int, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- send(String, Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the provided topic with the provided key and partition.
- send(String, Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- send(String, Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the provided topic with the provided key and partition.
- send(String, Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- send(String, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the provided topic with the provided key and no partition.
- send(String, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, Message<?>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- send(String, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the provided topic with no key or partition.
- send(String, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(ProducerRecord<Object, Object>, KafkaOperations<Object, Object>, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Send the record.
- send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- send(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- send(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the provided
ProducerRecord
. - send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(ProducerRecord<K, V>, Callback) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- send(Publisher<? extends SenderRecord<K, V, T>>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(Message<?>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- send(Message<?>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send a message with routing information in message headers.
- send(Message<?>) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(SenderRecord<K, V, T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- sendAndReceive(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request and receive a reply with the default timeout.
- sendAndReceive(ProducerRecord<K, V>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(ProducerRecord<K, V>, Duration) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request and receive a reply.
- sendAndReceive(ProducerRecord<K, V>, Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message with the default timeout.
- sendAndReceive(Message<?>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>, Duration) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message.
- sendAndReceive(Message<?>, Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>, Duration, ParameterizedTypeReference<P>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message.
- sendAndReceive(Message<?>, Duration, ParameterizedTypeReference<P>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>, ParameterizedTypeReference<P>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message.
- sendAndReceive(Message<?>, ParameterizedTypeReference<P>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendDefault(Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- sendDefault(Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the default topic with the provided key and partition.
- sendDefault(Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendDefault(Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- sendDefault(Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the default topic with the provided key and partition.
- sendDefault(Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendDefault(K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- sendDefault(K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the default topic with the provided key and no partition.
- sendDefault(K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendDefault(V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.
- sendDefault(V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Send the data to the default topic with no key or partition.
- sendDefault(V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sender(KafkaTemplate<Integer, String>) - Method in class org.springframework.kafka.jdocs.started.noboot.Config
- Sender - Class in org.springframework.kafka.jdocs.started.noboot
-
Code snippet for quick start.
- Sender(KafkaTemplate<Integer, String>) - Constructor for class org.springframework.kafka.jdocs.started.noboot.Sender
- sendFuture - Variable in class org.springframework.kafka.requestreply.RequestReplyMessageFuture
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.in the 3.0.0 KafkaProducer.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Deprecated.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
-
Deprecated.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Deprecated.in the 3.0.0 KafkaProducer.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Deprecated.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
-
Deprecated.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.springframework.kafka.core.KafkaOperations
-
When running in a transaction, send the consumer offset(s) to the transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
When running in a transaction, send the consumer offset(s) to the transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- sendResponse(Object, String, Object, boolean) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Send the result to the topic.
- SendResult<K,V> - Class in org.springframework.kafka.support
-
Result for a ListenableFuture after a send.
- SendResult(ProducerRecord<K, V>, RecordMetadata) - Constructor for class org.springframework.kafka.support.SendResult
- sendTransactionally(Publisher<? extends SenderRecord<K, V, T>>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- sendTransactionally(SenderRecord<K, V, T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- SerializationUtils - Class in org.springframework.kafka.support.serializer
-
Utilities for serialization.
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
- serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- serialize(String, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- serialize(String, T) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- serializedKeySize() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- serializedValueSize() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- serializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
- serializer() - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- setAckAfterHandle(boolean) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Set to false to prevent the container from committing the offset of a recovered record (when the error handler does not itself throw an exception).
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- setAckAfterHandle(boolean) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
-
Set to false to prevent the container from committing the offset of a recovered record (when the error handler does not itself throw an exception).
- setAckCount(int) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the number of outstanding record count after which offsets should be committed when
ContainerProperties.AckMode.COUNT
orContainerProperties.AckMode.COUNT_TIME
is being used. - setAckDiscarded(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set to true if the
AbstractKafkaListenerEndpoint.setRecordFilterStrategy(RecordFilterStrategy)
is in use. - setAckDiscarded(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to true to ack discards when a filter strategy is in use.
- setAckMode(ContainerProperties.AckMode) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the ack mode to use when auto ack (in the configuration properties) is false.
- setAckTime(long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the time (ms) after which outstanding offsets should be committed when
ContainerProperties.AckMode.TIME
orContainerProperties.AckMode.COUNT_TIME
is being used. - setAddTypeInfo(boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Set to false to disable adding type info headers.
- setAddTypeInfo(boolean) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Set to false to disable adding type info headers.
- setAdminTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the timeout in seconds for admin operations (e.g.
- setAdviceChain(Advice...) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a chain of listener
Advice
s; must not be null or have null elements. - setAfterRollbackProcessor(AfterRollbackProcessor<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a processor to invoke after a transaction rollback; typically will seek the unprocessed topic/partition to reprocess the records.
- setAfterRollbackProcessor(AfterRollbackProcessor<? super K, ? super V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set a processor to perform seeks on unprocessed records after a rollback.
- setAllowNonTransactional(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set to true to allow a non-transactional send when the template is transactional.
- setAlwaysClientIdSuffix(boolean) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
Set to false to suppress adding a suffix to the child container's client.id when the concurrency is only 1.
- setAlwaysStartAfterRefresh(boolean) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
By default, containers registered for endpoints after the context is refreshed are immediately started, regardless of their autoStartup property, to comply with the
SmartLifecycle
contract, where autoStartup is only considered during context initialization. - setAppendOriginalHeaders(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false if you don't want to append the current "original" headers (topic, partition etc.) if they are already present.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaAdmin
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaTemplate
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setAssignmentCommitOption(ContainerProperties.AssignmentCommitOption) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the assignment commit option.
- setAsyncAcks(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to support asynchronous record acknowledgments.
- setAuthExceptionRetryInterval(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the interval between retries after and
AuthenticationException
ororg.apache.kafka.common.errors.AuthorizationException
is thrown byKafkaConsumer
. - setAuthorizationExceptionRetryInterval(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Deprecated.
- setAutoCreate(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set to false to suppress auto creation of topics during context initialization.
- setAutoStartup(boolean) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set to false to not automatically start.
- setAutoStartup(boolean) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Set the autoStartup.
- setAutoStartup(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify an
autoStartup boolean
flag. - setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the autoStartup for this endpoint's container.
- setBackOff(BackOff) - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
-
Deprecated.Set a
BackOff
to suspend the thread after performing the seek. - setBackOffFunction(BiFunction<ConsumerRecord<?, ?>, Exception, BackOff>) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set a function to dynamically determine the
BackOff
to use, based on the consumer record and/or exception. - setBackOffHandler(BackOffHandler) - Method in class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManagerFactory
-
Set the back off handler to use in the created handlers.
- setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated.
- setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated.
- setBatchInterceptor(BatchInterceptor<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a batch interceptor to be called before and after calling the listener.
- setBatchInterceptor(BatchInterceptor<K, V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set an interceptor to be called before calling the record listener.
- setBatchListener(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set to true if this endpoint should create a batch listener.
- setBatchListener(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to true if this endpoint should create a batch listener.
- setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the message converter to use if dynamic argument type matching is needed for batch listeners.
- setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Set the BatchMessageConverter.
- setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a
BatchToRecordAdapter
. - setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a
BatchToRecordAdapter
. - setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Set a
BatchToRecordAdapter
. - setBean(Object) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the object instance that should manage this endpoint.
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Making a
BeanFactory
available is optional; if not set,KafkaListenerConfigurer
beans won't get autodetected and anendpoint registry
has to be explicitly configured. - setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
A
BeanFactory
only needs to be available in conjunction withKafkaListenerEndpointRegistrar.setContainerFactoryBeanName(java.lang.String)
. - setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- setBeanName(String) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setBeanName(String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- setBeanName(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- setBeanName(String) - Method in class org.springframework.kafka.core.KafkaTemplate
- setBeanName(String) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setBeanResolver(BeanResolver) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a bean resolver for runtime SpEL expressions.
- setBlockingRetriesBackOff(BackOff) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Set a
BackOff
to be used with blocking retries. - setBlockingRetryableExceptions(Class<? extends Exception>...) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Specify the exceptions to be retried via blocking.
- setBootstrapServersSupplier(Supplier<String>) - Method in class org.springframework.kafka.core.KafkaResourceFactory
-
Set a supplier for the bootstrap server list to override any configured in a subclass.
- setCaseSensitive(boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Set to false to make topic name matching case insensitive.
- setCauseChainTraversing(boolean) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
-
Set the flag enabling deep exception's cause chain traversing.
- setCharset(Charset) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set a charset to use when converting byte[] to String in method arguments and other String/byte[] conversions.
- setCharset(Charset) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Set the charset to use when mapping String-valued headers to/from byte[].
- setCharset(Charset) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Set a charset to use when converting byte[] to
String
. - setCharset(Charset) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Set a charset to use when converting
String
to byte[]. - setCheckDeserExWhenKeyNull(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set to true to always check for
DeserializationException
header when a null key is received. - setCheckDeserExWhenValueNull(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set to true to always check for
DeserializationException
header when a null value is received. - setClassIdFieldName(String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure header name for type information.
- setClassifications(Map<Class<? extends Throwable>, Boolean>, boolean) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Set an exception classifications to determine whether the exception should cause a retry (until exhaustion) or not.
- setClassifications(Map<Class<? extends Throwable>, Boolean>, boolean) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- setCleanupConfig(CleanupConfig) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setClientId(String) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the client id; overrides the consumer factory client.id property.
- setClientIdPrefix(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the client id prefix; overrides the client id in the consumer configuration properties.
- setClientIdSuffix(String) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Set a suffix to add to the
client.id
consumer property (if the consumer factory supports it). - setClientSupplier(KafkaClientSupplier) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setCloseTimeout(int) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Specify the timeout in seconds for the
KafkaStreams.close(Duration)
operation. - setCloseTimeout(int) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set the close timeout in seconds.
- setCloseTimeout(Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the maximum time to wait when closing a producer; default 5 seconds.
- setCloseTimeout(Duration) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
-
Set the maximum time to wait when closing a producer; default 5 seconds.
- setCommitCallback(OffsetCommitCallback) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
- setCommitLogLevel(LogIfLevelEnabled.Level) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the level at which to log offset commits.
- setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
-
Set to true to commit the offset for a recovered record.
- setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set to true to commit the offset for a recovered record.
- setCommitRetries(int) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set number of retries allowed when a
RetriableCommitFailedException
is thrown by the consumer when usingConsumerProperties.setSyncCommits(boolean)
set to true. - setCommitTimeout(Duration) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Set the timeout to use when committing offsets.
- setCommonErrorHandler(CommonErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the
CommonErrorHandler
which can handle errors for both record and batch listeners. - setCommonErrorHandler(CommonErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set the
CommonErrorHandler
which can handle errors for both record and batch listeners. - setConcurrency(int) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
The maximum number of concurrent
KafkaMessageListenerContainer
s running. - setConcurrency(Integer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the concurrency for this endpoint's container.
- setConcurrency(Integer) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
-
Specify the container concurrency.
- setConfigureDeserializers(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set to false (default true) to prevent programmatically provided deserializers (via constructor or setters) from being configured using the producer configuration, e.g.
- setConfigureSerializers(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set to false (default true) to prevent programmatically provided serializers (via constructor or setters) from being configured using the producer configuration, e.g.
- setConsumerFactory(ConsumerFactory<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify a
ConsumerFactory
to use. - setConsumerFactory(ConsumerFactory<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a consumer factory for receive operations.
- setConsumerGroupId(String) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set the group id for the consumer bound to this thread.
- setConsumerProperties(Properties) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- setConsumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the user defined
ConsumerRebalanceListener
implementation. - setConsumerRecordFormatter(Function<ConsumerRecord<?, ?>, String>) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set a formatter for logging
ConsumerRecord
s; default istopic-partition@offset
. - setConsumerStartTimeout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the timeout to wait for a consumer thread to start before logging an error.
- setConsumerStartTimout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Deprecated.
- setConsumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Deprecated.
- setContainerCustomizer(Consumer<ConcurrentMessageListenerContainer<?, ?>>) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- setContainerCustomizer(ContainerCustomizer<K, V, C>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a customizer used to further configure a container after it has been created.
- setContainerFactory(KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the
KafkaListenerContainerFactory
to use in case aKafkaListenerEndpoint
is registered with anull
container factory. - setContainerFactoryBeanName(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the bean name of the
KafkaListenerContainerFactory
to use in case aKafkaListenerEndpoint
is registered with anull
container factory. - setContentClassIdFieldName(String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure header name for container object contents type information.
- setControlFlag(KafkaJaasLoginModuleInitializer.ControlFlag) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- setCorrelationHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a custom header name for the correlation id.
- setCorrelationIdStrategy(Function<ProducerRecord<K, V>, CorrelationKey>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a function to be called to establish a unique correlation key for each request record.
- setCreateOrModifyTopic(Predicate<NewTopic>) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set a predicate that returns true if a discovered
NewTopic
bean should be considered for creation or modification by this admin instance. - setCustomMethodArgumentResolvers(HandlerMethodArgumentResolver...) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Add custom methods arguments resolvers to
KafkaListenerAnnotationBeanPostProcessor
Default empty list. - setDeadLetterPublishingRecovererCustomizer(Consumer<DeadLetterPublishingRecoverer>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- setDefaultContainerFactoryBeanName(String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set the name of the
KafkaListenerContainerFactory
to use by default. - setDefaultReplyTimeout(Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set the reply timeout used if no replyTimeout is provided in the
ReplyingKafkaTemplate.sendAndReceive(ProducerRecord, Duration)
call. - setDefaultTopic(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the default topic for send methods where a topic is not provided.
- setDelegates(ProducerListener<K, V>...) - Method in class org.springframework.kafka.support.CompositeProducerListener
- setDeliveryAttemptHeader(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to populate the
KafkaHeaders.DELIVERY_ATTEMPT
header when the error handler or after rollback processor implementsDeliveryAttemptAware
. - setEmergencyStop(Runnable) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Set a
Runnable
to call whenever a fatal error occurs on the listener thread. - setEncodeStrings(boolean) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Set to true to encode String-valued headers as JSON ("..."), by default just the raw String value is converted to a byte array using the configured charset.
- setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set the
KafkaListenerEndpointRegistry
that will hold the created endpoint and manage the lifecycle of the related listener container. - setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the
KafkaListenerEndpointRegistry
instance to use. - setEosMode(ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the exactly once semantics mode.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated.
- setErrorHandler(KafkaListenerErrorHandler) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the
KafkaListenerErrorHandler
to invoke if the listener method throws an exception. - setErrorHandlerCustomizer(Consumer<DefaultErrorHandler>) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- setErrorHandlers(Map<Class<? extends Throwable>, CommonErrorHandler>) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
-
Set the delegate error handlers; a
LinkedHashMap
argument is recommended so that the delegates are searched in a known order. - setExceptionHeadersCreator(DeadLetterPublishingRecoverer.ExceptionHeadersCreator) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set a
DeadLetterPublishingRecoverer.ExceptionHeadersCreator
implementation to completely take over setting the exception headers in the output record. - setFailedDeserializationFunction(Function<FailedDeserializationInfo, T>) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Provide an alternative supplying mechanism when deserialization fails.
- setFailIfSendResultIsError(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to true to enable waiting for the send result and throw an exception if it fails.
- setFallbackType(Class<?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a fallback type to use when using a type-aware message converter and this adapter cannot determine the inferred type from the method.
- setFatalIfBrokerNotAvailable(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set to true if you want the application context to fail to load if we are unable to connect to the broker during initialization, to check/add topics.
- setFixTxOffsets(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
When consuming records produced by a transactional producer, and the consumer is positioned at the end of a partition, the lag can incorrectly be reported as greater than zero, due to the pseudo record used to indicate transaction commit/rollback and, possibly, the presence of rolled-back records.
- setForKey(boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Set to true if this deserializer is to be used as a key deserializer when configuring outside of Kafka.
- setGenerateMessageId(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Generate
Message
ids
for produced messages. - setGenerateMessageId(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Generate
Message
ids
for produced messages. - setGenerateTimestamp(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Generate
timestamp
for produced messages. - setGenerateTimestamp(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Generate
timestamp
for produced messages. - setGenericErrorHandler(GenericErrorHandler<?>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated.
- setGroup(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the group for the corresponding listener container.
- setGroupId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the group id to override the
group.id
property in the ContainerFactory. - setGroupId(String) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the group id for this container.
- setHandlerMethod(HandlerAdapter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the
HandlerAdapter
to use to invoke the method processing an incomingConsumerRecord
. - setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Set the header mapper to map headers.
- setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Set the header mapper to map headers.
- setHeaders(Headers) - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
Set the headers.
- setHeadersFunction(BiFunction<ConsumerRecord<?, ?>, Exception, Headers>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set a function which will be called to obtain additional headers to add to the published record.
- setHeadersFunction(BiFunction<ConsumerRecord<?, ?>, Exception, Headers>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set a function that creates additional headers for the output record, in addition to the standard retry headers added by this factory.
- setHeaderValue(byte[]) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- setId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- setIdleBeforeDataMultiplier(double) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Multiply the
ContainerProperties.setIdleEventInterval(Long)
by this value until at least one record is received. - setIdleBetweenPolls(long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
The sleep interval in milliseconds used in the main loop between
Consumer.poll(Duration)
calls. - setIdleEventInterval(Long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
- setIdlePartitionEventInterval(Long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the idle partition event interval; when set, an event is emitted if a poll returns no records for a partition and this interval has elapsed since a record was returned.
- setIncludeContents(boolean) - Method in class org.springframework.kafka.support.LoggingProducerListener
-
Whether the log message should include the contents (key and payload).
- setInfrastructureCustomizer(KafkaStreamsInfrastructureCustomizer) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Set a customizer to configure the builder and/or topology before creating the stream.
- setInitialInterval(long) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setInterceptBeforeTx(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
When false, invoke the interceptor after the transaction starts.
- setKafkaConsumerProperties(Properties) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- setKafkaStreamsCustomizer(KafkaStreamsCustomizer) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Specify a
KafkaStreamsCustomizer
to customize aKafkaStreams
instance duringStreamsBuilderFactoryBean.start()
. - setKeyClassIdFieldName(String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure header name for map key type information.
- setKeyDeserializer(Deserializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set the key deserializer.
- setKeyDeserializerSupplier(Supplier<Deserializer<K>>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set a supplier to supply instances of the key deserializer.
- setKeySerializer(Serializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a key serializer.
- setKeySerializerSupplier(Supplier<Serializer<K>>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a supplier to supply instances of the key serializer.
- setListenerContainerRegistry(ListenerContainerRegistry) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
-
Sets the
ListenerContainerRegistry
, that will be used to fetch theMessageListenerContainer
to back off. - setListenerInfo(byte[]) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the listener info to insert in the record header.
- setListenerInfo(byte[]) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set arbitrary information that will be added to the
KafkaHeaders.LISTENER_INFO
header of all records. - setListenerTaskExecutor(AsyncTaskExecutor) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the executor for threads that poll the consumer.
- setLogContainerConfig(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to instruct each container to log this configuration.
- setLoginModule(String) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- setLogLevel(KafkaException.Level) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- setLogLevel(KafkaException.Level) - Method in class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
-
Set the level at which the exception thrown by this handler is logged.
- setLogOnlyMetadata(boolean) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Deprecated.in favor of
KafkaUtils.format(ConsumerRecord)
. - setMapAllStringsOut(boolean) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Set to true to map all
String
valued outbound headers tobyte[]
. - setMaxAge(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set the maximum age for a producer; useful when using transactions and the broker might expire a
transactional.id
due to inactivity. - setMaxContentLogged(int) - Method in class org.springframework.kafka.support.LoggingProducerListener
-
The maximum amount of data to be logged for either key or password.
- setMaxElapsedTime(long) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setMaxInterval(long) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setMessageConverter(MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- setMessageConverter(RecordMessageConverter) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the message converter to use.
- setMessageConverter(RecordMessageConverter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the MessageConverter.
- setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set the
MessageHandlerMethodFactory
to use to configure the message listener responsible to serve an endpoint detected by this processor. - setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the
MessageHandlerMethodFactory
to use to configure the message listener responsible to serve an endpoint detected by this processor. - setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the
MessageHandlerMethodFactory
to use to build theInvocableHandlerMethod
responsible to manage the invocation of this endpoint. - setMessageListener(Object) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the message listener; must be a
MessageListener
orAcknowledgingMessageListener
. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set a spring-messaging
SmartMessageConverter
to convert the record value to the desired type. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the
SmartMessageConverter
to use with the defaultMessagingMessageConverter
. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the
SmartMessageConverter
to use with the defaultMessagingMessageConverter
. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Set a spring-messaging
SmartMessageConverter
to convert the record value to the desired type. - setMethod(Method) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the method to invoke to process a message managed by this endpoint.
- setMicrometerEnabled(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set to false to disable micrometer timers, if micrometer is on the class path.
- setMicrometerEnabled(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to false to disable the Micrometer listener timers.
- setMicrometerTags(Map<String, String>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set additional tags for the Micrometer listener timers.
- setMicrometerTags(Map<String, String>) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set additional tags for the Micrometer listener timers.
- setMicrometerTagsProvider(Function<ConsumerRecord<?, ?>, Map<String, String>>) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a function to provide dynamic tags based on the consumer record.
- setMicrometerTagsProvider(Function<ProducerRecord<?, ?>, Map<String, String>>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a function to provide dynamic tags based on the producer record.
- setMissingTopicsFatal(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to false to allow the container to start even if any of the configured topics are not present on the broker.
- setMissingTopicsFatal(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to prevent the container from starting if any of the configured topics are not present on the broker.
- setModifyTopicConfigs(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set to true to compare the current topic configuration properties with those in the
NewTopic
bean, and update if different. - setMonitorInterval(int) - Method in class org.springframework.kafka.listener.ContainerProperties
-
The interval between checks for a non-responsive consumer in seconds; default 30.
- setMultiplier(double) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setNoPollThreshold(float) - Method in class org.springframework.kafka.listener.ContainerProperties
-
If the time since the last poll /
poll timeout
exceeds this value, a NonResponsiveConsumerEvent is published. - setOffset(Long) - Method in class org.springframework.kafka.support.TopicPartitionOffset
-
Set the offset.
- setOffsetAndMetadataProvider(OffsetAndMetadataProvider) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the offset and metadata provider associated to a commit callback.
- setOnlyLogRecordMetadata(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Deprecated.
- setOperationTimeout(int) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set the operation timeout in seconds.
- setOptions(Map<String, String>) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- setPartitionInfoTimeout(Duration) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Time to wait for partition information when verifying.
- setPartitionResolver(BiFunction<ConsumerRecord<?, ?>, String, Integer>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set a resolver for the partition number to publish to.
- setPauseImmediate(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to pause the container after the current record has been processed, rather than after all the records from the previous poll have been processed.
- setPhase(int) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify a
phase
to use. - setPhase(int) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setPhase(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setPhase(int) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set the
SmartLifecycle.getPhase()
. - setPhase(int) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- setPhysicalCloseTimeout(int) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
The time to wait when physically closing the producer via the factory rather than closing the producer itself (when
DefaultKafkaProducerFactory.reset()
,#closeProducerFor(String)
, orDefaultKafkaProducerFactory.closeThreadBoundProducer()
are invoked). - setPollTimeout(long) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the max time to block in the consumer waiting for records.
- setPollTimeoutWhilePaused(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the poll timeout to use while paused; usually a lower number than
pollTimeout
. - setProducerListener(ProducerListener<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a
ProducerListener
which will be invoked when Kafka acknowledges a send operation. - setProducerPerConsumerPartition(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set to false to revert to the previous behavior of a simple incrementing transactional.id suffix for each producer instead of maintaining a producer for each group/topic/partition.
- setProducerPerThread(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set to true to create a producer per thread instead of singleton that is shared by all clients.
- setProducerRecordFormatter(Function<ProducerRecord<?, ?>, String>) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set a formatter for logging
ProducerRecord
s; default isProducerRecord.toString()
. - setRawMappedHeaders(Map<String, Boolean>) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Set the headers to not perform any conversion on (except
String
tobyte[]
for outbound). - setRawRecordHeader(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Set to true to add the raw
List<ConsumerRecord<?, ?>>
as a headerKafkaHeaders.RAW_DATA
. - setRawRecordHeader(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Set to true to add the raw
ConsumerRecord
as a headerKafkaHeaders.RAW_DATA
. - setReclassifyOnExceptionChange(boolean) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
-
Set to false to not reclassify the exception if different from the previous failure.
- setRecordFilterStrategy(RecordFilterStrategy<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the record filter strategy.
- setRecordFilterStrategy(RecordFilterStrategy<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a
RecordFilterStrategy
implementation. - setRecordInterceptor(RecordInterceptor<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set an interceptor to be called before calling the listener.
- setRecordInterceptor(RecordInterceptor<K, V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set an interceptor to be called before calling the record listener.
- setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the message converter to use if dynamic argument type matching is needed for record listeners.
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- setRelativeToCurrent(boolean) - Method in class org.springframework.kafka.support.TopicPartitionOffset
-
Set whether the offset is relative to the current position.
- setRemoveTypeHeaders(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set to false to retain type information headers after deserialization.
- setReplaceOriginalHeaders(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Deprecated.
- setReplyErrorChecker(Function<ConsumerRecord<?, ?>, Exception>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a function to examine replies for an error returned by the server.
- setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a configurer which will be invoked when creating a reply message.
- setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a configurer which will be invoked when creating a reply message.
- setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a configurer which will be invoked when creating a reply message.
- setReplyPartitionHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a custom header name for the reply partition.
- setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the
KafkaTemplate
to use to send replies. - setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the
KafkaTemplate
to use to send replies. - setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the template to use to send any result from the method invocation.
- setReplyTopic(String) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the topic to which to send any result from the method invocation.
- setReplyTopicHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a custom header name for the reply topic.
- setResetStateOnExceptionChange(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set to true to reset the retry
BackOff
if the exception is a different type to the previous failure for the same record. - setResetStateOnRecoveryFailure(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set to false to immediately attempt to recover on the next attempt instead of repeating the BackOff cycle when recovery fails.
- setRestartAfterAuthExceptions(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to automatically restart the container if an auth exception is detected by the container (or all child containers).
- setRetainAllRetryHeaderValues(boolean) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set to false to only retain the last value for
RetryTopicHeaders
; true by default, which retains all the values as the record transitions through topics. - setRetainExceptionHeader(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to true to retain a Java serialized
DeserializationException
header. - setRetryListeners(List<RetryListener>) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
-
Set the retry listeners.
- setRetryListeners(RetryListener...) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set one or more
RetryListener
to receive notifications of retries and recovery. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- setReturnPartialOnTimeout(boolean) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Set to true to return a partial result when a request times out.
- setRunning(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setScheduler(TaskScheduler) - Method in class org.springframework.kafka.listener.ContainerProperties
-
A scheduler used with the monitor interval.
- setSeekAfterError(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
When true (default), the error handler will perform seeks on the failed and/or remaining records to they will be redelivered on the next poll.
- setSendFuture(ListenableFuture<SendResult<K, V>>) - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
- setSharedReplyTopic(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set to true when multiple templates are using the same topic for replies.
- setShutdownTimeout(long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the timeout for shutting down the container.
- setSkipSameTopicFatalExceptions(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false if you want to forward the record to the same topic even though the exception is fatal by this class' classification, e.g.
- setSplitIterables(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set to false to disable splitting
Iterable
reply values into separate records. - setSplitIterables(boolean) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set to false to disable splitting
Iterable
reply values into separate records. - setStatefulRetry(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- setStatefulRetry(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Deprecated.since 2.8 - use a suitably configured error handler instead.
- setStateListener(KafkaStreams.StateListener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setStateRestoreListener(StateRestoreListener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setStopContainerAbnormally(boolean) - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
-
Set to false to stop the container normally.
- setStopContainerWhenFenced(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to stop the container when a
ProducerFencedException
is thrown. - setStopImmediate(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to stop the container after processing the current record (when stop() is called).
- setStopLastGroupWhenIdle(boolean) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set to true to stop the containers in the final group when they go idle.
- setStoppedNormally(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setStreamsConfiguration(Properties) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Set the streams configuration
Properties
on this factory. - setStreamsUncaughtExceptionHandler(StreamsUncaughtExceptionHandler) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Set a
StreamsUncaughtExceptionHandler
. - setStripPreviousExceptionHeaders(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false to retain previous exception headers as well as headers for the current exception.
- setSubBatchPerPartition(Boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
When using a batch message listener whether to dispatch records by partition (with a transaction for each sub batch if transactions are in use) or the complete batch received by the
poll()
. - setSyncCommits(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
- setSyncCommitTimeout(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the timeout for commitSync operations (if
ConsumerProperties.isSyncCommits()
. - setSyncCommitTimeout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the timeout for commitSync operations (if
ConsumerProperties.isSyncCommits()
. - setTaskScheduler(TaskScheduler) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- setThingProp(String) - Method in class org.springframework.kafka.jdocs.requestreply.Application.Thing
- setThrowIfNoDestinationReturned(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to true to throw an exception if the destination resolver function returns a null TopicPartition.
- setTimeoutBuffer(long) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set the number of milliseconds to add to the producer configuration
delivery.timeout.ms
property to avoid timing out before the Kafka producer. - setTopicCheckTimeout(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
How long to wait for
Admin.describeTopics(Collection)
result futures to complete. - setTopicPartitions(TopicPartitionOffset...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the topicPartitions to use.
- setTopicPattern(Pattern) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the topic pattern to use.
- setTopics(String...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the topics to use.
- setTopicSuffixingStrategy(TopicSuffixingStrategy) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- setTransactionDefinition(TransactionDefinition) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a transaction definition with properties (e.g.
- setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a prefix for the
ProducerConfig.TRANSACTIONAL_ID_CONFIG
config. - setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a transaction id prefix to override the prefix in the producer factory.
- setTransactionIdPrefix(String) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
-
Set a transaction id prefix to override the prefix in the producer factory.
- setTransactionIdSuffix(String) - Static method in class org.springframework.kafka.support.TransactionSupport
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the transaction manager to start a transaction; if it is a
KafkaAwareTransactionManager
, offsets are committed with semantics equivalent toContainerProperties.AckMode.RECORD
andContainerProperties.AckMode.BATCH
depending on the listener type (record or batch). - setTypeFunction(BiFunction<byte[], Headers, JavaType>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
BiFunction
that receives the data to be deserialized and the headers and returns a JavaType. - setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
-
Set a customized type mapper.
- setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
-
Set a customized type mapper.
- setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a customized type mapper.
- setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Set a customized type mapper.
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
-
Set the precedence for evaluating type information in message properties.
- setTypeResolver(JsonTypeResolver) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
JsonTypeResolver
that receives the data to be deserialized and the headers and returns a JavaType. - setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Deprecated.
- setUntrustedType(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- setupBackoffAwareMessageListenerAdapter(ConcurrentMessageListenerContainer<?, ?>, ListenerContainerFactoryConfigurer.Configuration, boolean) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- setupDelegate(Map<String, ?>, String) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- setupListenerContainer(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setupListenerContainer(MessageListenerContainer, MessageConverter) - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Setup the specified message listener container with the model defined by this endpoint.
- setupMessageListener(Object) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setupMessageListener(Object) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Setup the message listener to use.
- setupThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- setupThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- setupThreadState(Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ThreadStateProcessor
-
Call to set up thread-bound resources which will be available for the entire duration of enclosed operation involving a
Consumer
. - setUseForKey(boolean) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure the TypeMapper to use default key type class.
- setUseTypeHeaders(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set to false to ignore type information in headers and use the configured target type instead.
- setUseTypeMapperForKey(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Configure the default Jackson2JavaTypeMapper to use key type headers.
- setUseTypeMapperForKey(boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Configure the default Jackson2JavaTypeMapper to use key type headers.
- setValidator(Validator) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the validator to use if the default message handler factory is used.
- setValidator(Validator) - Method in class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
-
Set a payload validator.
- setValueDeserializer(Deserializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set the value deserializer.
- setValueDeserializerSupplier(Supplier<Deserializer<V>>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set a supplier to supply instances of the value deserializer.
- setValueSerializer(Serializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a value serializer.
- setValueSerializerSupplier(Supplier<Serializer<V>>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a supplier to supply instances of the value serializer.
- setVerifyPartition(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false to disable partition verification.
- setWaitForSendResultTimeout(Duration) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set the minimum time to wait for message sending.
- setZkPort(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the port to run the embedded Zookeeper on (default random).
- shouldCopy(String, Object) - Method in interface org.springframework.kafka.listener.adapter.ReplyHeadersConfigurer
-
Return true if the header should be copied to the reply message.
- shouldRetryOn(Integer, Throwable) - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- shutdown() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- SIMPLE - org.springframework.kafka.listener.ListenerType
-
Simple.
- SimpleKafkaHeaderMapper - Class in org.springframework.kafka.support
-
A simple header mapper that maps headers directly; for outbound, only byte[] headers are mapped; for inbound, headers are mapped unchanged, as byte[].
- SimpleKafkaHeaderMapper() - Constructor for class org.springframework.kafka.support.SimpleKafkaHeaderMapper
-
Construct an instance with the default object mapper and default header patterns for outbound headers; all inbound headers are mapped.
- SimpleKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.SimpleKafkaHeaderMapper
-
Construct an instance with a default object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
- SimplePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
- SINGLE_TOPIC - org.springframework.kafka.retrytopic.FixedDelayStrategy
-
Uses a single topic to achieve non-blocking retry.
- SingleRecordHeader(String, byte[]) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.SingleRecordHeader
-
Construct an instance.
- SingleRecordHeader(ByteBuffer, ByteBuffer) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.SingleRecordHeader
-
Construct an instance.
- splitIterables() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
When false and the return type is an
Iterable
return the result as the value of a single reply record instead of individual records for each element. - SPRING_EMBEDDED_KAFKA_BROKERS - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- SPRING_EMBEDDED_ZOOKEEPER_CONNECT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- start() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- start() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- start() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- start() - Method in class org.springframework.kafka.listener.ContainerGroup
- start() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- start() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- start() - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Start the timer.
- stop() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- stop() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- stop() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- stop() - Method in class org.springframework.kafka.listener.ContainerGroup
- stop() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- stop() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- stop(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Stop the container.
- stop(Runnable) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- stop(Runnable) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- stop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- stop(Runnable) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- stopAbnormally(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- stopAbnormally(Runnable) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Stop the container after some exception so that
MessageListenerContainer.isInExpectedState()
will return false. - stoppableSleep(MessageListenerContainer, long) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Sleep for the desired timeout, as long as the container continues to run.
- streamsAdded(String, KafkaStreams) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
-
A new
KafkaStreams
was created. - streamsAdded(String, KafkaStreams) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- StreamsBuilderFactoryBean - Class in org.springframework.kafka.config
-
An
AbstractFactoryBean
for theStreamsBuilder
instance and lifecycle control for the internalKafkaStreams
instance. - StreamsBuilderFactoryBean() - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Default constructor that creates the factory without configuration
Properties
. - StreamsBuilderFactoryBean(KafkaStreamsConfiguration) - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration.
- StreamsBuilderFactoryBean(KafkaStreamsConfiguration, CleanupConfig) - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration and clean up configuration.
- StreamsBuilderFactoryBean.Listener - Interface in org.springframework.kafka.config
-
Called whenever a
KafkaStreams
is added or removed. - StreamsBuilderFactoryBeanConfigurer - Interface in org.springframework.kafka.config
-
A configurer for
StreamsBuilderFactoryBean
. - StreamsBuilderFactoryBeanCustomizer - Interface in org.springframework.kafka.config
-
Deprecated.in favor of
StreamsBuilderFactoryBeanConfigurer
due to a name clash with a similar class in Spring Boot. - streamsRemoved(String, KafkaStreams) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
-
An existing
KafkaStreams
was removed. - streamsRemoved(String, KafkaStreams) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- StringJsonMessageConverter - Class in org.springframework.kafka.support.converter
-
JSON Message converter - String on output, String, Bytes, or byte[] on input.
- StringJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.StringJsonMessageConverter
- StringJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.StringJsonMessageConverter
- StringOrBytesSerializer - Class in org.springframework.kafka.support.serializer
-
A serializer that can handle
byte[]
,Bytes
andString
. - StringOrBytesSerializer() - Constructor for class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- subscription() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- success(Object) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Record success.
- success(Object, Object) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Record success.
- success(ConsumerRecord<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- success(ConsumerRecord<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
-
Called after the listener exits normally.
- success(ConsumerRecords<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
-
Called after the listener exits normally.
- success(ConsumerRecords<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- SUFFICIENT - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
-
Sufficient - The
LoginModule
is not required to succeed. - suffix() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- SUFFIX_WITH_DELAY_VALUE - org.springframework.kafka.retrytopic.TopicSuffixingStrategy
-
Suffixes the topics the delay value for the topic.
- SUFFIX_WITH_INDEX_VALUE - org.springframework.kafka.retrytopic.TopicSuffixingStrategy
-
Suffixes the topics with their index in the retry topics.
- Suffixer - Class in org.springframework.kafka.support
-
Utility class that suffixes strings.
- Suffixer(String) - Constructor for class org.springframework.kafka.support.Suffixer
- SuffixingRetryTopicNamesProvider(DestinationTopic.Properties) - Constructor for class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- SuffixingRetryTopicNamesProviderFactory - Class in org.springframework.kafka.retrytopic
-
Retry and dead letter naming handling that add a suffix to each name.
- SuffixingRetryTopicNamesProviderFactory() - Constructor for class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory
- SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider - Class in org.springframework.kafka.retrytopic
- suffixTopicsWithIndexValues() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- supportsParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
T
- targetType - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- Thing() - Constructor for class org.springframework.kafka.jdocs.requestreply.Application.Thing
- ThreadStateProcessor - Interface in org.springframework.kafka.listener
-
A general interface for managing thread-bound resources when a
Consumer
is available. - TIME - org.springframework.kafka.listener.ContainerProperties.AckMode
-
Commit pending offsets after
ackTime
has elapsed. - timeout() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
The amount of time in milliseconds after which message retrying should give up and send the message to the DLT.
- timeoutAfter(long) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- timestamp() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- timestamp(long) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- timestamp(TimestampType, long) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- TIMESTAMP - org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
-
Seek to the time stamp; if no records exist with a timestamp greater than or equal to the timestamp seek to the end.
- TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for holding the timestamp of the producer record.
- TIMESTAMP_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for holding the
type
of timestamp. - TimestampedException - Exception in org.springframework.kafka.listener
-
A
KafkaException
that records the timestamp of when it was thrown. - TimestampedException(Exception) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Constructs an instance with the provided cause and the current time.
- TimestampedException(Exception, long) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Creates an instance with the timestamp of when it was thrown and its cause.
- TimestampedException(Exception, Clock) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Deprecated.
- TimestampedException(Exception, Instant) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Creates an instance with the Instant of when it was thrown and its cause.
- timestampHeader(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 timestamp of the original record.
- timestampType() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- timestampTypeHeader(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 timestampType of the original record.
- toClass(Headers) - Method in interface org.springframework.kafka.support.mapping.ClassMapper
- toClass(Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- ToFromStringSerde<T> - Class in org.springframework.kafka.support.serializer
-
A Serde that delegates to a
ToStringSerializer
andParseStringDeserializer
. - ToFromStringSerde(ToStringSerializer<T>, ParseStringDeserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.ToFromStringSerde
-
Construct an instance with the provided properties.
- toHeaders(Headers, Map<String, Object>) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
- toHeaders(Headers, Map<String, Object>) - Method in interface org.springframework.kafka.support.KafkaHeaderMapper
-
Map from the given target headers to abstracted
MessageHeaders
. - toHeaders(Headers, Map<String, Object>) - Method in class org.springframework.kafka.support.SimpleKafkaHeaderMapper
- toJavaType(Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- toJavaType(Headers) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- toMessage(List<ConsumerRecord<?, ?>>, Acknowledgment, Consumer<?, ?>, Type) - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
-
Convert a list of
ConsumerRecord
to aMessage
. - toMessage(List<ConsumerRecord<?, ?>>, Acknowledgment, Consumer<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- toMessage(ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
- toMessage(ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Type) - Method in interface org.springframework.kafka.support.converter.RecordMessageConverter
-
Convert a
ConsumerRecord
to aMessage
. - toMessagingMessage(List, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
- toMessagingMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- topic() - Method in annotation type org.springframework.kafka.annotation.TopicPartition
-
The topic to listen on.
- topic() - Method in class org.springframework.kafka.jdocs.started.consumer.Application
- topic() - Method in class org.springframework.kafka.jdocs.started.producer.Application
- topic() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- TOPIC - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The original topic of the failed record.
- TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the topic when sending data to Kafka.
- topic1() - Method in class org.springframework.kafka.jdocs.topics.Config
- topic2() - Method in class org.springframework.kafka.jdocs.topics.Config
- topic3() - Method in class org.springframework.kafka.jdocs.topics.Config
- topic4() - Method in class org.springframework.kafka.jdocs.topics.Config
- topic5() - Method in class org.springframework.kafka.jdocs.topics.Config
- topic6() - Method in class org.springframework.kafka.jdocs.topics.Config
- TopicBuilder - Class in org.springframework.kafka.config
-
Builder for a
NewTopic
. - TopicForRetryable - Class in org.springframework.kafka.support
-
Marker to indicate this
NewTopic
is for retryable topics; admin will ignore these if a regularNewTopic
exist. - TopicForRetryable(String, int, short) - Constructor for class org.springframework.kafka.support.TopicForRetryable
-
Create an instance with the provided properties.
- topicHeader(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 topic of the original record.
- TopicPartition - Annotation Type in org.springframework.kafka.annotation
-
Used to add topic/partition information to a
KafkaListener
. - TopicPartitionOffset - Class in org.springframework.kafka.support
-
A configuration container to represent a topic name, partition number and, optionally, an offset for it.
- TopicPartitionOffset(String, int) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with no initial offset management.
- TopicPartitionOffset(String, int, Long) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided initial offset with
TopicPartitionOffset.isRelativeToCurrent()
false. - TopicPartitionOffset(String, int, Long, boolean) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided initial offset.
- TopicPartitionOffset(String, int, Long, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided
TopicPartitionOffset.SeekPosition
. - TopicPartitionOffset(String, int, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided
TopicPartitionOffset.SeekPosition
. - TopicPartitionOffset(TopicPartition, Long, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided
TopicPartitionOffset.SeekPosition
. - TopicPartitionOffset.SeekPosition - Enum in org.springframework.kafka.support
-
Enumeration for "special" seeks.
- topicPartitions() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
The topicPartitions for this listener when using manual topic/partition assignment.
- topicPattern() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
The topic pattern for this listener.
- topics() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
-
The topics for this listener.
- topics() - Method in class org.springframework.kafka.jdocs.dynamic.Application
- topics() - Method in class org.springframework.kafka.jdocs.requestreply.Application
- topics() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Topics that should be created Topics may contain property place holders, e.g.
- topics456() - Method in class org.springframework.kafka.jdocs.topics.Config
- topicSuffixingStrategy() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Whether the retry topics will be suffixed with the delay value for that topic or a simple index.
- TopicSuffixingStrategy - Enum in org.springframework.kafka.retrytopic
-
Constants for the RetryTopic functionality.
- toString() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- toString() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- toString() - Method in class org.springframework.kafka.event.ConsumerFailedToStartEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerPartitionPausedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerPartitionResumedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerPausedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerResumedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStartedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStartingEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStoppedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
- toString() - Method in class org.springframework.kafka.event.ContainerStoppedEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
- toString() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
- toString() - Method in class org.springframework.kafka.jdocs.requestreply.Application.Thing
- toString() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- toString() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- toString() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- toString() - Method in class org.springframework.kafka.listener.ConsumerProperties
- toString() - Method in class org.springframework.kafka.listener.ContainerGroup
- toString() - Method in class org.springframework.kafka.listener.ContainerProperties
- toString() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- toString() - Method in class org.springframework.kafka.requestreply.CorrelationKey
- toString() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- toString() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- toString() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- toString() - Method in class org.springframework.kafka.support.SendResult
- toString() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- toString() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- toString() - Method in class org.springframework.kafka.test.core.BrokerAddress
- ToStringSerializer<T> - Class in org.springframework.kafka.support.serializer
-
Generic
Serializer
that relies onObject.toString()
to get serialized representation of the entity. - ToStringSerializer() - Constructor for class org.springframework.kafka.support.serializer.ToStringSerializer
- TRACE - org.springframework.kafka.KafkaException.Level
-
Trace.
- TRACE - org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Trace.
- transactionCapable() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- transactionCapable() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return true if the factory supports transactions.
- transactionManager() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- TransactionSupport - Class in org.springframework.kafka.support
-
Utilities for supporting transactions.
- transform(K, V) - Method in class org.springframework.kafka.streams.HeaderEnricher
- transform(K, V) - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
- traversingCauses() - Method in annotation type org.springframework.kafka.annotation.RetryableTopic
-
Whether or not the captured exception should be traversed to look for the exceptions provided above.
- traversingCauses() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- traversingCauses(boolean) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- trusted(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
- TRUSTED_PACKAGES - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property for trusted deserialization packages.
- trustedPackages(String...) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Add trusted packages to the default type mapper.
- TS - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The timestamp of the failed record.
- TS_TYPE - org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The timestamp type of the failed record.
- TYPE_ID - org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
-
The type is obtained from headers.
- TYPE_MAPPINGS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property to add type mappings to the type mapper: 'foo=com.Foo,bar=com.Bar'.
- TYPE_MAPPINGS - Static variable in class org.springframework.kafka.support.serializer.JsonSerializer
-
Kafka config property to add type mappings to the type mapper: 'foo:com.Foo,bar:com.Bar'.
- typeFunction(BiFunction<byte[], Headers, JavaType>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
BiFunction
that receives the data to be deserialized and the headers and returns a JavaType. - typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
- typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Use the supplied
Jackson2JavaTypeMapper
. - typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Use the supplied
Jackson2JavaTypeMapper
. - typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Use the supplied
Jackson2JavaTypeMapper
. - typeResolver(JsonTypeResolver) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
JsonTypeResolver
that receives the data to be deserialized and the headers and returns a JavaType.
U
- uniformRandomBackoff(long, long) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- unrecoverableBackOff(BackOff, ThreadLocal<BackOffExecution>, ThreadLocal<Long>) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Deprecated.
- unrecoverableBackOff(BackOff, ThreadLocal<BackOffExecution>, ThreadLocal<Long>, MessageListenerContainer) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Sleep according to the
BackOff
; when theBackOffExecution
returnsBackOffExecution.STOP
sleep for the previous backOff. - unregisterListenerContainer(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Unregister the listener container with the provided id.
- unregisterSeekCallback() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
- unregisterSeekCallback() - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
-
Called when the listener consumer terminates allowing implementations to clean up state, such as thread locals.
- unwrapIfNeeded(Exception) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
-
Remove a
TimestampedException
, if present. - updateConfigs(Map<String, Object>) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Update the consumer configuration map; useful for situations such as credential rotation.
- updateConfigs(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- updateConfigs(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- updateConfigs(Map<String, Object>) - Method in interface org.springframework.kafka.core.ProducerFactory
-
Update the producer configuration map; useful for situations such as credential rotation.
- USE_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property for using type headers (default true).
- useSingleTopicForFixedDelays() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- useSingleTopicForFixedDelays(FixedDelayStrategy) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- usingCompletableFuture() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Return an implementation that returns
CompletableFuture
instead ofListenableFuture
.
V
- V1 - org.springframework.kafka.listener.ContainerProperties.EOSMode
-
Deprecated.3.0 and later will require 2.5+ brokers
- V2 - org.springframework.kafka.listener.ContainerProperties.EOSMode
-
fetch-offset-request fencing (2.5+ brokers).
- value() - Method in annotation type org.springframework.kafka.annotation.KafkaListeners
- value() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
- value(V) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- VALUE_DEFAULT_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property for the default value type if no header.
- VALUE_DESERIALIZER_CLASS - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Property name for the delegate value deserializer.
- VALUE_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Deprecated.
- VALUE_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.SerializationUtils
-
Header name for deserialization exceptions.
- VALUE_FUNCTION - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Supplier for a T when deserialization fails.
- VALUE_PARSER - Static variable in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Property for the key parser method.
- VALUE_SERIALIZATION_SELECTOR - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
-
Name of the header containing the serialization selector for values.
- VALUE_SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
-
Name of the configuration property containing the serialization selector map for values with format
selector:class,...
. - VALUE_SERIALIZATION_TOPIC_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Name of the configuration property containing the serialization selector map for values with format
selector:class,...
. - VALUE_SERIALIZATION_TOPIC_DEFAULT - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Name of the default delegate for keys when no topic name match is fount.
- VALUE_TYPE - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Header for the type of value.
- VALUE_TYPE_METHOD - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
A method name to determine the
JavaType
to deserialize the value to: 'com.Foo.deserialize'. - valueOf(String) - Static method in enum org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.KafkaException.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.listener.ContainerProperties.AckMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.listener.ContainerProperties.EOSMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.listener.ListenerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.retrytopic.DltStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.retrytopic.FixedDelayStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.retrytopic.TopicSuffixingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.springframework.kafka.event.ConsumerStoppedEvent.Reason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.KafkaException.Level
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.listener.ContainerProperties.AckMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.listener.ContainerProperties.EOSMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.listener.ListenerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.retrytopic.DltStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.retrytopic.FixedDelayStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.retrytopic.TopicSuffixingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
-
Returns an array containing the constants of this enum type, in the order they are declared.
- verifySendResult(KafkaOperations<Object, Object>, ProducerRecord<Object, Object>, ListenableFuture<SendResult<Object, Object>>, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Wait for the send future to complete.
W
- waitForAssignment(Object, int) - Static method in class org.springframework.kafka.test.utils.ContainerTestUtils
-
Wait until the container has the required number of assigned partitions.
- waitForAssignment(Duration) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Wait until partitions are assigned, e.g.
- waitForAssignment(Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- wantsPollResult() - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
- wantsPollResult() - Method in interface org.springframework.kafka.listener.BatchMessageListener
-
Return true if this listener wishes to receive the original
ConsumerRecords
object instead of a list ofConsumerRecord
. - WARN - org.springframework.kafka.KafkaException.Level
-
Warn.
- WARN - org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Warn.
Z
- zkConnectionTimeout() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Timeout for internal ZK client connection.
- zkConnectionTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set connection timeout for the client to the embedded Zookeeper.
- zkPort(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set an explicit port for the embedded Zookeeper.
- zkPort(int) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
- zkSessionTimeout() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Timeout for internal ZK client session.
- zkSessionTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set session timeout for the client to the embedded Zookeeper.
- zookeeperPort() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
-
Set the port on which the embedded Zookeeper should listen;
All Classes All Packages