Class Hierarchy
- java.lang.Object
- org.springframework.kafka.listener.AbstractConsumerSeekAware (implements org.springframework.kafka.listener.ConsumerSeekAware)
- org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter<T> (implements org.springframework.kafka.listener.ConsumerSeekAware, org.springframework.kafka.listener.DelegatingMessageListener<T>)
- org.springframework.beans.factory.config.AbstractFactoryBean<T> (implements org.springframework.beans.factory.BeanClassLoaderAware, org.springframework.beans.factory.BeanFactoryAware, org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.FactoryBean<T>, org.springframework.beans.factory.InitializingBean)
- org.springframework.kafka.support.mapping.AbstractJavaTypeMapper (implements org.springframework.beans.factory.BeanClassLoaderAware)
- org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory (implements org.springframework.context.ApplicationContextAware, org.springframework.kafka.listener.KafkaBackOffManagerFactory)
- org.springframework.kafka.support.AbstractKafkaHeaderMapper (implements org.springframework.kafka.support.KafkaHeaderMapper)
- org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher (implements org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher)
- org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher (implements org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher)
- org.springframework.kafka.config.AbstractKafkaListenerContainerFactory<C,K,V> (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationEventPublisherAware, org.springframework.beans.factory.InitializingBean, org.springframework.kafka.config.KafkaListenerContainerFactory<C>)
- org.springframework.kafka.config.AbstractKafkaListenerEndpoint<K,V> (implements org.springframework.beans.factory.BeanFactoryAware, org.springframework.beans.factory.InitializingBean, org.springframework.kafka.config.KafkaListenerEndpoint)
- org.springframework.messaging.converter.AbstractMessageConverter (implements org.springframework.messaging.converter.SmartMessageConverter)
- org.springframework.kafka.listener.AbstractMessageListenerContainer<K,V> (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationEventPublisherAware, org.springframework.beans.factory.BeanNameAware, org.springframework.kafka.listener.GenericMessageListenerContainer<K,V>)
- org.springframework.transaction.support.AbstractPlatformTransactionManager (implements org.springframework.transaction.PlatformTransactionManager, java.io.Serializable)
- org.springframework.kafka.core.ABSwitchCluster (implements java.util.function.Supplier<T>)
- org.springframework.kafka.listener.adapter.AdapterUtils
- org.springframework.kafka.support.AllowDenyCollectionManager<T>
- org.springframework.kafka.retrytopic.BackOffValuesGenerator
- org.hamcrest.BaseMatcher<T> (implements org.hamcrest.Matcher<T>)
- org.hamcrest.DiagnosingMatcher<T>
 
- org.springframework.kafka.support.converter.BatchMessagingMessageConverter (implements org.springframework.kafka.support.converter.BatchMessageConverter)
- org.springframework.kafka.test.core.BrokerAddress
- org.springframework.data.transaction.ChainedTransactionManager (implements org.springframework.transaction.PlatformTransactionManager)
- org.springframework.kafka.core.CleanupConfig
- org.springframework.kafka.listener.CommonDelegatingErrorHandler (implements org.springframework.kafka.listener.CommonErrorHandler)
- org.springframework.kafka.listener.CommonLoggingErrorHandler (implements org.springframework.kafka.listener.CommonErrorHandler)
- org.springframework.kafka.listener.CommonMixedErrorHandler (implements org.springframework.kafka.listener.CommonErrorHandler)
- java.util.concurrent.CompletableFuture<T> (implements java.util.concurrent.CompletionStage<T>, java.util.concurrent.Future<V>)
- org.springframework.kafka.listener.CompositeBatchInterceptor<K,V> (implements org.springframework.kafka.listener.BatchInterceptor<K,V>)
- org.springframework.kafka.config.CompositeKafkaStreamsCustomizer (implements org.springframework.kafka.config.KafkaStreamsCustomizer)
- org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer (implements org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer)
- org.springframework.kafka.support.CompositeProducerInterceptor<K,V> (implements java.io.Closeable, org.apache.kafka.clients.producer.ProducerInterceptor<K,V>)
- org.springframework.kafka.support.CompositeProducerListener<K,V> (implements org.springframework.kafka.support.ProducerListener<K,V>)
- org.springframework.kafka.listener.CompositeRecordInterceptor<K,V> (implements org.springframework.kafka.listener.RecordInterceptor<K,V>)
- org.assertj.core.api.Condition<T> (implements org.assertj.core.api.Descriptable<SELF>)
- org.springframework.kafka.listener.ConsumerProperties
- org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- org.springframework.kafka.listener.ContainerGroup (implements org.springframework.context.Lifecycle)
- org.springframework.kafka.listener.ContainerGroupSequencer (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationListener<E>, org.springframework.context.SmartLifecycle)
- org.springframework.kafka.listener.ContainerPartitionPausingBackOffManager (implements org.springframework.kafka.listener.KafkaConsumerBackoffManager)
- org.springframework.kafka.listener.ContainerPausingBackOffHandler (implements org.springframework.kafka.listener.BackOffHandler)
- org.springframework.kafka.test.utils.ContainerTestUtils
- org.apache.kafka.streams.processor.api.ContextualProcessor<KIn,VIn,KOut,VOut> (implements org.apache.kafka.streams.processor.api.Processor<KIn,VIn,KOut,VOut>)
- org.springframework.kafka.listener.adapter.ConvertingMessageListener<V> (implements org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener<K,V>, org.springframework.kafka.listener.DelegatingMessageListener<T>)
- org.springframework.kafka.requestreply.CorrelationKey
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
- org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- org.springframework.kafka.listener.DefaultBackOffHandler (implements org.springframework.kafka.listener.BackOffHandler)
- org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter<K,V> (implements org.springframework.kafka.listener.adapter.BatchToRecordAdapter<K,V>)
- org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor (implements org.springframework.kafka.retrytopic.DestinationTopicProcessor)
- org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver.DestinationTopicHolder
- org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer<K,V> (implements org.apache.kafka.clients.producer.Producer<K,V>)
- org.springframework.kafka.support.serializer.DelegatingByTopicSerialization<T> (implements java.io.Closeable)
- org.springframework.kafka.support.serializer.DelegatingByTypeSerializer (implements org.apache.kafka.common.serialization.Serializer<T>)
- org.springframework.kafka.support.serializer.DelegatingDeserializer (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
- org.springframework.kafka.support.serializer.DelegatingSerializer (implements org.apache.kafka.common.serialization.Serializer<T>)
- org.springframework.kafka.retrytopic.DestinationTopic
- org.springframework.kafka.retrytopic.DestinationTopic.Properties
- org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
- org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory
- org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory.DestinationTopicSuffixes
- org.springframework.kafka.test.EmbeddedKafkaBroker (implements org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean)
- org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- org.springframework.kafka.test.condition.EmbeddedKafkaCondition (implements org.junit.jupiter.api.extension.AfterAllCallback, org.junit.jupiter.api.extension.ExecutionCondition, org.junit.jupiter.api.extension.ParameterResolver)
- org.springframework.kafka.retrytopic.EndpointCustomizer.TopicNamesHolder
- org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- org.springframework.kafka.support.EndpointHandlerMethod
- org.springframework.kafka.support.serializer.ErrorHandlingDeserializer<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.listener.ErrorHandlingUtils
- java.util.EventObject (implements java.io.Serializable)
- org.springframework.util.backoff.ExponentialBackOff (implements org.springframework.util.backoff.BackOff)
- org.junit.rules.ExternalResource (implements org.junit.rules.TestRule)
- org.springframework.kafka.support.serializer.FailedDeserializationInfo
- org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener (implements org.junit.platform.launcher.TestExecutionListener)
- org.springframework.kafka.listener.adapter.HandlerAdapter
- org.springframework.kafka.streams.HeaderEnricher<K,V> (implements org.apache.kafka.streams.kstream.Transformer<K,V,R>)
- org.springframework.kafka.streams.HeaderEnricher.Container<K,V>
- org.springframework.kafka.streams.HeaderEnricherProcessor.Container<K,V>
- org.springframework.kafka.listener.adapter.InvocationResult
- org.springframework.kafka.support.JacksonPresent
- org.springframework.kafka.support.JacksonUtils
- org.springframework.kafka.support.JavaUtils
- org.springframework.kafka.support.serializer.JsonDeserializer<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.support.serializer.JsonSerde<T> (implements org.apache.kafka.common.serialization.Serde<T>)
- org.springframework.kafka.support.serializer.JsonSerializer<T> (implements org.apache.kafka.common.serialization.Serializer<T>)
- org.springframework.kafka.test.utils.JUnitUtils
- org.springframework.kafka.test.utils.JUnitUtils.LevelsContainer
- org.springframework.kafka.core.KafkaAdmin.NewTopics
- org.springframework.kafka.aot.KafkaAvroBeanRegistrationAotProcessor (implements org.springframework.beans.factory.aot.BeanRegistrationAotProcessor)
- org.springframework.kafka.annotation.KafkaBootstrapConfiguration (implements org.springframework.context.annotation.ImportBeanDefinitionRegistrar)
- org.springframework.kafka.test.assertj.KafkaConditions
- org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- org.springframework.kafka.listener.KafkaExceptionLogLevelAware
- org.springframework.kafka.support.KafkaHeaders
- org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer (implements org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.SmartInitializingSingleton)
- org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor<K,V> (implements org.springframework.context.ApplicationContextAware, org.springframework.beans.factory.config.BeanPostProcessor, org.springframework.beans.factory.InitializingBean, org.springframework.core.Ordered, org.springframework.beans.factory.SmartInitializingSingleton)
- org.springframework.kafka.annotation.KafkaListenerConfigurationSelector (implements org.springframework.context.annotation.DeferredImportSelector)
- org.springframework.kafka.config.KafkaListenerConfigUtils
- org.springframework.kafka.config.KafkaListenerEndpointRegistrar (implements org.springframework.beans.factory.BeanFactoryAware, org.springframework.beans.factory.InitializingBean)
- org.springframework.kafka.config.KafkaListenerEndpointRegistry (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationListener<E>, org.springframework.beans.factory.DisposableBean, org.springframework.kafka.listener.ListenerContainerRegistry, org.springframework.context.SmartLifecycle)
- org.springframework.kafka.support.micrometer.KafkaListenerObservation.DefaultKafkaListenerObservationConvention (implements org.springframework.kafka.support.micrometer.KafkaListenerObservationConvention)
- org.springframework.kafka.test.hamcrest.KafkaMatchers
- org.springframework.kafka.support.KafkaNull
- org.springframework.kafka.core.KafkaResourceFactory
- org.springframework.kafka.core.DefaultKafkaConsumerFactory<K,V> (implements org.springframework.beans.factory.BeanNameAware, org.springframework.kafka.core.ConsumerFactory<K,V>)
- org.springframework.kafka.core.DefaultKafkaProducerFactory<K,V> (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationListener<E>, org.springframework.beans.factory.BeanNameAware, org.springframework.beans.factory.DisposableBean, org.springframework.kafka.core.ProducerFactory<K,V>, org.springframework.context.SmartLifecycle)
- org.springframework.kafka.core.KafkaAdmin (implements org.springframework.context.ApplicationContextAware, org.springframework.kafka.core.KafkaAdminOperations, org.springframework.beans.factory.SmartInitializingSingleton)
 
- org.springframework.kafka.aot.KafkaRuntimeHints (implements org.springframework.aot.hint.RuntimeHintsRegistrar)
- org.springframework.kafka.support.KafkaStreamBrancher<K,V>
- org.springframework.kafka.config.KafkaStreamsConfiguration
- org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
- org.springframework.kafka.streams.KafkaStreamsMicrometerListener (implements org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener)
- org.springframework.kafka.core.KafkaTemplate<K,V> (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationListener<E>, org.springframework.beans.factory.BeanNameAware, org.springframework.beans.factory.DisposableBean, org.springframework.kafka.core.KafkaOperations<K,V>, org.springframework.beans.factory.SmartInitializingSingleton)
- org.springframework.kafka.requestreply.ReplyingKafkaTemplate<K,V,R> (implements org.springframework.kafka.listener.BatchMessageListener<K,V>, org.springframework.kafka.listener.ConsumerSeekAware, org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean, org.springframework.kafka.requestreply.ReplyingKafkaOperations<K,V,R>, org.springframework.context.SmartLifecycle)
- org.springframework.kafka.core.RoutingKafkaTemplate
 
- org.springframework.kafka.support.micrometer.KafkaTemplateObservation.DefaultKafkaTemplateObservationConvention (implements org.springframework.kafka.support.micrometer.KafkaTemplateObservationConvention)
- org.springframework.kafka.test.utils.KafkaTestUtils
- org.springframework.kafka.support.KafkaUtils
- org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- org.springframework.kafka.retrytopic.ListenerContainerFactoryResolver
- org.springframework.kafka.listener.ListenerContainerPauseService
- org.springframework.kafka.listener.ListenerUtils
- org.springframework.kafka.test.rule.Log4j2LevelAdjuster (implements org.junit.rules.MethodRule)
- org.springframework.kafka.listener.LoggingCommitCallback (implements org.apache.kafka.clients.consumer.OffsetCommitCallback)
- org.springframework.kafka.support.LoggingProducerListener<K,V> (implements org.springframework.kafka.support.ProducerListener<K,V>)
- org.springframework.kafka.support.LogIfLevelEnabled
- org.springframework.kafka.test.condition.LogLevelsCondition (implements org.junit.jupiter.api.extension.AfterAllCallback, org.junit.jupiter.api.extension.AfterEachCallback, org.junit.jupiter.api.extension.BeforeAllCallback, org.junit.jupiter.api.extension.BeforeEachCallback, org.junit.jupiter.api.extension.ExecutionCondition)
- org.springframework.messaging.support.MessageHeaderAccessor
- org.springframework.messaging.MessageHeaders (implements java.util.Map<K,V>, java.io.Serializable)
- org.springframework.kafka.support.converter.MessagingMessageConverter (implements org.springframework.kafka.support.converter.RecordMessageConverter)
- org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter<K,V> (implements org.springframework.kafka.listener.ConsumerSeekAware)
- org.springframework.kafka.streams.messaging.MessagingTransformer<K,V,R> (implements org.apache.kafka.streams.kstream.Transformer<K,V,R>)
- org.springframework.kafka.core.MicrometerConsumerListener<K,V> (implements org.springframework.kafka.core.ConsumerFactory.Listener<K,V>)
- org.springframework.kafka.support.micrometer.MicrometerHolder
- org.springframework.kafka.core.MicrometerProducerListener<K,V> (implements org.springframework.kafka.core.ProducerFactory.Listener<K,V>)
- org.springframework.kafka.mock.MockConsumerFactory<K,V> (implements org.springframework.kafka.core.ConsumerFactory<K,V>)
- org.springframework.kafka.mock.MockProducerFactory<K,V> (implements org.springframework.kafka.core.ProducerFactory<K,V>)
- com.fasterxml.jackson.databind.Module (implements com.fasterxml.jackson.core.Versioned)
- com.fasterxml.jackson.databind.module.SimpleModule (implements java.io.Serializable)
 
- org.apache.kafka.clients.admin.NewTopic
- io.micrometer.observation.Observation.Context (implements io.micrometer.observation.Observation.ContextView)
- io.micrometer.observation.transport.ReceiverContext<C>
- io.micrometer.observation.transport.SenderContext<C>
 
- org.springframework.kafka.support.serializer.ParseStringDeserializer<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.messaging.handler.annotation.support.PayloadMethodArgumentResolver (implements org.springframework.messaging.handler.invocation.HandlerMethodArgumentResolver)
- org.springframework.kafka.core.ProducerFactoryUtils
- org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate<K,V>
- org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate<K,V> (implements java.lang.AutoCloseable, org.springframework.beans.factory.DisposableBean)
- java.lang.Record
- org.apache.kafka.common.header.internals.RecordHeader (implements org.apache.kafka.common.header.Header)
- org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler (implements org.apache.kafka.streams.errors.DeserializationExceptionHandler)
- org.springframework.transaction.support.ResourceHolderSupport (implements org.springframework.transaction.support.ResourceHolder)
- org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
- org.springframework.kafka.support.serializer.RetryingDeserializer<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.retrytopic.RetryTopicBeanNames
- org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- org.springframework.kafka.retrytopic.RetryTopicConfiguration
- org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- org.springframework.kafka.annotation.RetryTopicConfigurationProvider
- org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport (implements org.springframework.context.ApplicationContextAware, org.springframework.beans.factory.SmartInitializingSingleton)
- org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.BlockingRetriesConfigurer
- org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
- org.springframework.kafka.retrytopic.RetryTopicConfigurer (implements org.springframework.beans.factory.BeanFactoryAware)
- org.springframework.kafka.retrytopic.RetryTopicConstants
- org.springframework.kafka.retrytopic.RetryTopicHeaders
- org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper (implements org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean)
- org.springframework.kafka.listener.SeekUtils
- org.springframework.kafka.support.SendResult<K,V>
- org.springframework.kafka.support.serializer.SerializationUtils
- org.springframework.kafka.support.serializer.StringOrBytesSerializer (implements org.apache.kafka.common.serialization.Serializer<T>)
- org.springframework.kafka.support.Suffixer
- org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory (implements org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory)
- org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider (implements org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider)
- java.lang.Throwable (implements java.io.Serializable)
- org.springframework.kafka.support.serializer.ToFromStringSerde<T> (implements org.apache.kafka.common.serialization.Serde<T>)
- org.springframework.kafka.config.TopicBuilder
- org.springframework.kafka.support.TopicPartitionOffset
- org.springframework.kafka.support.serializer.ToStringSerializer<T> (implements org.apache.kafka.common.serialization.Serializer<T>)
 
Interface Hierarchy
- org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
- org.springframework.kafka.support.Acknowledgment
- org.springframework.kafka.listener.AfterRollbackProcessor<K,V>
- org.springframework.kafka.listener.BackOffHandler
- org.springframework.kafka.listener.adapter.BatchToRecordAdapter<K,V>
- org.springframework.kafka.listener.adapter.BatchToRecordAdapter.Callback<K,V>
- java.util.function.BiConsumer<T,U>
- java.util.function.BiFunction<T,U,R>
- org.springframework.kafka.support.mapping.ClassMapper
- java.util.function.Consumer<T>
- org.springframework.kafka.core.ConsumerFactory<K,V>
- org.springframework.kafka.core.ConsumerFactory.Listener<K,V>
- org.springframework.kafka.listener.ConsumerPauseResumeEventPublisher
- org.apache.kafka.clients.consumer.ConsumerRebalanceListener
- org.springframework.kafka.listener.ConsumerSeekAware
- org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
- org.springframework.kafka.config.ContainerCustomizer<K,V,C>
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer.ExceptionHeadersCreator
- org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory.DeadLetterPublisherCreator
- org.springframework.kafka.listener.DelegatingMessageListener<T>
- org.springframework.kafka.listener.DeliveryAttemptAware
- org.springframework.kafka.retrytopic.DestinationTopicContainer
- org.springframework.kafka.retrytopic.DestinationTopicProcessor
- org.springframework.beans.factory.DisposableBean
- org.springframework.kafka.retrytopic.EndpointCustomizer
- java.util.function.Function<T,R>
- org.springframework.kafka.listener.GenericErrorHandler<T>
- org.springframework.kafka.listener.GenericMessageListener<T>
- org.springframework.kafka.support.serializer.JsonTypeResolver
- org.springframework.kafka.core.KafkaAdminOperations
- org.springframework.kafka.listener.KafkaBackOffManagerFactory
- org.springframework.kafka.listener.KafkaConsumerBackoffManager
- org.springframework.kafka.support.KafkaHeaderMapper
- org.springframework.kafka.annotation.KafkaListenerConfigurer
- org.springframework.kafka.config.KafkaListenerContainerFactory<C>
- org.springframework.kafka.config.KafkaListenerEndpoint
- org.springframework.kafka.listener.KafkaListenerErrorHandler
- org.springframework.kafka.core.KafkaOperations<K,V>
- org.springframework.kafka.core.KafkaOperations.OperationsCallback<K,V,T>
- org.springframework.kafka.core.KafkaOperations.ProducerCallback<K,V,T>
- org.springframework.kafka.core.KafkaOperations2<K,V>
- org.springframework.kafka.config.KafkaStreamsCustomizer
- org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer
- io.micrometer.observation.KeyValuesConvention
- io.micrometer.observation.ObservationConvention<T>
 
- org.springframework.context.Lifecycle
- org.springframework.kafka.listener.ListenerContainerRegistry
- org.springframework.kafka.listener.ListenerMetadata
- org.springframework.kafka.support.converter.MessageConverter
- org.springframework.kafka.streams.messaging.MessagingFunction
- org.springframework.kafka.listener.OffsetAndMetadataProvider
- org.springframework.core.Ordered
- org.springframework.context.Phased
- org.springframework.kafka.core.ProducerFactory<K,V>
- org.springframework.kafka.core.ProducerFactory.Listener<K,V>
- org.springframework.kafka.support.ProducerListener<K,V>
- org.springframework.kafka.listener.adapter.RecordFilterStrategy<K,V>
- org.springframework.kafka.listener.RecoveryStrategy
- org.springframework.kafka.listener.adapter.ReplyHeadersConfigurer
- org.springframework.kafka.requestreply.ReplyingKafkaOperations<K,V,R>
- org.springframework.kafka.listener.RetryListener
- org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory
- org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
- org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
- org.springframework.kafka.listener.ThreadStateProcessor
- org.springframework.transaction.TransactionManager
Annotation Interface Hierarchy