JavaScript is disabled on your browser.
Skip navigation links
Overview
Package
Class
Tree
Deprecated
Index
Help
Spring Kafka
Prev
Next
Frames
No Frames
All Classes
Hierarchy For All Packages
Package Hierarchies:
org.springframework.kafka
,
org.springframework.kafka.annotation
,
org.springframework.kafka.config
,
org.springframework.kafka.core
,
org.springframework.kafka.core.reactive
,
org.springframework.kafka.event
,
org.springframework.kafka.listener
,
org.springframework.kafka.listener.adapter
,
org.springframework.kafka.requestreply
,
org.springframework.kafka.security.jaas
,
org.springframework.kafka.streams
,
org.springframework.kafka.streams.messaging
,
org.springframework.kafka.support
,
org.springframework.kafka.support.converter
,
org.springframework.kafka.support.serializer
,
org.springframework.kafka.test
,
org.springframework.kafka.test.assertj
,
org.springframework.kafka.test.condition
,
org.springframework.kafka.test.context
,
org.springframework.kafka.test.core
,
org.springframework.kafka.test.hamcrest
,
org.springframework.kafka.test.rule
,
org.springframework.kafka.test.utils
,
org.springframework.kafka.transaction
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.kafka.listener.adapter.
AbstractFilteringMessageListener
<K,V,T>
org.springframework.kafka.listener.adapter.
FilteringBatchMessageListenerAdapter
<K,V> (implements org.springframework.kafka.listener.
BatchAcknowledgingConsumerAwareMessageListener
<K,V>)
org.springframework.kafka.listener.adapter.
FilteringMessageListenerAdapter
<K,V> (implements org.springframework.kafka.listener.
AcknowledgingConsumerAwareMessageListener
<K,V>)
org.springframework.kafka.listener.adapter.
AbstractRetryingMessageListenerAdapter
<K,V,T>
org.springframework.kafka.listener.adapter.
RetryingMessageListenerAdapter
<K,V> (implements org.springframework.kafka.listener.
AcknowledgingConsumerAwareMessageListener
<K,V>)
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.config.
StreamsBuilderFactoryBean
(implements org.springframework.context.SmartLifecycle)
org.springframework.kafka.support.converter.
AbstractJavaTypeMapper
(implements org.springframework.beans.factory.BeanClassLoaderAware)
org.springframework.kafka.support.converter.
DefaultJackson2JavaTypeMapper
(implements org.springframework.kafka.support.converter.
Jackson2JavaTypeMapper
)
org.springframework.kafka.support.
AbstractKafkaHeaderMapper
(implements org.springframework.kafka.support.
KafkaHeaderMapper
)
org.springframework.kafka.support.
DefaultKafkaHeaderMapper
org.springframework.kafka.support.
SimpleKafkaHeaderMapper
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.
ConcurrentKafkaListenerContainerFactory
<K,V>
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.kafka.config.
MethodKafkaListenerEndpoint
<K,V>
org.springframework.kafka.config.
MultiMethodKafkaListenerEndpoint
<K,V>
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.kafka.listener.
ConcurrentMessageListenerContainer
<K,V>
org.springframework.kafka.listener.
KafkaMessageListenerContainer
<K,V>
org.springframework.transaction.support.AbstractPlatformTransactionManager (implements org.springframework.transaction.PlatformTransactionManager, java.io.Serializable)
org.springframework.kafka.transaction.
KafkaTransactionManager
<K,V> (implements org.springframework.kafka.transaction.
KafkaAwareTransactionManager
<K,V>)
org.hamcrest.BaseMatcher<T> (implements org.hamcrest.Matcher<T>)
org.hamcrest.DiagnosingMatcher<T>
org.springframework.kafka.test.hamcrest.
KafkaMatchers.ConsumerRecordKeyMatcher
<K>
org.springframework.kafka.test.hamcrest.
KafkaMatchers.ConsumerRecordPartitionMatcher
org.springframework.kafka.test.hamcrest.
KafkaMatchers.ConsumerRecordTimestampMatcher
org.springframework.kafka.test.hamcrest.
KafkaMatchers.ConsumerRecordValueMatcher
<V>
org.springframework.kafka.listener.
BatchLoggingErrorHandler
(implements org.springframework.kafka.listener.
BatchErrorHandler
)
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.transaction.
ChainedKafkaTransactionManager
<K,V> (implements org.springframework.kafka.transaction.
KafkaAwareTransactionManager
<K,V>)
org.springframework.kafka.core.
CleanupConfig
org.springframework.kafka.config.
CompositeKafkaStreamsCustomizer
(implements org.springframework.kafka.config.
KafkaStreamsCustomizer
)
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.test.assertj.
KafkaConditions.ConsumerRecordKeyCondition
<K>
org.springframework.kafka.test.assertj.
KafkaConditions.ConsumerRecordPartitionCondition
org.springframework.kafka.test.assertj.
KafkaConditions.ConsumerRecordTimestampCondition
org.springframework.kafka.test.assertj.
KafkaConditions.ConsumerRecordValueCondition
<V>
org.springframework.kafka.listener.
ConsumerProperties
org.springframework.kafka.listener.
ContainerProperties
org.springframework.kafka.listener.
ContainerStoppingBatchErrorHandler
(implements org.springframework.kafka.listener.
ContainerAwareBatchErrorHandler
)
org.springframework.kafka.listener.
ContainerStoppingErrorHandler
(implements org.springframework.kafka.listener.
ContainerAwareErrorHandler
)
org.springframework.kafka.test.utils.
ContainerTestUtils
org.springframework.kafka.requestreply.
CorrelationKey
org.springframework.kafka.listener.
DeadLetterPublishingRecoverer
(implements org.springframework.kafka.listener.
ConsumerRecordRecoverer
)
org.springframework.kafka.core.
DefaultKafkaConsumerFactory
<K,V> (implements org.springframework.kafka.core.
ConsumerFactory
<K,V>)
org.springframework.kafka.support.
DefaultKafkaHeaderMapper.NonTrustedHeaderType
org.springframework.kafka.core.
DefaultKafkaProducerFactory
<K,V> (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationListener<E>, org.springframework.beans.factory.DisposableBean, org.springframework.kafka.core.
ProducerFactory
<K,V>)
org.springframework.kafka.core.
DefaultKafkaProducerFactory.CloseSafeProducer
<K,V> (implements org.apache.kafka.clients.producer.Producer<K,V>)
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.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.support.serializer.
ErrorHandlingDeserializer
<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
org.springframework.kafka.support.serializer.
ErrorHandlingDeserializer2
<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
java.util.EventObject (implements java.io.Serializable)
org.springframework.context.ApplicationEvent
org.springframework.kafka.event.
KafkaEvent
org.springframework.kafka.event.
ConsumerFailedToStartEvent
org.springframework.kafka.event.
ConsumerPausedEvent
org.springframework.kafka.event.
ConsumerResumedEvent
org.springframework.kafka.event.
ConsumerStartedEvent
org.springframework.kafka.event.
ConsumerStartingEvent
org.springframework.kafka.event.
ConsumerStoppedEvent
org.springframework.kafka.event.
ConsumerStoppingEvent
org.springframework.kafka.event.
ContainerStoppedEvent
org.springframework.kafka.event.
ListenerContainerIdleEvent
org.springframework.kafka.event.
NonResponsiveConsumerEvent
org.junit.rules.ExternalResource (implements org.junit.rules.TestRule)
org.springframework.kafka.test.rule.
EmbeddedKafkaRule
org.springframework.kafka.support.serializer.
FailedDeserializationInfo
org.springframework.kafka.listener.
FailedRecordProcessor
org.springframework.kafka.listener.
DefaultAfterRollbackProcessor
<K,V> (implements org.springframework.kafka.listener.
AfterRollbackProcessor
<K,V>)
org.springframework.kafka.listener.
SeekToCurrentErrorHandler
(implements org.springframework.kafka.listener.
ContainerAwareErrorHandler
)
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.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
(implements org.springframework.context.ApplicationContextAware, org.springframework.beans.factory.SmartInitializingSingleton)
org.springframework.kafka.annotation.
KafkaBootstrapConfiguration
(implements org.springframework.context.annotation.ImportBeanDefinitionRegistrar)
org.springframework.kafka.test.assertj.
KafkaConditions
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.beans.factory.BeanFactoryAware, org.springframework.beans.factory.config.BeanPostProcessor, 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.context.SmartLifecycle)
org.springframework.kafka.test.hamcrest.
KafkaMatchers
org.springframework.kafka.support.
KafkaNull
org.springframework.kafka.support.
KafkaStreamBrancher
<K,V>
org.springframework.kafka.config.
KafkaStreamsConfiguration
org.springframework.kafka.annotation.
KafkaStreamsDefaultConfiguration
org.springframework.kafka.core.
KafkaTemplate
<K,V> (implements org.springframework.kafka.core.
KafkaOperations
<K,V>)
org.springframework.kafka.requestreply.
ReplyingKafkaTemplate
<K,V,R> (implements org.springframework.kafka.listener.
BatchMessageListener
<K,V>, 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.requestreply.
AggregatingReplyingKafkaTemplate
<K,V,R> (implements org.springframework.kafka.listener.
BatchConsumerAwareMessageListener
<K,V>)
org.springframework.kafka.test.utils.
KafkaTestUtils
org.springframework.kafka.support.
KafkaUtils
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.listener.
LoggingErrorHandler
(implements org.springframework.kafka.listener.
ErrorHandler
)
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.MessageHeaders (implements java.util.Map<K,V>, java.io.Serializable)
org.springframework.kafka.support.converter.
KafkaMessageHeaders
org.springframework.kafka.support.converter.
MessagingMessageConverter
(implements org.springframework.kafka.support.converter.
RecordMessageConverter
)
org.springframework.kafka.support.converter.
JsonMessageConverter
org.springframework.kafka.support.converter.
ByteArrayJsonMessageConverter
org.springframework.kafka.support.converter.
BytesJsonMessageConverter
org.springframework.kafka.support.converter.
StringJsonMessageConverter
org.springframework.kafka.support.converter.
ProjectingMessageConverter
org.springframework.kafka.listener.adapter.
MessagingMessageListenerAdapter
<K,V> (implements org.springframework.kafka.listener.
ConsumerSeekAware
)
org.springframework.kafka.listener.adapter.
BatchMessagingMessageListenerAdapter
<K,V> (implements org.springframework.kafka.listener.
BatchAcknowledgingConsumerAwareMessageListener
<K,V>)
org.springframework.kafka.listener.adapter.
RecordMessagingMessageListenerAdapter
<K,V> (implements org.springframework.kafka.listener.
AcknowledgingConsumerAwareMessageListener
<K,V>)
org.springframework.kafka.listener.adapter.
MessagingMessageListenerAdapter.ReplyExpressionRoot
org.springframework.kafka.streams.messaging.
MessagingTransformer
<K,V,R> (implements org.apache.kafka.streams.kstream.Transformer<K,V,R>)
com.fasterxml.jackson.databind.Module (implements com.fasterxml.jackson.core.Versioned)
com.fasterxml.jackson.databind.module.SimpleModule (implements java.io.Serializable)
org.springframework.kafka.support.
JacksonMimeTypeModule
org.springframework.kafka.core.
ProducerFactoryUtils
org.springframework.kafka.support.
ProducerListenerAdapter
<K,V> (implements org.springframework.kafka.support.
ProducerListener
<K,V>)
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)
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.core.
KafkaResourceHolder
<K,V>
org.springframework.kafka.support.serializer.
RetryingDeserializer
<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
org.springframework.kafka.listener.
SeekToCurrentBatchErrorHandler
(implements org.springframework.kafka.listener.
ContainerAwareBatchErrorHandler
)
org.springframework.kafka.support.
SeekUtils
org.springframework.kafka.support.
SendResult
<K,V>
org.springframework.util.concurrent.SettableListenableFuture<T> (implements org.springframework.util.concurrent.ListenableFuture<T>)
org.springframework.kafka.requestreply.
RequestReplyFuture
<K,V,R>
org.springframework.kafka.support.serializer.
StringOrBytesSerializer
(implements org.apache.kafka.common.serialization.Serializer<T>)
java.lang.Throwable (implements java.io.Serializable)
java.lang.Exception
java.lang.RuntimeException
org.springframework.core.NestedRuntimeException
org.springframework.kafka.
KafkaException
org.springframework.kafka.support.converter.
ConversionException
org.springframework.kafka.support.serializer.
DeserializationException
org.springframework.kafka.core.
KafkaProducerException
org.springframework.kafka.requestreply.
KafkaReplyTimeoutException
org.springframework.kafka.listener.
ListenerExecutionFailedException
org.springframework.kafka.config.
TopicBuilder
org.springframework.kafka.support.
TopicPartitionInitialOffset
org.springframework.kafka.support.
TopicPartitionOffset
org.springframework.kafka.support.
TransactionSupport
Interface Hierarchy
org.springframework.kafka.support.
AbstractKafkaHeaderMapper.HeaderMatcher
org.springframework.kafka.support.
Acknowledgment
org.springframework.kafka.listener.
AfterRollbackProcessor
<K,V>
java.util.function.BiConsumer<T,U>
org.springframework.kafka.listener.
ConsumerRecordRecoverer
org.springframework.kafka.support.converter.
ClassMapper
org.springframework.kafka.support.converter.
Jackson2JavaTypeMapper
org.springframework.kafka.core.
ConsumerFactory
<K,V>
org.apache.kafka.clients.consumer.ConsumerRebalanceListener
org.springframework.kafka.listener.
ConsumerAwareRebalanceListener
org.springframework.kafka.listener.
ConsumerSeekAware
org.springframework.kafka.listener.
ConsumerSeekAware.ConsumerSeekCallback
org.springframework.kafka.listener.
DelegatingMessageListener
<T>
org.springframework.kafka.listener.
GenericErrorHandler
<T>
org.springframework.kafka.listener.
BatchErrorHandler
org.springframework.kafka.listener.
ConsumerAwareBatchErrorHandler
org.springframework.kafka.listener.
ContainerAwareBatchErrorHandler
org.springframework.kafka.listener.
ContainerAwareBatchErrorHandler
org.springframework.kafka.listener.
ConsumerAwareBatchErrorHandler
org.springframework.kafka.listener.
ContainerAwareBatchErrorHandler
org.springframework.kafka.listener.
ConsumerAwareErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
RemainingRecordsErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
ContainerAwareBatchErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
ErrorHandler
org.springframework.kafka.listener.
ConsumerAwareErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
RemainingRecordsErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
RemainingRecordsErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
RemainingRecordsErrorHandler
org.springframework.kafka.listener.
ContainerAwareErrorHandler
org.springframework.kafka.listener.
GenericMessageListener
<T>
org.springframework.kafka.listener.
AcknowledgingConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
AcknowledgingMessageListener
<K,V>
org.springframework.kafka.listener.
BatchAcknowledgingConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
BatchAcknowledgingMessageListener
<K,V>
org.springframework.kafka.listener.
BatchConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
BatchMessageListener
<K,V>
org.springframework.kafka.listener.
BatchAcknowledgingConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
BatchAcknowledgingMessageListener
<K,V>
org.springframework.kafka.listener.
BatchConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
ConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
MessageListener
<K,V>
org.springframework.kafka.listener.
AcknowledgingConsumerAwareMessageListener
<K,V>
org.springframework.kafka.listener.
AcknowledgingMessageListener
<K,V>
org.springframework.kafka.listener.
ConsumerAwareMessageListener
<K,V>
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.listener.
ConsumerAwareListenerErrorHandler
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.config.
KafkaStreamsCustomizer
org.springframework.context.Lifecycle
org.springframework.context.SmartLifecycle (also extends org.springframework.context.Phased)
org.springframework.kafka.listener.
MessageListenerContainer
org.springframework.kafka.listener.
GenericMessageListenerContainer
<K,V>
org.springframework.kafka.support.converter.
MessageConverter
org.springframework.kafka.support.converter.
BatchMessageConverter
org.springframework.kafka.support.converter.
RecordMessageConverter
org.springframework.kafka.streams.messaging.
MessagingFunction
org.springframework.context.Phased
org.springframework.context.SmartLifecycle (also extends org.springframework.context.Lifecycle)
org.springframework.kafka.listener.
MessageListenerContainer
org.springframework.kafka.listener.
GenericMessageListenerContainer
<K,V>
org.springframework.kafka.core.
ProducerFactory
<K,V>
org.springframework.kafka.support.
ProducerListener
<K,V>
org.springframework.kafka.listener.adapter.
RecordFilterStrategy
<K,V>
org.springframework.kafka.listener.
RecordInterceptor
<K,V>
org.springframework.kafka.listener.adapter.
ReplyHeadersConfigurer
org.springframework.kafka.requestreply.
ReplyingKafkaOperations
<K,V,R>
org.springframework.kafka.config.
StreamsBuilderFactoryBeanCustomizer
org.springframework.transaction.TransactionManager
org.springframework.transaction.PlatformTransactionManager
org.springframework.transaction.support.ResourceTransactionManager
org.springframework.kafka.transaction.
KafkaAwareTransactionManager
<K,V>
Annotation Type Hierarchy
org.springframework.kafka.annotation.
TopicPartition
(implements java.lang.annotation.Annotation)
org.springframework.kafka.annotation.
EnableKafkaStreams
(implements java.lang.annotation.Annotation)
org.springframework.kafka.annotation.
EnableKafka
(implements java.lang.annotation.Annotation)
org.springframework.kafka.annotation.
KafkaListener
(implements java.lang.annotation.Annotation)
org.springframework.kafka.annotation.
KafkaListeners
(implements java.lang.annotation.Annotation)
org.springframework.kafka.annotation.
PartitionOffset
(implements java.lang.annotation.Annotation)
org.springframework.kafka.annotation.
KafkaHandler
(implements java.lang.annotation.Annotation)
org.springframework.kafka.test.context.
EmbeddedKafka
(implements java.lang.annotation.Annotation)
org.springframework.kafka.test.condition.
LogLevels
(implements java.lang.annotation.Annotation)
Enum Hierarchy
java.lang.Object
java.lang.Enum<E> (implements java.lang.Comparable<T>, java.io.Serializable)
org.springframework.kafka.listener.
ListenerType
org.springframework.kafka.listener.
ContainerProperties.AckMode
org.springframework.kafka.support.
LogIfLevelEnabled.Level
org.springframework.kafka.support.
TopicPartitionInitialOffset.SeekPosition
org.springframework.kafka.support.
TopicPartitionOffset.SeekPosition
org.springframework.kafka.support.converter.
Jackson2JavaTypeMapper.TypePrecedence
org.springframework.kafka.security.jaas.
KafkaJaasLoginModuleInitializer.ControlFlag
Skip navigation links
Overview
Package
Class
Tree
Deprecated
Index
Help
Spring Kafka
Prev
Next
Frames
No Frames
All Classes