Index

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

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 Class 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.
deadLetterPublishingRecovererFactory(DestinationTopicResolver) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
Create the DeadLetterPublishingRecovererFactory that will be used to create the DeadLetterPublishingRecoverer to forward the records to a given DestinationTopic.
DeadLetterPublishingRecovererFactory - Class in org.springframework.kafka.retrytopic
Creates and configures the DeadLetterPublishingRecoverer that will be used to forward the messages using the DestinationTopicResolver.
DeadLetterPublishingRecovererFactory(DestinationTopicResolver) - Constructor for class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
 
DEBUG - Enum constant in enum class org.springframework.kafka.KafkaException.Level
Debug.
DEBUG - Enum constant in enum class org.springframework.kafka.support.LogIfLevelEnabled.Level
Debug.
decorateFactory(ConcurrentKafkaListenerContainerFactory<?, ?>, ListenerContainerFactoryConfigurer.Configuration) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
decorateFactoryWithoutSettingContainerProperties(ConcurrentKafkaListenerContainerFactory<?, ?>, ListenerContainerFactoryConfigurer.Configuration) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
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 and SeekUtils.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 of 10 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_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 default StreamsBuilderFactoryBean 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 new Consumer instances for provided Map configs and optional Deserializers on each ConsumerFactory.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
The ProducerFactory implementation for a singleton shared Producer instance.
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 Serializers.
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 Serializers.
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 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
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
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>, 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
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 TopicDescriptions 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 the DestinationTopic instances and store them in the provided DestinationTopicResolver.
DestinationTopicProcessor - Interface in org.springframework.kafka.retrytopic
The DestinationTopicProcessor creates and registers the DestinationTopic instances in the provided DestinationTopicProcessor.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 the DestinationTopic 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 the DestinationTopic to which a given ConsumerRecord 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 Interface in org.springframework.kafka.annotation
Annotation to determine the method the should process the DLT topic message.
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() - Element in annotation interface 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 Class in org.springframework.kafka.retrytopic
Strategies for handling DLT processing.
dltSuffix(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
 
dltTopicSuffix() - Element in annotation interface 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.
A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form