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.jdocs.requestreply,
- org.springframework.kafka.jdocs.started.consumer,
- org.springframework.kafka.jdocs.started.noboot,
- org.springframework.kafka.jdocs.started.producer,
- org.springframework.kafka.jdocs.topics,
- org.springframework.kafka.listener,
- org.springframework.kafka.listener.adapter,
- org.springframework.kafka.requestreply,
- org.springframework.kafka.retrytopic,
- 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.mapping,
- org.springframework.kafka.support.micrometer,
- 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.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter<K,V> (implements org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener<K,V>)
- org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener<K,V,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.config.StreamsBuilderFactoryBean (implements org.springframework.beans.factory.BeanNameAware, org.springframework.context.SmartLifecycle)
- org.springframework.kafka.support.mapping.AbstractJavaTypeMapper (implements org.springframework.beans.factory.BeanClassLoaderAware)
- org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper (implements org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper)
- org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory (implements org.springframework.context.ApplicationContextAware, org.springframework.kafka.listener.KafkaBackOffManagerFactory)
- org.springframework.kafka.listener.PartitionPausingBackOffManagerFactory
- 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.config.MethodKafkaListenerEndpoint<K,V>
- org.springframework.messaging.converter.AbstractMessageConverter (implements org.springframework.messaging.converter.SmartMessageConverter)
- org.springframework.messaging.converter.MappingJackson2MessageConverter
- org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
- org.springframework.messaging.converter.MappingJackson2MessageConverter
- 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.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.jdocs.requestreply.Application
- org.springframework.kafka.jdocs.started.consumer.Application
- org.springframework.kafka.jdocs.started.producer.Application
- org.springframework.kafka.jdocs.requestreply.Application.Thing
- org.springframework.kafka.retrytopic.BackOffValuesGenerator
- 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.hamcrest.DiagnosingMatcher<T>
- 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.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)
- 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.CompositeProducerListener<K,V> (implements org.springframework.kafka.support.ProducerListener<K,V>)
- org.springframework.kafka.listener.CompositeRecordInterceptor<K,V> (implements org.springframework.kafka.listener.ConsumerAwareRecordInterceptor<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.ConsumerRecordKeyValueCondition<K,V>
- 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.ConditionalDelegatingBatchErrorHandler (implements org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler)
- org.springframework.kafka.listener.ConditionalDelegatingErrorHandler (implements org.springframework.kafka.listener.ContainerAwareErrorHandler)
- org.springframework.kafka.jdocs.started.noboot.Config
- org.springframework.kafka.jdocs.topics.Config
- org.springframework.kafka.listener.ConsumerProperties
- org.springframework.kafka.listener.ContainerProperties
- 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.test.utils.ContainerTestUtils
- 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.retrytopic.DeadLetterPublishingRecovererFactory
- 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 (implements org.springframework.context.ApplicationListener<E>, org.springframework.kafka.retrytopic.DestinationTopicResolver)
- 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.DelegatingByTopicDeserializer (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.support.serializer.DelegatingByTopicSerializer (implements org.apache.kafka.common.serialization.Serializer<T>)
- 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.context.ApplicationEvent
- org.springframework.kafka.event.KafkaEvent
- org.springframework.kafka.event.ConsumerFailedToStartEvent
- org.springframework.kafka.event.ConsumerPartitionPausedEvent
- org.springframework.kafka.event.ConsumerPartitionResumedEvent
- 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.ListenerContainerNoLongerIdleEvent
- org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
- org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
- org.springframework.kafka.event.NonResponsiveConsumerEvent
- org.springframework.kafka.event.KafkaEvent
- org.springframework.context.ApplicationEvent
- org.springframework.util.backoff.ExponentialBackOff (implements org.springframework.util.backoff.BackOff)
- org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- 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.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.NewTopics
- 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.listener.CommonContainerStoppingErrorHandler (implements org.springframework.kafka.listener.CommonErrorHandler)
- 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.listener.ExceptionClassifier
- org.springframework.kafka.listener.DeadLetterPublishingRecoverer (implements org.springframework.kafka.listener.ConsumerAwareRecordRecoverer)
- org.springframework.kafka.listener.FailedRecordProcessor (implements org.springframework.kafka.listener.DeliveryAttemptAware)
- org.springframework.kafka.listener.DefaultAfterRollbackProcessor<K,V> (implements org.springframework.kafka.listener.AfterRollbackProcessor<K,V>)
- org.springframework.kafka.listener.FailedBatchProcessor
- org.springframework.kafka.listener.DefaultErrorHandler (implements org.springframework.kafka.listener.CommonErrorHandler)
- org.springframework.kafka.listener.RecoveringBatchErrorHandler (implements org.springframework.kafka.listener.ContainerAwareBatchErrorHandler)
- org.springframework.kafka.listener.SeekToCurrentErrorHandler (implements org.springframework.kafka.listener.ContainerAwareErrorHandler)
- org.springframework.kafka.listener.RetryingBatchErrorHandler (implements org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler)
- org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler (implements org.springframework.kafka.listener.ContainerAwareBatchErrorHandler)
- 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.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.kafka.core.KafkaAdmin (implements org.springframework.context.ApplicationContextAware, org.springframework.kafka.core.KafkaAdminOperations, org.springframework.beans.factory.SmartInitializingSingleton)
- 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.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.core.RoutingKafkaTemplate
- 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.test.utils.KafkaTestUtils
- org.springframework.kafka.support.KafkaUtils
- org.springframework.kafka.jdocs.started.noboot.Listener
- org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- org.springframework.kafka.retrytopic.ListenerContainerFactoryResolver
- 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.support.converter.JsonMessageConverter
- 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>)
- 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>)
- 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
- com.fasterxml.jackson.databind.module.SimpleModule (implements java.io.Serializable)
- org.springframework.kafka.support.serializer.ParseStringDeserializer<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.listener.PartitionPausingBackoffManager (implements org.springframework.context.ApplicationListener<E>, org.springframework.kafka.listener.KafkaConsumerBackoffManager)
- org.springframework.messaging.handler.annotation.support.PayloadMethodArgumentResolver (implements org.springframework.messaging.handler.invocation.HandlerMethodArgumentResolver)
- org.springframework.kafka.annotation.KafkaNullAwarePayloadArgumentResolver
- 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)
- 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.annotation.RetryableTopicAnnotationProcessor
- org.springframework.kafka.support.serializer.RetryingDeserializer<T> (implements org.apache.kafka.common.serialization.Deserializer<T>)
- org.springframework.kafka.retrytopic.RetryTopicBootstrapper
- org.springframework.kafka.retrytopic.RetryTopicConfiguration
- org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- org.springframework.kafka.annotation.RetryTopicConfigurationProvider
- org.springframework.kafka.retrytopic.RetryTopicConfigurer
- org.springframework.kafka.retrytopic.RetryTopicConstants
- org.springframework.kafka.retrytopic.RetryTopicHeaders
- org.springframework.kafka.retrytopic.RetryTopicInternalBeanNames
- org.springframework.kafka.listener.SeekUtils
- org.springframework.kafka.jdocs.started.noboot.Sender
- org.springframework.kafka.support.SendResult<K,V>
- org.springframework.kafka.support.serializer.SerializationUtils
- org.springframework.util.concurrent.SettableListenableFuture<T> (implements org.springframework.util.concurrent.ListenableFuture<T>)
- org.springframework.kafka.requestreply.RequestReplyFuture<K,V,R>
- org.springframework.kafka.requestreply.RequestReplyMessageFuture<K,V>
- org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture<K,V,P>
- 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)
- java.lang.Exception
- java.lang.RuntimeException
- org.springframework.core.NestedRuntimeException
- org.springframework.kafka.KafkaException
- org.springframework.kafka.listener.BatchListenerFailedException
- org.springframework.kafka.support.converter.ConversionException
- org.springframework.kafka.support.serializer.DeserializationException
- org.springframework.kafka.listener.KafkaBackoffException
- org.springframework.kafka.core.KafkaProducerException
- org.springframework.kafka.requestreply.KafkaReplyTimeoutException
- org.springframework.kafka.listener.ListenerExecutionFailedException
- org.springframework.kafka.listener.TimestampedException
- org.springframework.kafka.KafkaException
- org.springframework.core.NestedRuntimeException
- java.lang.RuntimeException
- java.lang.Exception
- 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>)
- org.springframework.kafka.support.TransactionSupport
- org.springframework.kafka.listener.WakingKafkaConsumerTimingAdjuster (implements org.springframework.kafka.listener.KafkaConsumerTimingAdjuster)
Interface Hierarchy
- org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
- org.springframework.kafka.support.Acknowledgment
- org.springframework.kafka.listener.AfterRollbackProcessor<K,V>
- org.springframework.kafka.listener.adapter.BatchToRecordAdapter<K,V>
- org.springframework.kafka.listener.adapter.BatchToRecordAdapter.Callback<K,V>
- java.util.function.BiConsumer<T,U>
- org.springframework.kafka.listener.ConsumerRecordRecoverer
- org.springframework.kafka.listener.ConsumerAwareRecordRecoverer
- org.springframework.kafka.listener.ConsumerRecordRecoverer
- java.util.function.BiFunction<T,U,R>
- org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor.AnnotationEnhancer
- org.springframework.kafka.support.mapping.ClassMapper
- org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- java.util.function.Consumer<T>
- org.springframework.kafka.retrytopic.RetryTopicConfigurer.EndpointProcessor
- org.springframework.kafka.core.ConsumerFactory<K,V>
- org.springframework.kafka.core.ConsumerFactory.Listener<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.config.ContainerCustomizer<K,V,C>
- org.springframework.kafka.listener.DelegatingMessageListener<T>
- org.springframework.kafka.listener.DeliveryAttemptAware
- org.springframework.kafka.listener.CommonErrorHandler
- org.springframework.kafka.retrytopic.DestinationTopicContainer
- org.springframework.kafka.retrytopic.DestinationTopicResolver
- org.springframework.kafka.retrytopic.DestinationTopicProcessor
- org.springframework.beans.factory.DisposableBean
- org.springframework.kafka.listener.MessageListenerContainer (also extends org.springframework.context.SmartLifecycle)
- org.springframework.kafka.listener.GenericMessageListenerContainer<K,V>
- org.springframework.kafka.listener.MessageListenerContainer (also extends org.springframework.context.SmartLifecycle)
- org.springframework.kafka.retrytopic.EndpointCustomizer
- org.springframework.util.concurrent.FailureCallback
- org.springframework.kafka.core.KafkaFailureCallback<K,V>
- org.springframework.kafka.core.KafkaSendCallback<K,V> (also extends org.springframework.util.concurrent.ListenableFutureCallback<T>)
- org.springframework.util.concurrent.ListenableFutureCallback<T> (also extends org.springframework.util.concurrent.SuccessCallback<T>)
- org.springframework.kafka.core.KafkaSendCallback<K,V> (also extends org.springframework.kafka.core.KafkaFailureCallback<K,V>)
- org.springframework.kafka.core.KafkaFailureCallback<K,V>
- java.util.function.Function<T,R>
- org.springframework.kafka.core.ConsumerPostProcessor<K,V>
- org.springframework.kafka.core.ProducerPostProcessor<K,V>
- 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.ListenerInvokingBatchErrorHandler
- org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
- org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
- org.springframework.kafka.listener.ErrorHandler
- org.springframework.kafka.listener.ConsumerAwareErrorHandler
- org.springframework.kafka.listener.RemainingRecordsErrorHandler
- org.springframework.kafka.listener.ContainerAwareErrorHandler
- org.springframework.kafka.listener.RemainingRecordsErrorHandler
- org.springframework.kafka.listener.ConsumerAwareErrorHandler
- org.springframework.kafka.listener.BatchErrorHandler
- org.springframework.kafka.listener.GenericMessageListener<T>
- 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.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.listener.BatchMessageListener<K,V>
- org.springframework.kafka.support.serializer.JsonTypeResolver
- org.springframework.kafka.core.KafkaAdminOperations
- org.springframework.kafka.listener.KafkaBackOffManagerFactory
- org.springframework.kafka.listener.KafkaConsumerBackoffManager
- org.springframework.kafka.listener.KafkaConsumerTimingAdjuster
- 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.kafka.config.KafkaStreamsInfrastructureCustomizer
- org.springframework.context.Lifecycle
- org.springframework.context.SmartLifecycle (also extends org.springframework.context.Phased)
- org.springframework.kafka.listener.MessageListenerContainer (also extends org.springframework.beans.factory.DisposableBean)
- org.springframework.kafka.listener.GenericMessageListenerContainer<K,V>
- org.springframework.kafka.listener.MessageListenerContainer (also extends org.springframework.beans.factory.DisposableBean)
- org.springframework.context.SmartLifecycle (also extends org.springframework.context.Phased)
- org.springframework.kafka.listener.ListenerContainerRegistry
- 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.core.Ordered
- org.springframework.kafka.config.StreamsBuilderFactoryBeanConfigurer
- org.springframework.context.Phased
- org.springframework.context.SmartLifecycle (also extends org.springframework.context.Lifecycle)
- org.springframework.kafka.listener.MessageListenerContainer (also extends org.springframework.beans.factory.DisposableBean)
- org.springframework.kafka.listener.GenericMessageListenerContainer<K,V>
- org.springframework.kafka.listener.MessageListenerContainer (also extends org.springframework.beans.factory.DisposableBean)
- org.springframework.context.SmartLifecycle (also extends org.springframework.context.Lifecycle)
- 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.config.StreamsBuilderFactoryBeanCustomizer
- org.springframework.util.concurrent.SuccessCallback<T>
- org.springframework.util.concurrent.ListenableFutureCallback<T> (also extends org.springframework.util.concurrent.FailureCallback)
- org.springframework.kafka.core.KafkaSendCallback<K,V> (also extends org.springframework.kafka.core.KafkaFailureCallback<K,V>)
- org.springframework.util.concurrent.ListenableFutureCallback<T> (also extends org.springframework.util.concurrent.FailureCallback)
- org.springframework.kafka.listener.ThreadStateProcessor
- org.springframework.kafka.listener.BatchInterceptor<K,V>
- org.springframework.kafka.listener.RecordInterceptor<K,V>
- org.springframework.kafka.listener.ConsumerAwareRecordInterceptor<K,V>
- org.springframework.transaction.TransactionManager
- org.springframework.transaction.PlatformTransactionManager
- org.springframework.kafka.transaction.KafkaAwareTransactionManager<K,V>
- org.springframework.transaction.PlatformTransactionManager
Annotation Type Hierarchy
- org.springframework.kafka.annotation.DltHandler (implements java.lang.annotation.Annotation)
- org.springframework.kafka.test.context.EmbeddedKafka (implements java.lang.annotation.Annotation)
- org.springframework.kafka.annotation.EnableKafka (implements java.lang.annotation.Annotation)
- org.springframework.kafka.annotation.EnableKafkaStreams (implements java.lang.annotation.Annotation)
- org.springframework.kafka.annotation.KafkaHandler (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.test.condition.LogLevels (implements java.lang.annotation.Annotation)
- org.springframework.kafka.annotation.PartitionOffset (implements java.lang.annotation.Annotation)
- org.springframework.kafka.annotation.RetryableTopic (implements java.lang.annotation.Annotation)
- org.springframework.kafka.annotation.TopicPartition (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.event.ConsumerStoppedEvent.Reason
- org.springframework.kafka.listener.ContainerProperties.AckMode
- org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
- org.springframework.kafka.listener.ContainerProperties.EOSMode
- org.springframework.kafka.retrytopic.DltStrategy
- org.springframework.kafka.retrytopic.FixedDelayStrategy
- org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
- org.springframework.kafka.KafkaException.Level
- org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
- org.springframework.kafka.listener.ListenerType
- org.springframework.kafka.support.LogIfLevelEnabled.Level
- org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
- org.springframework.kafka.retrytopic.TopicSuffixingStrategy
- java.lang.Enum<E> (implements java.lang.Comparable<T>, java.io.Serializable)