Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
C
- CASE_SENSITIVE - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- 
Set to false to make topic pattern matching case-insensitive.
- categories() - Element in annotation interface org.springframework.kafka.test.condition.LogLevels
- 
Category names representing Log4j or Logback categories to change.
- categories(String...) - Method in class org.springframework.kafka.test.rule.Log4j2LevelAdjuster
- ChainedKafkaTransactionManager<K,V> - Class in org.springframework.kafka.transaction
- 
Deprecated.
- ChainedKafkaTransactionManager(PlatformTransactionManager...) - Constructor for class org.springframework.kafka.transaction.ChainedKafkaTransactionManager
- 
Deprecated.Construct an instance with the providedPlatformTransactionManagers.
- checkBootstrap(Map<String, Object>) - Method in class org.springframework.kafka.core.KafkaResourceFactory
- 
Enhance the properties by calling theKafkaResourceFactory.setBootstrapServersSupplier(Supplier)and replace the bootstrap servers properties.
- checkDeserialization(ConsumerRecord<?, ?>, LogAccessor) - Static method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- 
Return aDeserializationExceptionif either the key or value failed deserialization; null otherwise.
- checkDeserializer(ConsumerFactory<K, V>, Properties, boolean, ClassLoader) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
- 
Determine whether the key or value deserializer is an instance ofErrorHandlingDeserializer.
- checkForErrors(ConsumerRecord<K, R>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- 
Check for errors in a reply.
- checkGroupId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- checkTopics() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- childStarted(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- childStarted(MessageListenerContainer) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
- 
Notify a parent container that a child container has started.
- childStopped(MessageListenerContainer, ConsumerStoppedEvent.Reason) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- childStopped(MessageListenerContainer, ConsumerStoppedEvent.Reason) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- childStopped(MessageListenerContainer, ConsumerStoppedEvent.Reason) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
- 
Notify a parent container that a child container has stopped.
- classes() - Element in annotation interface org.springframework.kafka.test.condition.LogLevels
- 
Classes representing Log4j categories to change.
- ClassMapper - Interface in org.springframework.kafka.support.mapping
- 
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
- CleanupConfig - Class in org.springframework.kafka.core
- 
Specifies time ofKafkaStreams.cleanUp()execution.
- CleanupConfig() - Constructor for class org.springframework.kafka.core.CleanupConfig
- CleanupConfig(boolean, boolean) - Constructor for class org.springframework.kafka.core.CleanupConfig
- cleanupOnStart() - Method in class org.springframework.kafka.core.CleanupConfig
- cleanupOnStop() - Method in class org.springframework.kafka.core.CleanupConfig
- clearConsumerGroupId() - Static method in class org.springframework.kafka.support.KafkaUtils
- 
Clear the group id for the consumer bound to this thread.
- clearThreadState() - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
- 
Optional method to clear thread state; will be called just before a consumer thread terminates.
- clearThreadState() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- clearThreadState() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
- 
Optional method to clear thread state; will be called just before a consumer thread terminates.
- clearThreadState() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- clearThreadState() - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
- clearThreadState() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
- clearThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- clearThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- clearThreadState(Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ThreadStateProcessor
- 
Call to clear thread-bound resources which were set up inThreadStateProcessor.setupThreadState(Consumer).
- clientIdPrefix() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
- 
When provided, overrides the client id property in the consumer factory configuration.
- clientInstanceId(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- close() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory.ExtendedKafkaConsumer
- close() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- close() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- close() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- close() - Method in class org.springframework.kafka.streams.HeaderEnricherProcessor
- close() - Method in class org.springframework.kafka.streams.messaging.MessagingProcessor
- close() - Method in class org.springframework.kafka.support.CompositeProducerInterceptor
- close() - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- close() - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- close() - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.JsonSerde
- close() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- close() - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
- close() - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- close() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- close(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory.ExtendedKafkaConsumer
- close(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- closeProducer(Producer<K, V>, boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
- closeThreadBoundProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
When usingDefaultKafkaProducerFactory.setProducerPerThread(boolean)(true), call this method to close and release this thread's producer.
- closeThreadBoundProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
- 
If the factory implementation uses thread-bound producers, call this method to close and release this thread's producer.
- clusterId() - Method in class org.springframework.kafka.core.KafkaAdmin
- clusterId() - Method in interface org.springframework.kafka.core.KafkaAdminOperations
- 
Return the cluster id, if available.
- clusterId() - Method in class org.springframework.kafka.core.KafkaTemplate
- 
Return the cluster id, if available.
- commit() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- committed(Set<TopicPartition>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- commitTransaction() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- CommonContainerStoppingErrorHandler - Class in org.springframework.kafka.listener
- 
ACommonErrorHandlerthat stops the container when an error occurs.
- CommonContainerStoppingErrorHandler() - Constructor for class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- 
Construct an instance with a defaultSimpleAsyncTaskExecutor.
- CommonContainerStoppingErrorHandler(Executor) - Constructor for class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- 
Construct an instance with the providedExecutor.
- CommonDelegatingErrorHandler - Class in org.springframework.kafka.listener
- 
An error handler that delegates to different error handlers, depending on the exception type.
- CommonDelegatingErrorHandler(CommonErrorHandler) - Constructor for class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- 
Construct an instance with a default error handler that will be invoked if the exception has no matches.
- CommonErrorHandler - Interface in org.springframework.kafka.listener
- 
Listener container error handling contract.
- commonHeaders(Acknowledgment, Consumer<?, ?>, Map<String, Object>, Object, Object, Object, Object, Object, Object) - Method in interface org.springframework.kafka.support.converter.MessageConverter
- 
Set up the common headers.
- CommonLoggingErrorHandler - Class in org.springframework.kafka.listener
- 
TheCommonErrorHandlerimplementation for logging exceptions.
- CommonLoggingErrorHandler() - Constructor for class org.springframework.kafka.listener.CommonLoggingErrorHandler
- CommonMixedErrorHandler - Class in org.springframework.kafka.listener
- 
ACommonErrorHandlerthat delegates to differentCommonErrorHandlers for record and batch listeners.
- CommonMixedErrorHandler(CommonErrorHandler, CommonErrorHandler) - Constructor for class org.springframework.kafka.listener.CommonMixedErrorHandler
- 
Construct an instance with the provided delegateCommonErrorHandlers.
- compact() - Method in class org.springframework.kafka.config.TopicBuilder
- 
Set theTopicConfig.CLEANUP_POLICY_CONFIGtoTopicConfig.CLEANUP_POLICY_COMPACT.
- CompositeBatchInterceptor<K,V> - Class in org.springframework.kafka.listener
- 
ABatchInterceptorthat delegates to one or moreBatchInterceptors in order.
- CompositeBatchInterceptor(BatchInterceptor<K, V>...) - Constructor for class org.springframework.kafka.listener.CompositeBatchInterceptor
- 
Construct an instance with the provided delegates.
- CompositeKafkaStreamsCustomizer - Class in org.springframework.kafka.config
- 
CompositeKafkaStreamsCustomizercustomizesKafkaStreamsby delegating to a list of providedKafkaStreamsCustomizer.
- CompositeKafkaStreamsCustomizer() - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- CompositeKafkaStreamsCustomizer(List<KafkaStreamsCustomizer>) - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- CompositeKafkaStreamsInfrastructureCustomizer - Class in org.springframework.kafka.config
- 
CompositeKafkaStreamsInfrastructureCustomizercustomizesKafkaStreamsby delegating to a list of providedKafkaStreamsInfrastructureCustomizer.
- CompositeKafkaStreamsInfrastructureCustomizer(KafkaStreamsInfrastructureCustomizer...) - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
- 
Construct an instance with the provided customizers.
- CompositeProducerInterceptor<K,V> - Class in org.springframework.kafka.support
- 
AProducerInterceptorthat delegates to a collection of interceptors.
- CompositeProducerInterceptor(ProducerInterceptor<K, V>...) - Constructor for class org.springframework.kafka.support.CompositeProducerInterceptor
- 
Construct an instance with the provided delegates toProducerInterceptors.
- CompositeProducerListener<K,V> - Class in org.springframework.kafka.support
- 
AProducerListenerthat delegates to a collection of listeners.
- CompositeProducerListener(ProducerListener<K, V>...) - Constructor for class org.springframework.kafka.support.CompositeProducerListener
- CompositeRecordInterceptor<K,V> - Class in org.springframework.kafka.listener
- 
ARecordInterceptorthat delegates to one or moreRecordInterceptors in order.
- CompositeRecordInterceptor(RecordInterceptor<K, V>...) - Constructor for class org.springframework.kafka.listener.CompositeRecordInterceptor
- 
Construct an instance with the provided delegates.
- concurrency() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
- 
Override the container factory'sconcurrencysetting for this listener.
- concurrency() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
- 
Concurrency for the retry and DLT containers; if not specified, the main container concurrency is used.
- concurrency(Integer) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- 
Configure the concurrency for the retry and DLT containers.
- ConcurrentContainerStoppedEvent - Class in org.springframework.kafka.event
- 
An event published when a concurrent container is stopped.
- ConcurrentContainerStoppedEvent(Object, ConsumerStoppedEvent.Reason) - Constructor for class org.springframework.kafka.event.ConcurrentContainerStoppedEvent
- 
Construct an instance with the provided source and container.
- ConcurrentKafkaListenerContainerFactory<K,V> - Class in org.springframework.kafka.config
- 
AKafkaListenerContainerFactoryimplementation to build aConcurrentMessageListenerContainer.
- ConcurrentKafkaListenerContainerFactory() - Constructor for class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
- ConcurrentMessageListenerContainer<K,V> - Class in org.springframework.kafka.listener
- 
Creates 1 or moreKafkaMessageListenerContainers based onconcurrency.
- ConcurrentMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- 
Construct an instance with the supplied configuration properties.
- conditionalSleep(Supplier<Boolean>, long) - Static method in class org.springframework.kafka.listener.ListenerUtils
- 
Sleep for the desired timeout, as long as shouldSleepCondition supplies true.
- conditionalSleepWithPoll(Supplier<Boolean>, long, Consumer<?, ?>) - Static method in class org.springframework.kafka.listener.ListenerUtils
- 
Sleep for the desired timeout, as long as shouldSleepCondition supplies true.
- config(String, String) - Method in class org.springframework.kafka.config.TopicBuilder
- 
Set a configuration option.
- configs(Map<String, String>) - Method in class org.springframework.kafka.config.TopicBuilder
- 
Set the configs.
- configure(C) - Method in interface org.springframework.kafka.config.ContainerCustomizer
- 
Configure the container.
- configure(Map<String, ?>) - Method in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- configure(Map<String, ?>) - Method in class org.springframework.kafka.support.CompositeProducerInterceptor
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerde
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
- configure(Map<String, ?>, boolean) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- configure(StreamsBuilderFactoryBean) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanConfigurer
- 
Configure the factory bean.
- configureBlockingRetries(RetryTopicConfigurationSupport.BlockingRetriesConfigurer) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method to configure blocking retries parameters such as exceptions to be retried and theBackOffto be used.
- configureBuilder(StreamsBuilder) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
- configureBuilder(StreamsBuilder) - Method in interface org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer
- 
Configure the builder.
- configureCustomizers(RetryTopicConfigurationSupport.CustomizersConfigurer) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method to configure customizers for components created by non-blocking retries' configuration, such asMessageListenerContainer,DeadLetterPublishingRecovererandDefaultErrorHandler.
- configureDeadLetterPublishingContainerFactory() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method to further configure theDeadLetterPublishingRecovererFactory.
- configureDelegate(Map<String, ?>, boolean, Deserializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
- configureDelegate(Map<String, ?>, boolean, Serializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- configureDelegate(Map<String, ?>, boolean, T) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- 
Configure the delegate.
- configureDestinationTopicResolver() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method to configure theDestinationTopicResolver.
- configureKafkaListeners(KafkaListenerEndpointRegistrar) - Method in interface org.springframework.kafka.annotation.KafkaListenerConfigurer
- 
Callback allowing aKafkaListenerEndpointRegistryand specificKafkaListenerEndpointinstances to be registered against the givenKafkaListenerEndpointRegistrar.
- configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- 
Create aHandlerAdapterfor this listener adapter.
- configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
- configureListenerContainerFactoryConfigurer() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method to further configure theListenerContainerFactoryConfigurer.
- configureRetryTopicConfigurer() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method if you need to configure theRetryTopicConfigurer.
- configureTopology(Topology) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
- configureTopology(Topology) - Method in interface org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer
- 
Configure the topology.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Subscribe a consumer to all the embedded topics.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
Subscribe a consumer to all the embedded topics.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Subscribe a consumer to all the embedded topics.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>, boolean) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Subscribe a consumer to all the embedded topics.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>, boolean) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
Subscribe a consumer to all the embedded topics.
- consumeFromAllEmbeddedTopics(Consumer<?, ?>, boolean) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Subscribe a consumer to all the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, boolean, String) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Subscribe a consumer to one of the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, boolean, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
Subscribe a consumer to one of the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, boolean, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Subscribe a consumer to one of the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, String) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Subscribe a consumer to one of the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
Subscribe a consumer to one of the embedded topics.
- consumeFromAnEmbeddedTopic(Consumer<?, ?>, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Subscribe a consumer to one of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, boolean, String...) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Subscribe a consumer to one or more of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, boolean, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
Subscribe a consumer to one or more of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, boolean, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Subscribe a consumer to one or more of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, String...) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Subscribe a consumer to one or more of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
Subscribe a consumer to one or more of the embedded topics.
- consumeFromEmbeddedTopics(Consumer<?, ?>, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Subscribe a consumer to one or more of the embedded topics.
- CONSUMER - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header for theConsumerobject.
- CONSUMER_AWARE - Enum constant in enum class org.springframework.kafka.listener.ListenerType
- 
Consumer aware.
- consumerAdded(String, Consumer<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory.Listener
- 
A new consumer was created.
- consumerAdded(String, Consumer<K, V>) - Method in class org.springframework.kafka.core.MicrometerConsumerListener
- ConsumerAwareListenerErrorHandler - Interface in org.springframework.kafka.listener
- 
An error handler that has access to the consumer.
- ConsumerAwareMessageListener<K,V> - Interface in org.springframework.kafka.listener
- 
Listener for handling individual incoming Kafka messages.
- ConsumerAwareRebalanceListener - Interface in org.springframework.kafka.listener
- 
A rebalance listener that provides access to the consumer object.
- ConsumerAwareRecordRecoverer - Interface in org.springframework.kafka.listener
- 
AConsumerRecordRecovererthat supports getting a reference to theConsumer.
- consumerFactory - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- ConsumerFactory<K,V> - Interface in org.springframework.kafka.core
- 
The strategy to produce aConsumerinstance.
- ConsumerFactory.Listener<K,V> - Interface in org.springframework.kafka.core
- 
Called whenever a consumer is added or removed.
- ConsumerFailedToStartEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer fails to start.
- ConsumerFailedToStartEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerFailedToStartEvent
- 
Construct an instance with the provided source and container.
- consumerGroupHeader(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
- 
Sets the name of the header that will be used to store the consumer group that failed to consume the original record.
- ConsumerPartitionPausedEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer partition is paused.
- ConsumerPartitionPausedEvent(Object, Object, TopicPartition) - Constructor for class org.springframework.kafka.event.ConsumerPartitionPausedEvent
- 
Construct an instance with the provided source and partition.
- ConsumerPartitionResumedEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer partition is resumed.
- ConsumerPartitionResumedEvent(Object, Object, TopicPartition) - Constructor for class org.springframework.kafka.event.ConsumerPartitionResumedEvent
- 
Construct an instance with the provided source and partition.
- ConsumerPausedEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer is paused.
- ConsumerPausedEvent(Object, Object, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerPausedEvent
- 
Construct an instance with the provided source and partitions.
- ConsumerPausedEvent(Object, Object, Collection<TopicPartition>, String) - Constructor for class org.springframework.kafka.event.ConsumerPausedEvent
- 
Construct an instance with the provided source and partitions.
- ConsumerPauseResumeEventPublisher - Interface in org.springframework.kafka.listener
- 
Objects that can publish consumer pause/resume events.
- ConsumerPostProcessor<K,V> - Interface in org.springframework.kafka.core
- 
Called by consumer factories to perform post processing on newly created consumers.
- ConsumerProperties - Class in org.springframework.kafka.listener
- 
Common consumer properties.
- ConsumerProperties(String...) - Constructor for class org.springframework.kafka.listener.ConsumerProperties
- 
Create properties for a container that will subscribe to the specified topics.
- ConsumerProperties(Pattern) - Constructor for class org.springframework.kafka.listener.ConsumerProperties
- 
Create properties for a container that will subscribe to topics matching the specified pattern.
- ConsumerProperties(TopicPartitionOffset...) - Constructor for class org.springframework.kafka.listener.ConsumerProperties
- 
Create properties for a container that will assign itself the provided topic partitions.
- consumerProps(String, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
- 
Set up test properties for an<Integer, String>consumer.
- consumerProps(String, String, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
- 
Set up test properties for an<Integer, String>consumer.
- consumerProps(String, String, EmbeddedKafkaBroker) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
- 
Set up test properties for an<Integer, String>consumer.
- ConsumerRecordKeyCondition(K) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyCondition
- ConsumerRecordKeyMatcher(K) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
- ConsumerRecordKeyValueCondition(K, V) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyValueCondition
- ConsumerRecordMetadata - Class in org.springframework.kafka.listener.adapter
- 
Used to provide a listener method argument when the user supplies such a parameter.
- ConsumerRecordMetadata(RecordMetadata, TimestampType) - Constructor for class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- ConsumerRecordPartitionCondition(int) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordPartitionCondition
- ConsumerRecordPartitionMatcher(int) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
- ConsumerRecordRecoverer - Interface in org.springframework.kafka.listener
- 
ABiConsumerextension for recovering consumer records.
- ConsumerRecordTimestampCondition(TimestampType, long) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordTimestampCondition
- ConsumerRecordTimestampMatcher(TimestampType, long) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordTimestampMatcher
- ConsumerRecordValueCondition(V) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordValueCondition
- ConsumerRecordValueMatcher(V) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordValueMatcher
- consumerRemoved(String, Consumer<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory.Listener
- 
An existing consumer was removed.
- consumerRemoved(String, Consumer<K, V>) - Method in class org.springframework.kafka.core.MicrometerConsumerListener
- ConsumerResumedEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer is resumed.
- ConsumerResumedEvent(Object, Object, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerResumedEvent
- 
Construct an instance with the provided source and partitions.
- ConsumerRetryAuthEvent - Class in org.springframework.kafka.event
- 
An event published when authentication or authorization of a consumer fails and is being retried.
- ConsumerRetryAuthEvent(Object, Object, ConsumerRetryAuthEvent.Reason) - Constructor for class org.springframework.kafka.event.ConsumerRetryAuthEvent
- 
Construct an instance with the provided source and container.
- ConsumerRetryAuthEvent.Reason - Enum Class in org.springframework.kafka.event
- 
Reasons for retrying auth a consumer.
- ConsumerRetryAuthSuccessfulEvent - Class in org.springframework.kafka.event
- 
An event published when authentication or authorization has been retried successfully.
- ConsumerRetryAuthSuccessfulEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerRetryAuthSuccessfulEvent
- 
Construct an instance with the provided source and container.
- ConsumerSeekAware - Interface in org.springframework.kafka.listener
- 
Listeners that implement this interface are provided with aConsumerSeekAware.ConsumerSeekCallbackwhich can be used to perform a seek operation.
- ConsumerSeekAware.ConsumerSeekCallback - Interface in org.springframework.kafka.listener
- 
A callback that a listener can invoke to seek to a specific offset.
- ConsumerStartedEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer has started.
- ConsumerStartedEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerStartedEvent
- 
Construct an instance with the provided source and container.
- ConsumerStartingEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer is initializing.
- ConsumerStartingEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerStartingEvent
- 
Construct an instance with the provided source and container.
- ConsumerStoppedEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer is stopped.
- ConsumerStoppedEvent(Object, Object, ConsumerStoppedEvent.Reason) - Constructor for class org.springframework.kafka.event.ConsumerStoppedEvent
- 
Construct an instance with the provided source and container.
- ConsumerStoppedEvent.Reason - Enum Class in org.springframework.kafka.event
- 
Reasons for stopping a consumer.
- ConsumerStoppingEvent - Class in org.springframework.kafka.event
- 
An event published when a consumer is stopped.
- ConsumerStoppingEvent(Object, Object, Consumer<?, ?>, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerStoppingEvent
- 
Construct an instance with the provided source, consumer and partitions.
- ContainerCustomizer<K,V, - Interface in org.springframework.kafka.configC> 
- 
Called by the container factory after the container is created and configured.
- containerFactory() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
- 
The bean name of theKafkaListenerContainerFactoryto use to create the message listener container responsible to serve this endpoint.
- containerGroup() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
- 
If provided, the listener container for this listener will be added to a bean with this value as its name, of typeCollection<MessageListenerContainer>.
- ContainerGroup - Class in org.springframework.kafka.listener
- 
A group of listener containers.
- ContainerGroup(String) - Constructor for class org.springframework.kafka.listener.ContainerGroup
- 
Construct an instance with the provided name.
- ContainerGroup(String, List<MessageListenerContainer>) - Constructor for class org.springframework.kafka.listener.ContainerGroup
- 
Construct an instance with the provided name and containers.
- ContainerGroup(String, MessageListenerContainer...) - Constructor for class org.springframework.kafka.listener.ContainerGroup
- 
Construct an instance with the provided name and containers.
- ContainerGroupSequencer - Class in org.springframework.kafka.listener
- 
Sequence the starting of container groups when all containers in the previous group are idle.
- ContainerGroupSequencer(ListenerContainerRegistry, long, String...) - Constructor for class org.springframework.kafka.listener.ContainerGroupSequencer
- 
Set containers in each group to not auto start.
- ContainerPartitionPausingBackOffManager - Class in org.springframework.kafka.listener
- 
A manager that backs off consumption for a given topic if the timestamp provided is not due.
- ContainerPartitionPausingBackOffManager(ListenerContainerRegistry, BackOffHandler) - Constructor for class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManager
- 
Construct an instance with the provided registry and back off handler.
- ContainerPartitionPausingBackOffManagerFactory - Class in org.springframework.kafka.listener
- 
A factory forContainerPartitionPausingBackOffManager.
- ContainerPartitionPausingBackOffManagerFactory(ListenerContainerRegistry, ApplicationContext) - Constructor for class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManagerFactory
- 
Construct an instance with the provided properties.
- ContainerPausingBackOffHandler - Class in org.springframework.kafka.listener
- 
ABackOffHandlerthat pauses the container for the backoff.
- ContainerPausingBackOffHandler(ListenerContainerPauseService) - Constructor for class org.springframework.kafka.listener.ContainerPausingBackOffHandler
- 
Create an instance with the providedListenerContainerPauseService.
- containerPostProcessor() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
- 
Set the bean name of aContainerPostProcessorto allow customizing the container after its creation and configuration.
- ContainerPostProcessor<K,V, - Interface in org.springframework.kafka.configC> 
- 
Called by the container factory after the container is created and configured.
- ContainerProperties - Class in org.springframework.kafka.listener
- 
Contains runtime properties for a listener container.
- ContainerProperties(String...) - Constructor for class org.springframework.kafka.listener.ContainerProperties
- 
Create properties for a container that will subscribe to the specified topics.
- ContainerProperties(Pattern) - Constructor for class org.springframework.kafka.listener.ContainerProperties
- 
Create properties for a container that will subscribe to topics matching the specified pattern.
- ContainerProperties(TopicPartitionOffset...) - Constructor for class org.springframework.kafka.listener.ContainerProperties
- 
Create properties for a container that will assign itself the provided topic partitions.
- ContainerProperties.AckMode - Enum Class in org.springframework.kafka.listener
- 
The offset commit behavior enumeration.
- ContainerProperties.AssignmentCommitOption - Enum Class in org.springframework.kafka.listener
- 
Offset commit behavior during assignment.
- ContainerProperties.EOSMode - Enum Class in org.springframework.kafka.listener
- 
Mode for exactly once semantics.
- ContainerStoppedEvent - Class in org.springframework.kafka.event
- 
An event published when a container is stopped.
- ContainerStoppedEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ContainerStoppedEvent
- 
Construct an instance with the provided source and container.
- ContainerTestUtils - Class in org.springframework.kafka.test.utils
- 
Utilities for testing listener containers.
- contains(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerGroup
- 
Return true if the provided container is in this group.
- contentTypeConverter() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
- 
Set the bean name of aSmartMessageConverter(such as theCompositeMessageConverter) to use in conjunction with theMessageHeaders.CONTENT_TYPEheader to perform the conversion to the required type.
- Context(String, List<DestinationTopic.Properties>) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
- ContinuationHandlerMethodArgumentResolver - Class in org.springframework.kafka.listener.adapter
- 
No-op resolver for method arguments of typeContinuation.
- ContinuationHandlerMethodArgumentResolver() - Constructor for class org.springframework.kafka.listener.adapter.ContinuationHandlerMethodArgumentResolver
- controlledShutdown() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
- CONVERSION_FAILURES - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing a list of conversion failures (for batch listeners only).
- ConversionException - Exception Class in org.springframework.kafka.support.converter
- 
Exception for conversions.
- ConversionException(String, Throwable) - Constructor for exception class org.springframework.kafka.support.converter.ConversionException
- 
Construct an instance with the provided properties.
- ConversionException(String, List<ConsumerRecord<?, ?>>, Throwable) - Constructor for exception class org.springframework.kafka.support.converter.ConversionException
- 
Construct an instance with the provided properties.
- ConversionException(String, ConsumerRecord<?, ?>, Throwable) - Constructor for exception class org.springframework.kafka.support.converter.ConversionException
- 
Construct an instance with the provided properties.
- ConversionException(String, Message<?>, Throwable) - Constructor for exception class org.springframework.kafka.support.converter.ConversionException
- 
Construct an instance with the provided properties.
- convert(ConsumerRecord<?, ?>, Type, List<ConversionException>) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- 
Convert the record value.
- convertFromInternal(Message<?>, Class<?>, Object) - Method in class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
- ConvertingMessageListener<V> - Class in org.springframework.kafka.listener.adapter
- 
AAcknowledgingConsumerAwareMessageListeneradapter that implements converting receivedConsumerRecordusing specifiedMessageConverterand then passes result to specifiedMessageListener.
- ConvertingMessageListener(MessageListener<?, V>, Class<V>) - Constructor for class org.springframework.kafka.listener.adapter.ConvertingMessageListener
- 
Construct an instance with the providedMessageListenerandClassas a desired type ofConsumerRecord's value after conversion.
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.ByteArrayJsonMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.BytesJsonMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
- 
Subclasses can convert the payload; by default, it's sent unchanged to Kafka.
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.ProjectingMessageConverter
- convertPayload(Message<?>) - Method in class org.springframework.kafka.support.converter.StringJsonMessageConverter
- copyWithConfigurationOverride(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
Copy properties of the instance and the given properties to create a new producer factory.
- copyWithConfigurationOverride(Map<String, Object>) - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Copy the properties of the instance and the given properties to create a new producer factory.
- copyWithType(TypeReference<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- 
Copies this deserializer with same configuration, except new target type reference is used.
- copyWithType(TypeReference<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerde
- 
Copies this serde with same configuration, except new target type reference is used.
- copyWithType(TypeReference<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- 
Copies this serializer with same configuration, except new target type reference is used.
- copyWithType(JavaType) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- 
Copies this deserializer with same configuration, except new target java type is used.
- copyWithType(JavaType) - Method in class org.springframework.kafka.support.serializer.JsonSerde
- 
Copies this serde with same configuration, except new target java type is used.
- copyWithType(JavaType) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- 
Copies this serializer with same configuration, except new target java type is used.
- copyWithType(Class<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- 
Copies this deserializer with same configuration, except new target type is used.
- copyWithType(Class<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerde
- 
Copies this serde with same configuration, except new target type is used.
- copyWithType(Class<? super X>) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- 
Copies this serializer with same configuration, except new target type reference is used.
- CORRELATION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing information to correlate requests/replies.
- CorrelationKey - Class in org.springframework.kafka.requestreply
- 
Wrapper for byte[] that can be used as a hash key.
- CorrelationKey(byte[]) - Constructor for class org.springframework.kafka.requestreply.CorrelationKey
- count() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
- COUNT - Enum constant in enum class org.springframework.kafka.listener.ContainerProperties.AckMode
- 
Commit pending offsets afterackCounthas been exceeded.
- COUNT_PROPERTY_NAME - Static variable in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
- 
The number of brokers forEmbeddedKafkaBroker.
- COUNT_TIME - Enum constant in enum class org.springframework.kafka.listener.ContainerProperties.AckMode
- create() - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- create() - Method in interface org.springframework.kafka.listener.KafkaBackOffManagerFactory
- create(String) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- create(Function<ProducerRecord<?, ?>, KafkaOperations<?, ?>>, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Method in interface org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory.DeadLetterPublisherCreator
- 
Create aDeadLetterPublishingRecovererusing the supplied properties.
- create(Headers, Exception, boolean, DeadLetterPublishingRecoverer.HeaderNames) - Method in interface org.springframework.kafka.listener.DeadLetterPublishingRecoverer.ExceptionHeadersCreator
- 
Create exception headers.
- create(KafkaOperations<?, ?>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- 
Create theRetryTopicConfigurationwith the provided template.
- create(EmbeddedKafka) - Static method in class org.springframework.kafka.test.EmbeddedKafkaBrokerFactory
- 
Create anEmbeddedKafkaBrokerbased on theEmbeddedKafkaannotation.
- create(EmbeddedKafka, Function<String, String>) - Static method in class org.springframework.kafka.test.EmbeddedKafkaBrokerFactory
- 
Create anEmbeddedKafkaBrokerbased on theEmbeddedKafkaannotation.
- createAccessor(Message<?>) - Method in class org.springframework.kafka.support.KafkaMessageHeaderAccessor
- createAdmin() - Method in class org.springframework.kafka.core.KafkaAdmin
- 
Creates a newAdminclient instance using theAdminClientclass.
- createClientMetrics(C, List<Tag>) - Method in class org.springframework.kafka.core.KafkaMetricsSupport
- 
Create aio.micrometer.core.instrument.binder.kafka.KafkaMetricsinstance for the provided Kafka client and metric tags.
- createClientMetrics(KafkaStreams, List<Tag>) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- createComponentFactory() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Override this method to provide a subclass ofRetryTopicComponentFactorywith different component implementations or subclasses.
- createConsumer() - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Create a consumer with the group id and client id as configured in the properties.
- createConsumer(String) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Create a consumer, appending the suffix to theclient.idproperty, if present.
- createConsumer(String, String) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Create a consumer with an explicit group id; in addition, the client id suffix is appended to theclient.idproperty, if both are present.
- createConsumer(String, String, String) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Create a consumer with an explicit group id; in addition, the client id suffix is appended to the clientIdPrefix which overrides theclient.idproperty, if present.
- createConsumer(String, String, String) - Method in class org.springframework.kafka.mock.MockConsumerFactory
- createConsumer(String, String, String, Properties) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Create a consumer with an explicit group id; in addition, the client id suffix is appended to the clientIdPrefix which overrides theclient.idproperty, if present.
- createConsumer(String, String, String, Properties) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createConsumer(String, String, String, Properties) - Method in class org.springframework.kafka.mock.MockConsumerFactory
- createContainer(String...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(String...) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
- 
Create and configure a container without a listener; used to create containers that are not used for KafkaListener annotations.
- createContainer(Pattern) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(Pattern) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
- 
Create and configure a container without a listener; used to create containers that are not used for KafkaListener annotations.
- createContainer(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(TopicPartitionOffset...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createContainer(TopicPartitionOffset...) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
- 
Create and configure a container without a listener; used to create containers that are not used for KafkaListener annotations.
- createContainerInstance(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- 
Create an empty container instance.
- createContainerInstance(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
- createContext(long, String, TopicPartition, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.KafkaConsumerBackoffManager
- createDefaultErrorHandlerInstance(DeadLetterPublishingRecoverer) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- createDelegates(String, Map<String, ?>, boolean) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- createDelegates(String, Map<String, ?>, boolean) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- createEndpointCustomizer() - Method in class org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- createEndpointCustomizer(EndpointHandlerMethod, DestinationTopic.Properties) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createErrorHandler(DeadLetterPublishingRecoverer) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- createHandlerMethodWith(Object, Method) - Static method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createHandlerMethodWith(Object, String) - Static method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createInstance() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- createInstanceAndConfigure(Map<String, ?>, boolean, Map<String, Deserializer<?>>, String, String) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- createInstanceAndConfigure(Map<String, ?>, boolean, Map<String, Serializer<?>>, String, String) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- createInternalRetryTopicClock() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- 
Create aClockinstance that will be used for all time-related operations in the retry topic processes.
- createInvocableHandlerMethod(Object, Method) - Method in class org.springframework.kafka.listener.adapter.KafkaMessageHandlerMethodFactory
- createKafkaConsumer(String, String, String, Properties) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createKafkaConsumer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- createKafkaProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
Subclasses must return a raw producer which will be wrapped in aDefaultKafkaProducerFactory.CloseSafeProducer.
- createListenerContainer(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- createListenerContainer(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
- 
Create aMessageListenerContainerfor the givenKafkaListenerEndpoint.
- createListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- 
Create and start a newMessageListenerContainerusing the specified factory.
- createManagerFor(Collection<T>, Collection<T>) - Static method in class org.springframework.kafka.support.AllowDenyCollectionManager
- createManagerFor(Collection<T>, Collection<T>, Collection<Predicate<T>>) - Static method in class org.springframework.kafka.support.AllowDenyCollectionManager
- createMappings(String) - Static method in class org.springframework.kafka.support.serializer.JsonSerializer
- createMessageListener(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- 
Create aMessageListenerthat is able to serve this endpoint for the specified container.
- createMessageListener(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- createMessageListenerInstance(MessageConverter) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- 
Create an emptyMessagingMessageListenerAdapterinstance.
- createMessagingErrorMessage(String, Object) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- createNewTopicBeans(Collection<String>, RetryTopicConfiguration.TopicCreation) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- createNonTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createNonTransactionalProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Create a non-transactional producer.
- createNonTransactionalProducer() - Method in class org.springframework.kafka.mock.MockProducerFactory
- createOffsetAndMetadata(MessageListenerContainer, long) - Static method in class org.springframework.kafka.listener.ListenerUtils
- 
Create a newOffsetAndMetadatausing the given container and offset.
- createOrModifyTopics(NewTopic...) - Method in class org.springframework.kafka.core.KafkaAdmin
- createOrModifyTopics(NewTopic...) - Method in interface org.springframework.kafka.core.KafkaAdminOperations
- 
Create topics if they don't exist or increase the number of partitions if needed.
- createProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Create a producer which will be transactional if the factory is so configured.
- createProducer() - Method in class org.springframework.kafka.mock.MockProducerFactory
- createProducer(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createProducer(String) - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Create a producer with an overridden transaction id prefix.
- createProducer(String) - Method in class org.springframework.kafka.mock.MockProducerFactory
- createProducerRecord(ConsumerRecord<?, ?>, TopicPartition, Headers, byte[], byte[]) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
- 
Subclasses can override this method to customize the producer record to send to the DLQ.
- createProperties() - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory
- createRawConsumer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- 
Create aConsumer.
- createRawProducer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- createRetryTopicNamesProvider(DestinationTopic.Properties) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory
- createRetryTopicNamesProvider(DestinationTopic.Properties) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory
- createSimpleLoggingConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- 
Return default implementation ofConsumerRebalanceListenerinstance.
- createTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
Subclasses must return a producer from theDefaultKafkaProducerFactory.getCache()or a new raw producer wrapped in aDefaultKafkaProducerFactory.CloseSafeProducer.
- createTransactionalProducer(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- customBackoff(SleepingBackOffPolicy<?>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- 
Configure a customSleepingBackOffPolicy.
- customize(KafkaStreams) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
- customize(KafkaStreams) - Method in interface org.springframework.kafka.config.KafkaStreamsCustomizer
- 
Customize the instance ofKafkaStreamsafterStreamsBuilderFactoryBeanhas applied its default configurations.
- customizeAndRegisterTopics(RetryTopicNamesProviderFactory.RetryTopicNamesProvider, MethodKafkaListenerEndpoint<?, ?>) - Method in class org.springframework.kafka.retrytopic.EndpointCustomizerFactory
- customizeContainer(C, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- customizeDeadLetterPublishingRecoverer(Consumer<DeadLetterPublishingRecoverer>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
- 
Customize theDeadLetterPublishingRecovererthat will be used to forward the records to the retry topics and DLT.
- customizeEndpointAndCollectTopics(T) - Method in interface org.springframework.kafka.retrytopic.EndpointCustomizer
- 
Customize the endpoint and return the topic names generated for this endpoint.
- customizeErrorHandler(Consumer<DefaultErrorHandler>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
- 
Customize theCommonErrorHandlerinstances that will be used for the feature.
- customizeListenerContainer(Consumer<ConcurrentMessageListenerContainer<?, ?>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
- 
Customize theConcurrentMessageListenerContainerinstances created for the retry and DLT consumers.
- CustomizersConfigurer() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.CustomizersConfigurer
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
ChainedTransactionManagerjavadocs.