A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes All Packages

A

abortTransaction() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
AbstractConsumerSeekAware - Class in org.springframework.kafka.listener
Manages the ConsumerSeekAware.ConsumerSeekCallback s for the listener.
AbstractConsumerSeekAware() - Constructor for class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
AbstractDelegatingMessageListenerAdapter<T> - Class in org.springframework.kafka.listener.adapter
Top level class for all listener adapters.
AbstractDelegatingMessageListenerAdapter(T) - Constructor for class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
AbstractFilteringMessageListener<K,​V,​T> - Class in org.springframework.kafka.listener.adapter
An abstract message listener adapter that implements record filter logic via a RecordFilterStrategy.
AbstractFilteringMessageListener(T, RecordFilterStrategy<K, V>) - Constructor for class org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener
 
AbstractJavaTypeMapper - Class in org.springframework.kafka.support.converter
Abstract type mapper.
AbstractJavaTypeMapper() - Constructor for class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
AbstractKafkaHeaderMapper - Class in org.springframework.kafka.support
Base for Kafka header mappers.
AbstractKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper
 
AbstractKafkaHeaderMapper.HeaderMatcher - Interface in org.springframework.kafka.support
A matcher for headers.
AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher - Class in org.springframework.kafka.support
A matcher that never matches a set of headers.
AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher - Class in org.springframework.kafka.support
A pattern-based header matcher that matches if the specified header matches the specified simple pattern.
AbstractKafkaListenerContainerFactory<C extends AbstractMessageListenerContainer<K,​V>,​K,​V> - Class in org.springframework.kafka.config
Base KafkaListenerContainerFactory for Spring's base container implementation.
AbstractKafkaListenerContainerFactory() - Constructor for class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
AbstractKafkaListenerEndpoint<K,​V> - Class in org.springframework.kafka.config
Base model for a Kafka listener endpoint.
AbstractKafkaListenerEndpoint() - Constructor for class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
AbstractMessageListenerContainer<K,​V> - Class in org.springframework.kafka.listener
The base implementation for the MessageListenerContainer.
AbstractMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.AbstractMessageListenerContainer
Construct an instance with the provided factory and properties.
AbstractRetryingMessageListenerAdapter<K,​V,​T> - Class in org.springframework.kafka.listener.adapter
Base class for retrying message listener adapters.
AbstractRetryingMessageListenerAdapter(T, RetryTemplate) - Constructor for class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
Construct an instance with the supplied retry template.
AbstractRetryingMessageListenerAdapter(T, RetryTemplate, RecoveryCallback<? extends Object>) - Constructor for class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
Construct an instance with the supplied template and callback.
ABSwitchCluster - Class in org.springframework.kafka.core
A Supplier for bootstrap servers that can toggle between 2 lists of servers.
ABSwitchCluster(String, String) - Constructor for class org.springframework.kafka.core.ABSwitchCluster
Construct an instance with primary and secondary bootstrap servers.
accept(ConsumerRecord<?, ?>, Exception) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
 
acceptIfCondition(boolean, T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the condition is true.
acceptIfCondition(boolean, T, Consumer<T>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke Consumer.accept(Object) with the value if the condition is true.
acceptIfHasText(String, Consumer<String>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfHasText(T, String, BiConsumer<T, String>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the value argument is not null or empty.
acceptIfNotEmpty(List<T>, Consumer<List<T>>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfNotEmpty(T[], Consumer<T[]>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null or empty.
acceptIfNotNull(T1, T2, BiConsumer<T1, T2>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke BiConsumer.accept(Object, Object) with the arguments if the t2 argument is not null.
acceptIfNotNull(T, Consumer<T>) - Method in class org.springframework.kafka.support.JavaUtils
Invoke Consumer.accept(Object) with the value if it is not null.
acknowledge() - Method in interface org.springframework.kafka.support.Acknowledgment
Invoked when the record or batch for which the acknowledgment has been created has been processed.
ACKNOWLEDGING - org.springframework.kafka.listener.ListenerType
Acknowledging.
ACKNOWLEDGING_CONSUMER_AWARE - org.springframework.kafka.listener.ListenerType
Acknowledging and consumer aware.
AcknowledgingConsumerAwareMessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
AcknowledgingMessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
Acknowledgment - Interface in org.springframework.kafka.support
Handle for acknowledging the processing of a ConsumerRecord.
ACKNOWLEDGMENT - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for the Acknowledgment.
adapt(List<Message<?>>, List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>, BatchToRecordAdapter.Callback<K, V>) - Method in interface org.springframework.kafka.listener.adapter.BatchToRecordAdapter
Adapt the list and invoke the callback for each message.
adapt(List<Message<?>>, List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>, BatchToRecordAdapter.Callback<K, V>) - Method in class org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter
 
AdapterUtils - Class in org.springframework.kafka.listener.adapter
Utilities for listener adapters.
ADD_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonSerializer
Kafka config property for disabling adding type headers.
ADD_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
Kafka config property for enabling/disabling adding type headers.
addDelegate(String, Deserializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
 
addDelegate(String, Serializer<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
 
addDelegate(ProducerListener<K, V>) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
addHeader(Headers, String, Class<?>) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
additionalHeaders() - Method in interface org.springframework.kafka.listener.adapter.ReplyHeadersConfigurer
A map of additional headers to add to the reply message.
addKafkaStreamsCustomizers(List<KafkaStreamsCustomizer>) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
 
addKafkaStreamsCustomizers(KafkaStreamsInfrastructureCustomizer...) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
Add customizers.
addListener(int, ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
Add a listener at a specific index.
addListener(int, ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Add a listener at a specific index.
addListener(int, ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Add a listener at a specific index.
addListener(int, ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
Add a listener at a specific index.
addListener(StreamsBuilderFactoryBean.Listener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Add a StreamsBuilderFactoryBean.Listener which will be called after starting and stopping the streams.
addListener(ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
Add a listener.
addListener(ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Add a listener.
addListener(ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Add a listener.
addListener(ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
Add a listener.
addMatchers(AbstractKafkaHeaderMapper.HeaderMatcher...) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
Subclasses can invoke this to add custom AbstractKafkaHeaderMapper.HeaderMatchers.
addNotRetryableException(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
addNotRetryableExceptions(Class<? extends Exception>...) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Add exception types to the default list.
addPostProcessor(ConsumerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
Add a post processor.
addPostProcessor(ConsumerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
addPostProcessor(ProducerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
addPostProcessor(ProducerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
Add a post processor.
addTopics(String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Add topics to the existing broker(s) using the configured number of partitions.
addTopics(NewTopic...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Add topics to the existing broker(s).
addTopicsWithResults(String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Add topics to the existing broker(s) using the configured number of partitions.
addTopicsWithResults(NewTopic...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Add topics to the existing broker(s) and returning a map of results.
addToStringClasses(String...) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Add class names that the outbound mapper should perform toString() operations on before mapping.
addTrustedPackages(String...) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
Specify a set of packages to trust during deserialization.
addTrustedPackages(String...) - Method in interface org.springframework.kafka.support.converter.Jackson2JavaTypeMapper
 
addTrustedPackages(String...) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Add packages to the trusted packages list (default java.util, java.lang) used when constructing objects from JSON.
addTrustedPackages(String...) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Add trusted packages for deserialization.
addTypeInfo - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
 
adjustLogLevels(String, List<Class<?>>, List<String>, Level) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
 
after() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
 
afterAll(ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
 
afterAll(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
 
afterEach(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
 
afterPropertiesSet() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
afterPropertiesSet() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
afterPropertiesSet() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
 
afterPropertiesSet() - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
 
afterPropertiesSet() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
afterPropertiesSet() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
AfterRollbackProcessor<K,​V> - Interface in org.springframework.kafka.listener
Invoked by a listener container with remaining, unprocessed, records (including the failed record).
afterSingletonsInstantiated() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
afterSingletonsInstantiated() - Method in class org.springframework.kafka.core.KafkaAdmin
 
afterSingletonsInstantiated() - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
AGGREGATED_RESULTS_TOPIC - Static variable in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
Pseudo topic name for the "outer" ConsumerRecord that has the aggregated results in its value after a normal release by the release strategy.
AggregatingReplyingKafkaTemplate<K,​V,​R> - Class in org.springframework.kafka.requestreply
A replying template that aggregates multiple replies with the same correlation id.
AggregatingReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, Collection<ConsumerRecord<K, R>>>, BiPredicate<List<ConsumerRecord<K, R>>, Boolean>) - Constructor for class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
Construct an instance using the provided parameter arguments.
ALPHA - org.springframework.kafka.listener.ContainerProperties.EOSMode
'transactional.id' fencing (0.11 - 2.4 brokers).
ALWAYS - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
Always commit the current offset during partition assignment.
apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.kafka.test.rule.Log4j2LevelAdjuster
 
asProperties() - Method in class org.springframework.kafka.config.KafkaStreamsConfiguration
Return the configuration map as a Properties.
assignment() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
assignReplicas(int, List<Integer>) - Method in class org.springframework.kafka.config.TopicBuilder
Add an individual replica assignment.
AUTH - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
An authorization exception occurred.
autoStartup() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
Set to true or false, to override the default setting in the container factory.

B

BATCH - org.springframework.kafka.listener.ContainerProperties.AckMode
Commit the offsets of all records returned by the previous poll after they all have been processed by the listener.
BATCH_CONVERTED_HEADERS - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for a list of Maps of converted native Kafka headers.
BatchAcknowledgingConsumerAwareMessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling a batch of incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
BatchAcknowledgingMessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling a batch of incoming Kafka messages, propagating an acknowledgment handle that recipients can invoke when the message has been processed.
BatchConsumerAwareMessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling a batch of incoming Kafka messages; the list is created from the consumer records object returned by a poll.
BatchErrorHandler - Interface in org.springframework.kafka.listener
Handles errors thrown during the execution of a BatchMessageListener.
BatchInterceptor<K,​V> - Interface in org.springframework.kafka.listener
An interceptor for batches of records.
BatchListenerFailedException - Exception in org.springframework.kafka.listener
An exception thrown by user code to inform the framework which record in a batch has failed.
BatchListenerFailedException(String, int) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
Construct an instance with the provided properties.
BatchListenerFailedException(String, Throwable, int) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
Construct an instance with the provided properties.
BatchListenerFailedException(String, Throwable, ConsumerRecord<?, ?>) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
Construct an instance with the provided properties.
BatchListenerFailedException(String, ConsumerRecord<?, ?>) - Constructor for exception org.springframework.kafka.listener.BatchListenerFailedException
Construct an instance with the provided properties.
BatchLoggingErrorHandler - Class in org.springframework.kafka.listener
Simple handler that invokes a LoggingErrorHandler for each record.
BatchLoggingErrorHandler() - Constructor for class org.springframework.kafka.listener.BatchLoggingErrorHandler
 
BatchMessageConverter - Interface in org.springframework.kafka.support.converter
A Kafka-specific Message converter strategy.
BatchMessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling a batch of incoming Kafka messages; the list is created from the consumer records object returned by a poll.
BatchMessagingMessageConverter - Class in org.springframework.kafka.support.converter
A Messaging MessageConverter implementation used with a batch message listener; the consumer record values are extracted into a collection in the message payload.
BatchMessagingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Create an instance that does not convert the record values.
BatchMessagingMessageConverter(RecordMessageConverter) - Constructor for class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Create an instance that converts record values using the supplied converter.
BatchMessagingMessageListenerAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
A MessageListener adapter that invokes a configurable HandlerAdapter; used when the factory is configured for the listener to receive batches of messages.
BatchMessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Create an instance with the provided parameters.
BatchMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Create an instance with the provided parameters.
BatchToRecordAdapter<K,​V> - Interface in org.springframework.kafka.listener.adapter
An adapter that adapts a batch listener to a record listener method.
BatchToRecordAdapter.Callback<K,​V> - Interface in org.springframework.kafka.listener.adapter
A callback for each message.
BEAN_NAME - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
beanRef() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
A pseudo bean name used in SpEL expressions within this annotation to reference the current bean within which this listener is defined.
before() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
 
beforeAll(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
 
beforeEach(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
 
BEGINNING - org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
Seek to the beginning.
beginningOffsets(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
beginTransaction() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
BETA - org.springframework.kafka.listener.ContainerProperties.EOSMode
fetch-offset-request fencing (2.5+ brokers).
bootstrapServersProperty() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
The property name to set with the bootstrap server addresses instead of the default "spring.embedded.kafka.brokers".
bounce(BrokerAddress) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
branch(Predicate<? super K, ? super V>, Consumer<? super KStream<K, V>>) - Method in class org.springframework.kafka.support.KafkaStreamBrancher
Defines a new branch.
BROKER_LIST_PROPERTY - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set the value of this property to a property name that should be set to the list of embedded broker addresses instead of "spring.embedded.kafka.brokers".
BrokerAddress - Class in org.springframework.kafka.test.core
Encapsulates the address of a Kafka broker.
BrokerAddress(String) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
 
BrokerAddress(String, int) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
 
BrokerAddress(BrokerEndPoint) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
 
brokerListProperty(String) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set the system property with this name to the list of broker addresses.
brokerProperties() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Properties in form key=value that should be added to the broker config before runs.
brokerProperties(Map<String, String>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Specify the properties to configure Kafka Broker before start, e.g.
brokerProperties(Map<String, String>) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
Specify the properties to configure Kafka Broker before start, e.g.
brokerPropertiesLocation() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Spring Resource url specifying the location of properties that should be added to the broker config.
brokerProperty(String, Object) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Specify a broker property.
brokerProperty(String, Object) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
Specify a broker property.
build() - Method in class org.springframework.kafka.config.TopicBuilder
 
buildConsumerRecordMetadata(Object) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
Build a ConsumerRecordMetadata from data which must be a ConsumerRecord.
buildConsumerRecordMetadataFromArray(Object...) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
Build a ConsumerRecordMetadata from the first ConsumerRecord in data, if any.
ByteArrayJsonMessageConverter - Class in org.springframework.kafka.support.converter
JSON Message converter - byte[] on output, String, Bytes, or byte[] on input.
ByteArrayJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.ByteArrayJsonMessageConverter
 
ByteArrayJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.ByteArrayJsonMessageConverter
 
BytesJsonMessageConverter - Class in org.springframework.kafka.support.converter
JSON Message converter - Bytes on output, String, Bytes, or byte[] on input.
BytesJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.BytesJsonMessageConverter
 
BytesJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.BytesJsonMessageConverter
 

C

categories() - Method in annotation type 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
A ChainedTransactionManager that has exactly one KafkaAwareTransactionManager in the chain.
ChainedKafkaTransactionManager(PlatformTransactionManager...) - Constructor for class org.springframework.kafka.transaction.ChainedKafkaTransactionManager
Construct an instance with the provided PlatformTransactionManagers.
checkBootstrap(Map<String, Object>) - Method in class org.springframework.kafka.core.KafkaResourceFactory
Enhance the properties by calling the KafkaResourceFactory.setBootstrapServersSupplier(Supplier) amd replace the bootstrap servers properties.
checkDeserialization(ConsumerRecord<?, ?>, LogAccessor) - Static method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Return a DeserializationException if either the key or value failed deserialization; null otherwise.
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
 
classes() - Method in annotation type org.springframework.kafka.test.condition.LogLevels
Classes representing Log4j categories to change.
ClassMapper - Interface in org.springframework.kafka.support.converter
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 of KafkaStreams.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.DefaultAfterRollbackProcessor
 
clearThreadState() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
 
clearThreadState() - Method in interface org.springframework.kafka.listener.GenericErrorHandler
Optional method to clear thread state; will be called just before a consumer thread terminates.
clearThreadState() - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
 
clearTransactionIdSuffix() - Static method in class org.springframework.kafka.support.TransactionSupport
 
clientIdPrefix() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
When provided, overrides the client id property in the consumer factory configuration.
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.HeaderEnricher
 
close() - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
 
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.DefaultKafkaProducerFactory.CloseSafeProducer
 
closeProducer(Producer<K, V>, boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
 
closeProducerFor(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
closeProducerFor(String) - Method in interface org.springframework.kafka.core.ProducerFactory
Remove the specified producer from the cache and close it.
closeThreadBoundProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
When using DefaultKafkaProducerFactory.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.
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
 
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.
compact() - Method in class org.springframework.kafka.config.TopicBuilder
Set the TopicConfig.CLEANUP_POLICY_CONFIG to TopicConfig.CLEANUP_POLICY_COMPACT.
CompositeBatchInterceptor<K,​V> - Class in org.springframework.kafka.listener
A BatchInterceptor that delegates to one or more BatchInterceptors 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
Composite KafkaStreamsCustomizer customizes KafkaStreams by delegating to a list of provided KafkaStreamsCustomizer.
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
Composite KafkaStreamsInfrastructureCustomizer customizes KafkaStreams by delegating to a list of provided KafkaStreamsInfrastructureCustomizer.
CompositeKafkaStreamsInfrastructureCustomizer(KafkaStreamsInfrastructureCustomizer...) - Constructor for class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
Construct an instance with the provided customizers.
CompositeProducerListener<K,​V> - Class in org.springframework.kafka.support
A ProducerListener that 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
A RecordInterceptor that delegates to one or more RecordInterceptors in order.
CompositeRecordInterceptor(RecordInterceptor<K, V>...) - Constructor for class org.springframework.kafka.listener.CompositeRecordInterceptor
Construct an instance with the provided delegates.
concurrency() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
Override the container factory's concurrency setting for this listener.
ConcurrentKafkaListenerContainerFactory<K,​V> - Class in org.springframework.kafka.config
ConcurrentKafkaListenerContainerFactory() - Constructor for class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
 
ConcurrentMessageListenerContainer<K,​V> - Class in org.springframework.kafka.listener
Creates 1 or more KafkaMessageListenerContainers based on concurrency.
ConcurrentMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
Construct an instance with the supplied configuration properties.
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, ?>, 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
Overridden to avoid deprecation warnings.
configure(StreamsBuilderFactoryBean) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanCustomizer
Deprecated.
Configure the factory bean.
configureBuilder(StreamsBuilder) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsInfrastructureCustomizer
 
configureBuilder(StreamsBuilder) - Method in interface org.springframework.kafka.config.KafkaStreamsInfrastructureCustomizer
Configure the builder.
configureKafkaListeners(KafkaListenerEndpointRegistrar) - Method in interface org.springframework.kafka.annotation.KafkaListenerConfigurer
Callback allowing a KafkaListenerEndpointRegistry and specific KafkaListenerEndpoint instances to be registered against the given KafkaListenerEndpointRegistrar.
configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Create a HandlerAdapter for this listener adapter.
configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
 
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 class org.springframework.kafka.test.EmbeddedKafkaBroker
Subscribe a consumer to all the embedded topics.
consumeFromAnEmbeddedTopic(Consumer<?, ?>, String) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Subscribe a consumer to one of the embedded topics.
consumeFromEmbeddedTopics(Consumer<?, ?>, String...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Subscribe a consumer to one or more of the embedded topics.
CONSUMER - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for the Consumer object.
CONSUMER_AWARE - 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
 
ConsumerAwareBatchErrorHandler - Interface in org.springframework.kafka.listener
An error handler that has access to the consumer, for example to adjust offsets after an error.
ConsumerAwareErrorHandler - Interface in org.springframework.kafka.listener
An error handler that has access to the consumer, for example to adjust offsets after an error.
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.
consumerFactory - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
ConsumerFactory<K,​V> - Interface in org.springframework.kafka.core
The strategy to produce a Consumer instance(s).
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.
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, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerPausedEvent
Deprecated.
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, 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
A BiConsumer extension 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.
ConsumerResumedEvent(Object, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerResumedEvent
Deprecated.
ConsumerSeekAware - Interface in org.springframework.kafka.listener
Listeners that implement this interface are provided with a ConsumerSeekAware.ConsumerSeekCallback which 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) - Constructor for class org.springframework.kafka.event.ConsumerStoppedEvent
Deprecated.
ConsumerStoppedEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ConsumerStoppedEvent
Deprecated.
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 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.
ConsumerStoppingEvent(Object, Consumer<?, ?>, Collection<TopicPartition>) - Constructor for class org.springframework.kafka.event.ConsumerStoppingEvent
Deprecated.
ContainerAwareBatchErrorHandler - Interface in org.springframework.kafka.listener
An error handler that has access to the batch of records from the last poll the consumer, and the container.
ContainerAwareErrorHandler - Interface in org.springframework.kafka.listener
An error handler that has access to the unprocessed records from the last poll (including the failed record), the consumer, and the container.
ContainerCustomizer<K,​V,​C extends AbstractMessageListenerContainer<K,​V>> - Interface in org.springframework.kafka.config
Called by the container factory after the container is created and configured.
containerFactory() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
The bean name of the KafkaListenerContainerFactory to use to create the message listener container responsible to serve this endpoint.
containerGroup() - Method in annotation type 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 type Collection<MessageListenerContainer>.
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 in org.springframework.kafka.listener
The offset commit behavior enumeration.
ContainerProperties.AssignmentCommitOption - Enum in org.springframework.kafka.listener
Offset commit behavior during assignment.
ContainerProperties.EOSMode - Enum 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) - Constructor for class org.springframework.kafka.event.ContainerStoppedEvent
Deprecated.
ContainerStoppedEvent(Object, Object) - Constructor for class org.springframework.kafka.event.ContainerStoppedEvent
Construct an instance with the provided source and container.
ContainerStoppingBatchErrorHandler - Class in org.springframework.kafka.listener
A container error handler that stops the container after an exception is thrown by the listener.
ContainerStoppingBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.ContainerStoppingBatchErrorHandler
Construct an instance with a SimpleAsyncTaskExecutor.
ContainerStoppingBatchErrorHandler(Executor) - Constructor for class org.springframework.kafka.listener.ContainerStoppingBatchErrorHandler
Construct an instance with the provided Executor.
ContainerStoppingErrorHandler - Class in org.springframework.kafka.listener
A container error handler that stops the container after an exception is thrown by the listener.
ContainerStoppingErrorHandler() - Constructor for class org.springframework.kafka.listener.ContainerStoppingErrorHandler
 
ContainerStoppingErrorHandler(Executor) - Constructor for class org.springframework.kafka.listener.ContainerStoppingErrorHandler
 
ContainerTestUtils - Class in org.springframework.kafka.test.utils
Utilities for testing listener containers.
CONTEXT_ACKNOWLEDGMENT - Static variable in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
RetryContext attribute key for an acknowledgment if the listener is capable of acknowledging.
CONTEXT_CONSUMER - Static variable in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
RetryContext attribute key for the consumer if the listener is consumer-aware.
CONTEXT_RECORD - Static variable in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
RetryContext attribute key for the record.
controlledShutdown() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
 
ConversionException - Exception in org.springframework.kafka.support.converter
Exception for conversions.
ConversionException(String, Throwable) - Constructor for exception org.springframework.kafka.support.converter.ConversionException
 
convert(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Convert the record value.
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
 
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() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
 
COUNT - org.springframework.kafka.listener.ContainerProperties.AckMode
Commit pending offsets after ackCount has been exceeded.
COUNT_TIME - org.springframework.kafka.listener.ContainerProperties.AckMode
Commit pending offsets after ackCount has been exceeded or after ackTime has elapsed.
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 the client.id property, 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 the client.id property, 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 the client.id property, if present.
createConsumer(String, String, String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
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 the client.id property, if present.
createConsumer(String, String, String, Properties) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
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(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
 
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
 
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
 
createKafkaConsumer(String, String, String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Deprecated.
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 a DefaultKafkaProducerFactory.CloseSafeProducer.
createListenerContainer(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
createListenerContainer(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.config.KafkaListenerContainerFactory
createListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Create and start a new MessageListenerContainer using the specified factory.
createMappings(String) - Static method in class org.springframework.kafka.support.serializer.JsonSerializer
 
createMessageListener(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Create a MessageListener that 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 empty MessagingMessageListenerAdapter instance.
createMessagingErrorMessage(String, Object) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
createNonTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
createNonTransactionalProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
Create a non-transactional producer.
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(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.
createProducerRecord(ConsumerRecord<?, ?>, TopicPartition, Headers, byte[], boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Subclasses can override this method to customize the producer record to send to the DLQ.
createRawConsumer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Create a Consumer.
createRawProducer(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
createSimpleLoggingConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Return default implementation of ConsumerRebalanceListener instance.
createTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Subclasses must return a producer from the DefaultKafkaProducerFactory.getCache() or a new raw producer wrapped in a DefaultKafkaProducerFactory.CloseSafeProducer.
createTransactionalProducer(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
createTransactionalProducerForPartition() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
createTransactionalProducerForPartition(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
customize(KafkaStreams) - Method in class org.springframework.kafka.config.CompositeKafkaStreamsCustomizer
 
customize(KafkaStreams) - Method in interface org.springframework.kafka.config.KafkaStreamsCustomizer
 

D

DeadLetterPublishingRecoverer - Class in org.springframework.kafka.listener
A ConsumerRecordRecoverer that publishes a failed record to a dead-letter topic.
DeadLetterPublishingRecoverer(Map<Class<?>, KafkaOperations<? extends Object, ? extends Object>>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Create an instance with the provided templates and a default destination resolving function that returns a TopicPartition based on the original topic (appended with ".DLT") from the failed record, and the same partition as the failed record.
DeadLetterPublishingRecoverer(Map<Class<?>, KafkaOperations<? extends Object, ? extends Object>>, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Create an instance with the provided templates and destination resolving function, that receives the failed consumer record and the exception and returns a TopicPartition.
DeadLetterPublishingRecoverer(KafkaOperations<? extends Object, ? extends Object>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Create an instance with the provided template and a default destination resolving function that returns a TopicPartition based on the original topic (appended with ".DLT") from the failed record, and the same partition as the failed record.
DeadLetterPublishingRecoverer(KafkaOperations<? extends Object, ? extends Object>, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Create an instance with the provided template and destination resolving function, that receives the failed consumer record and the exception and returns a TopicPartition.
DeadLetterPublishingRecoverer(KafkaTemplate<? extends Object, ? extends Object>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
DeadLetterPublishingRecoverer(KafkaTemplate<? extends Object, ? extends Object>, BiFunction<ConsumerRecord<?, ?>, Exception, TopicPartition>) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
DEBUG - org.springframework.kafka.KafkaException.Level
Debug.
DEBUG - org.springframework.kafka.support.LogIfLevelEnabled.Level
Debug.
DEFAULT_BACK_OFF - Static variable in class org.springframework.kafka.listener.SeekUtils
The default back off - a FixedBackOff with 0 interval and SeekUtils.DEFAULT_MAX_FAILURES - 1 retry attempts.
DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for type information.
DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.kafka.config.StreamsBuilderFactoryBean
The default Duration of 10 seconds for close timeout.
DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.kafka.core.KafkaAdmin
The default close timeout duration as 10 seconds.
DEFAULT_CLOSE_TIMEOUT - Static variable in class org.springframework.kafka.core.ProducerFactoryUtils
The default close timeout (5 seconds).
DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for container object contents type information.
DEFAULT_KAFKA_LISTENER_CONTAINER_FACTORY_BEAN_NAME - Static variable in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
The bean name of the default KafkaListenerContainerFactory.
DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for map key type information.
DEFAULT_MAX_CONTENT_LOGGED - Static variable in class org.springframework.kafka.support.LoggingProducerListener
Default max content logged.
DEFAULT_MAX_FAILURES - Static variable in class org.springframework.kafka.listener.SeekUtils
The number of times a topic/partition/offset can fail before being rejected.
DEFAULT_MONITOR_INTERVAL - Static variable in class org.springframework.kafka.listener.ContainerProperties
The default monitorInterval (s).
DEFAULT_NO_POLL_THRESHOLD - Static variable in class org.springframework.kafka.listener.ContainerProperties
The default noPollThreshold.
DEFAULT_PHASE - Static variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
The default SmartLifecycle phase for listener containers 2147483547.
DEFAULT_PHYSICAL_CLOSE_TIMEOUT - Static variable in interface org.springframework.kafka.core.ProducerFactory
The default close timeout duration as 30 seconds.
DEFAULT_POLL_TIMEOUT - Static variable in class org.springframework.kafka.listener.ConsumerProperties
The default pollTimeout (ms).
DEFAULT_PORT - Static variable in class org.springframework.kafka.test.core.BrokerAddress
 
DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class org.springframework.kafka.listener.ContainerProperties
The default shutDownTimeout (ms).
DEFAULT_STREAMS_BUILDER_BEAN_NAME - Static variable in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
The bean name for auto-configured default StreamsBuilderFactoryBean.
DEFAULT_STREAMS_CONFIG_BEAN_NAME - Static variable in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
The bean name for the StreamsConfig to be used for the default StreamsBuilderFactoryBean bean definition.
DEFAULT_ZK_CONNECTION_TIMEOUT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
DefaultAfterRollbackProcessor<K,​V> - Class in org.springframework.kafka.listener
Default implementation of AfterRollbackProcessor.
DefaultAfterRollbackProcessor() - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
Construct an instance with the default recoverer which simply logs the record after 10 (maxFailures) have occurred for a topic/partition/offset.
DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
Construct an instance with the provided recoverer which will be called after 10 (maxFailures) have occurred for a topic/partition/offset.
DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
DefaultAfterRollbackProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff, KafkaOperations<?, ?>, boolean) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
DefaultAfterRollbackProcessor(BackOff) - Constructor for class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
Construct an instance with the default recoverer which simply logs the record after the backOff returns STOP for a topic/partition/offset.
DefaultBatchToRecordAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
The default BatchToRecordAdapter implementation; if the supplied recoverer throws an exception, the batch will be aborted; otherwise the next record will be processed.
DefaultBatchToRecordAdapter() - Constructor for class org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter
Construct an instance with the default recoverer which simply logs the failed record.
DefaultBatchToRecordAdapter(ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.listener.adapter.DefaultBatchToRecordAdapter
Construct an instance with the provided recoverer.
defaultBranch(Consumer<? super KStream<K, V>>) - Method in class org.springframework.kafka.support.KafkaStreamBrancher
Defines a default branch.
DefaultJackson2JavaTypeMapper - Class in org.springframework.kafka.support.converter
Jackson 2 type mapper.
DefaultJackson2JavaTypeMapper() - Constructor for class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
DefaultKafkaConsumerFactory<K,​V> - Class in org.springframework.kafka.core
The ConsumerFactory implementation to produce new Consumer instances for provided Map configs and optional Deserializers on each ConsumerFactory.createConsumer() invocation.
DefaultKafkaConsumerFactory(Map<String, Object>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Construct a factory with the provided configuration.
DefaultKafkaConsumerFactory(Map<String, Object>, Supplier<Deserializer<K>>, Supplier<Deserializer<V>>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Construct a factory with the provided configuration and deserializer suppliers.
DefaultKafkaConsumerFactory(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Construct a factory with the provided configuration and deserializers.
DefaultKafkaHeaderMapper - Class in org.springframework.kafka.support
Default header mapper for Apache Kafka.
DefaultKafkaHeaderMapper() - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Construct an instance with the default object mapper and default header patterns for outbound headers; all inbound headers are mapped.
DefaultKafkaHeaderMapper(ObjectMapper) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Construct an instance with the provided object mapper and default header patterns for outbound headers; all inbound headers are mapped.
DefaultKafkaHeaderMapper(ObjectMapper, String...) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Construct an instance with the provided object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
DefaultKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Construct an instance with a default object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
DefaultKafkaHeaderMapper.NonTrustedHeaderType - Class in org.springframework.kafka.support
Represents a header that could not be decoded due to an untrusted type.
DefaultKafkaProducerFactory<K,​V> - Class in org.springframework.kafka.core
The ProducerFactory implementation for a singleton shared Producer instance.
DefaultKafkaProducerFactory(Map<String, Object>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
Construct a factory with the provided configuration.
DefaultKafkaProducerFactory(Map<String, Object>, Supplier<Serializer<K>>, Supplier<Serializer<V>>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
Construct a factory with the provided configuration and Serializer Suppliers.
DefaultKafkaProducerFactory(Map<String, Object>, Serializer<K>, Serializer<V>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
Construct a factory with the provided configuration and Serializers.
DefaultKafkaProducerFactory.CloseSafeProducer<K,​V> - Class in org.springframework.kafka.core
A wrapper class for the delegate.
defaultKafkaStreamsBuilder(ObjectProvider<KafkaStreamsConfiguration>, ObjectProvider<StreamsBuilderFactoryBeanCustomizer>, ObjectProvider<StreamsBuilderFactoryBeanConfigurer>) - Method in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
Bean for the default StreamsBuilderFactoryBean.
defaultPropertyOverrides() - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Return a Properties object equal to the default consumer property overrides.
delegate - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
delegateType - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
DelegatingDeserializer - Class in org.springframework.kafka.support.serializer
A Deserializer that delegates to other deserializers based on a serialization selector header.
DelegatingDeserializer() - Constructor for class org.springframework.kafka.support.serializer.DelegatingDeserializer
DelegatingDeserializer(Map<String, Deserializer<?>>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingDeserializer
Construct an instance with the supplied mapping of selectors to delegate deserializers.
DelegatingInvocableHandler - Class in org.springframework.kafka.listener.adapter
Delegates to an InvocableHandlerMethod based on the message payload type.
DelegatingInvocableHandler(List<InvocableHandlerMethod>, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext, BeanFactory) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
DelegatingInvocableHandler(List<InvocableHandlerMethod>, InvocableHandlerMethod, Object, BeanExpressionResolver, BeanExpressionContext, BeanFactory, Validator) - Constructor for class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Construct an instance with the supplied handlers for the bean.
DelegatingMessageListener<T> - Interface in org.springframework.kafka.listener
Classes implementing this interface allow containers to determine the type of the ultimate listener.
DelegatingSerializer - Class in org.springframework.kafka.support.serializer
A Serializer that delegates to other serializers based on a serialization selector header.
DelegatingSerializer() - Constructor for class org.springframework.kafka.support.serializer.DelegatingSerializer
DelegatingSerializer(Map<String, Serializer<?>>) - Constructor for class org.springframework.kafka.support.serializer.DelegatingSerializer
Construct an instance with the supplied mapping of selectors to delegate serializers.
DELIVERY_ATTEMPT - Static variable in class org.springframework.kafka.support.KafkaHeaders
For inbound messages, when container retries are enabled the delivery attempt.
deliveryAttempt(TopicPartitionOffset) - Method in interface org.springframework.kafka.listener.DeliveryAttemptAware
Return the next delivery attempt for the topic/partition/offset.
deliveryAttempt(TopicPartitionOffset) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
 
DeliveryAttemptAware - Interface in org.springframework.kafka.listener
A component implementing this interface can provide the next delivery attempt.
describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
 
describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
 
describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordTimestampMatcher
 
describeTo(Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordValueMatcher
 
DeserializationException - Exception in org.springframework.kafka.support.serializer
Exception returned in the consumer record value or key when a deserialization failure occurs.
DeserializationException(String, byte[], boolean, Throwable) - Constructor for exception org.springframework.kafka.support.serializer.DeserializationException
Construct an instance with the provided properties.
DeserializationException(String, Headers, byte[], boolean, Throwable) - Constructor for exception org.springframework.kafka.support.serializer.DeserializationException
Deprecated.
Headers are not set during construction.
deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
 
deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
 
deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
 
deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
 
deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
 
deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
 
deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
 
deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.RetryingDeserializer
 
deserializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
 
deserializer() - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
 
destroy() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
destroy() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
destroy() - Method in class org.springframework.kafka.core.KafkaTemplate
 
destroy() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
destroy() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
destroy() - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
destroy() - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
Remove the timers.
destroy() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
determineInferredType(Method) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Subclasses can override this method to use a different mechanism to determine the target type of the payload conversion.
determineListenerType(Object) - Static method in class org.springframework.kafka.listener.ListenerUtils
 
DLT_EXCEPTION_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
Exception class name for a record published sent to a dead-letter topic.
DLT_EXCEPTION_MESSAGE - Static variable in class org.springframework.kafka.support.KafkaHeaders
Exception message for a record published to a dead-letter topic.
DLT_EXCEPTION_STACKTRACE - Static variable in class org.springframework.kafka.support.KafkaHeaders
Exception stack trace for a record published to a dead-letter topic.
DLT_ORIGINAL_OFFSET - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original offset for a record published to a dead-letter topic.
DLT_ORIGINAL_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original partition for a record published to a dead-letter topic.
DLT_ORIGINAL_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original timestamp for a record published to a dead-letter topic.
DLT_ORIGINAL_TIMESTAMP_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original timestamp type for a record published to a dead-letter topic.
DLT_ORIGINAL_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
Original topic for a record published to a dead-letter topic.
doBegin(Object, TransactionDefinition) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doGetTransaction() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doInKafka(Producer<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations.ProducerCallback
 
doInOperations(KafkaOperations<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations.OperationsCallback
 
dontRemoveTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Don't remove type information headers.
dontRemoveTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonSerde
Don't remove type information headers after deserialization.
doOnConsumer(Function<Consumer<K, V>, ? extends T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
doOnProducer(Function<Producer<K, V>, ? extends T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
doResume(Object, Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doRollback(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doSeeks(List<ConsumerRecord<?, ?>>, Consumer<?, ?>, Exception, boolean, BiPredicate<ConsumerRecord<?, ?>, Exception>, LogAccessor) - Static method in class org.springframework.kafka.listener.SeekUtils
Seek records to earliest position, optionally skipping the first.
doSend(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
Send the producer record.
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doStart() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
doStart() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
doStart() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
doStop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
doStop(Runnable) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
doStop(Runnable) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
doSuspend(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doWithAdmin(Consumer<AdminClient>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Create an AdminClient; invoke the callback and reliably close the admin.
doWithAdminFunction(Function<AdminClient, T>) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Create an AdminClient; invoke the callback and reliably close the admin.

E

EmbeddedKafka - Annotation Type in org.springframework.kafka.test.context
Annotation that can be specified on a test class that runs Spring Kafka based tests.
EmbeddedKafkaBroker - Class in org.springframework.kafka.test
An embedded Kafka Broker(s) and Zookeeper manager.
EmbeddedKafkaBroker(int) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker
 
EmbeddedKafkaBroker(int, boolean, int, String...) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker
Create embedded Kafka brokers listening on random ports.
EmbeddedKafkaBroker(int, boolean, String...) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker
Create embedded Kafka brokers.
EmbeddedKafkaBroker.EmbeddedZookeeper - Class in org.springframework.kafka.test
Ported from scala to allow setting the port.
EmbeddedKafkaCondition - Class in org.springframework.kafka.test.condition
JUnit5 condition for an embedded broker.
EmbeddedKafkaCondition() - Constructor for class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
 
EmbeddedKafkaRule - Class in org.springframework.kafka.test.rule
A TestRule wrapper around an EmbeddedKafkaBroker.
EmbeddedKafkaRule(int) - Constructor for class org.springframework.kafka.test.rule.EmbeddedKafkaRule
 
EmbeddedKafkaRule(int, boolean, int, String...) - Constructor for class org.springframework.kafka.test.rule.EmbeddedKafkaRule
Create embedded Kafka brokers listening on random ports.
EmbeddedKafkaRule(int, boolean, String...) - Constructor for class org.springframework.kafka.test.rule.EmbeddedKafkaRule
Create embedded Kafka brokers.
EmbeddedZookeeper(int) - Constructor for class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
 
EnableKafka - Annotation Type in org.springframework.kafka.annotation
Enable Kafka listener annotated endpoints that are created under the covers by a AbstractListenerContainerFactory.
EnableKafkaStreams - Annotation Type in org.springframework.kafka.annotation
Enable default Kafka Streams components.
END - org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
Seek to the end.
endOffsets(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
enhancedObjectMapper() - Static method in class org.springframework.kafka.support.JacksonUtils
Factory for ObjectMapper instances with registered well-known modules and disabled MapperFeature.DEFAULT_VIEW_INCLUSION and DeserializationFeature.FAIL_ON_UNKNOWN_PROPERTIES features.
enhancedObjectMapper(ClassLoader) - Static method in class org.springframework.kafka.support.JacksonUtils
Factory for ObjectMapper instances with registered well-known modules and disabled MapperFeature.DEFAULT_VIEW_INCLUSION and DeserializationFeature.FAIL_ON_UNKNOWN_PROPERTIES features.
equals(Object) - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
equals(Object) - Method in class org.springframework.kafka.requestreply.CorrelationKey
 
equals(Object) - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
equals(Object) - Method in class org.springframework.kafka.test.core.BrokerAddress
 
ERROR - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
A Error was thrown.
ERROR - org.springframework.kafka.KafkaException.Level
Error.
ERROR - org.springframework.kafka.support.LogIfLevelEnabled.Level
Error.
errorHandler() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
Set an KafkaListenerErrorHandler bean name to invoke if the listener method throws an exception.
ErrorHandler - Interface in org.springframework.kafka.listener
Handles errors thrown during the execution of a MessageListener.
ErrorHandlingDeserializer<T> - Class in org.springframework.kafka.support.serializer
Delegating key/value deserializer that catches exceptions, returning them in the headers as serialized java objects.
ErrorHandlingDeserializer() - Constructor for class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
ErrorHandlingDeserializer(Deserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
 
evaluateExecutionCondition(ExtensionContext) - Method in class org.springframework.kafka.test.condition.LogLevelsCondition
 
exchange(Message<?>) - Method in interface org.springframework.kafka.streams.messaging.MessagingFunction
 
execute(KafkaOperations.ProducerCallback<Object, Object, T>) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
execute(KafkaOperations.ProducerCallback<K, V, T>) - Method in interface org.springframework.kafka.core.KafkaOperations
Execute some arbitrary operation(s) on the producer and return the result.
execute(KafkaOperations.ProducerCallback<K, V, T>) - Method in class org.springframework.kafka.core.KafkaTemplate
 
executeInTransaction(KafkaOperations.OperationsCallback<Object, Object, T>) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
executeInTransaction(KafkaOperations.OperationsCallback<K, V, T>) - Method in interface org.springframework.kafka.core.KafkaOperations
Execute some arbitrary operation(s) on the operations and return the result.
executeInTransaction(KafkaOperations.OperationsCallback<K, V, T>) - Method in class org.springframework.kafka.core.KafkaTemplate
 
extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Subclasses can convert the value; by default, it's returned as provided by Kafka unless a RecordMessageConverter has been provided.
extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
 
extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Subclasses can convert the value; by default, it's returned as provided by Kafka.
extractAndConvertValue(ConsumerRecord<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.ProjectingMessageConverter
 

F

FailedDeserializationInfo - Class in org.springframework.kafka.support.serializer
Class containing all the contextual information around a deserialization error.
FailedDeserializationInfo(String, Headers, byte[], boolean, Exception) - Constructor for class org.springframework.kafka.support.serializer.FailedDeserializationInfo
Construct an instance with the contextual information.
FailedRecordProcessor - Class in org.springframework.kafka.listener
Common super class for classes that deal with failing to consume a consumer record.
FailedRecordProcessor(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.FailedRecordProcessor
 
failure(Object, String) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
Record failure.
failure(ConsumerRecord<K, V>, Exception) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
 
failure(ConsumerRecord<K, V>, Exception) - Method in interface org.springframework.kafka.listener.RecordInterceptor
Called after the listener throws an exception.
failure(ConsumerRecords<K, V>, Exception) - Method in interface org.springframework.kafka.listener.BatchInterceptor
Called after the listener throws an exception.
failure(ConsumerRecords<K, V>, Exception) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
 
FATAL - org.springframework.kafka.KafkaException.Level
Fatal.
FATAL - org.springframework.kafka.support.LogIfLevelEnabled.Level
Fatal.
FENCED - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
The transactional producer was fenced and the container stopContainerWhenFenced property is true.
filter(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener
 
filter(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.adapter.RecordFilterStrategy
Return true if the record should be discarded.
FilteringBatchMessageListenerAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
A BatchMessageListener adapter that implements filter logic via a RecordFilterStrategy.
FilteringBatchMessageListenerAdapter(BatchMessageListener<K, V>, RecordFilterStrategy<K, V>) - Constructor for class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
Create an instance with the supplied strategy and delegate listener.
FilteringBatchMessageListenerAdapter(BatchMessageListener<K, V>, RecordFilterStrategy<K, V>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
Create an instance with the supplied strategy and delegate listener.
FilteringMessageListenerAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
A MessageListener adapter that implements filter logic via a RecordFilterStrategy.
FilteringMessageListenerAdapter(MessageListener<K, V>, RecordFilterStrategy<K, V>) - Constructor for class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
Create an instance with the supplied strategy and delegate listener.
FilteringMessageListenerAdapter(MessageListener<K, V>, RecordFilterStrategy<K, V>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
Create an instance with the supplied strategy and delegate listener.
findHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
 
flush() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
flush() - Method in interface org.springframework.kafka.core.KafkaOperations
Flush the producer.
flush() - Method in class org.springframework.kafka.core.KafkaTemplate
Flush the producer.
flush() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
Deprecated.
- flush does not make sense in the context of a reactive flow since, the send completion signal is a send result, which implies that a flush is redundant. If you use this method with reactor-kafka 1.3 or later, it must be scheduled to avoid a deadlock; see https://issues.apache.org/jira/browse/KAFKA-10790 (since 2.7).
flush() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
forKeys() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Designate this deserializer for deserializing keys (default is values); only applies if the default type mapper is used.
forKeys() - Method in class org.springframework.kafka.support.serializer.JsonSerde
Designate this Serde for serializing/deserializing keys (default is values).
forKeys() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
Designate this serializer for serializing keys (default is values); only applies if the default type mapper is used.
fromAddress(String) - Static method in class org.springframework.kafka.test.core.BrokerAddress
 
fromClass(Class<?>, Headers) - Method in interface org.springframework.kafka.support.converter.ClassMapper
 
fromClass(Class<?>, Headers) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
fromHeaders(MessageHeaders, Headers) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
 
fromHeaders(MessageHeaders, Headers) - Method in interface org.springframework.kafka.support.KafkaHeaderMapper
Map from the given MessageHeaders to the specified target message.
fromHeaders(MessageHeaders, Headers) - Method in class org.springframework.kafka.support.SimpleKafkaHeaderMapper
 
fromJavaType(JavaType, Headers) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
fromJavaType(JavaType, Headers) - Method in interface org.springframework.kafka.support.converter.Jackson2JavaTypeMapper
 
fromMessage(Message<?>, String) - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
Convert a message to a producer record.
fromMessage(Message<?>, String) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
 
fromMessage(Message<?>, String) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
 
fromMessage(Message<?>, String) - Method in interface org.springframework.kafka.support.converter.RecordMessageConverter
Convert a message to a producer record.

G

GenericErrorHandler<T> - Interface in org.springframework.kafka.listener
A generic error handler.
GenericMessageListener<T> - Interface in org.springframework.kafka.listener
Top level interface for listeners.
GenericMessageListenerContainer<K,​V> - Interface in org.springframework.kafka.listener
Generic message listener container; adds parameters.
get() - Method in class org.springframework.kafka.core.ABSwitchCluster
 
getAckCount() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getAckMode() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getAckTime() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getAdviceChain() - Method in class org.springframework.kafka.listener.ContainerProperties
A chain of listener Advices.
getAfterRollbackProcessor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Return the currently configured AfterRollbackProcessor.
getAllListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Return all MessageListenerContainer instances including those managed by this registry and those declared as beans in the application context.
getApplicationContext() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getApplicationEventPublisher() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getAssignedPartitions() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
getAssignedPartitions() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
Return the TopicPartitions currently assigned to this container, either explicitly or by Kafka; may be null if not assigned yet.
getAssignedPartitions() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return the assigned topics/partitions for this container.
getAssignedReplyTopicPartitions() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Return the topics/partitions assigned to the replying listener container.
getAssignmentCommitOption() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getAssignmentsByClientId() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
getAssignmentsByClientId() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
getAssignmentsByClientId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return the assigned topics/partitions for this container, by client.id.
getAuthorizationExceptionRetryInterval() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
getAutoStartup() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getAutoStartup() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the autoStartup for this endpoint's container.
getBatchInterceptor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getBatchMessageConverter() - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Return the BatchMessagingMessageConverter for this listener, being able to convert Message.
getBatchToRecordAdapter() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getBean() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
 
getBean() - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Return the bean for this handler.
getBean() - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
 
getBeanExpressionContext() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getBeanFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getBeanName() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getBeanResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getBootstrapServers() - Method in class org.springframework.kafka.core.KafkaResourceFactory
 
getBroker() - Static method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
 
getBrokerAddress(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getBrokerAddresses() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getBrokersAsString() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getCache() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
getCache(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
getCallbacksAndTopics() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
Return the currently registered callbacks and their associated TopicPartition(s).
getCharset() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
 
getCharset() - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
Get the configured charset.
getCharset() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
Get the configured charset.
getClassIdFieldName() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getClassifier() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Return the exception classifier.
getClassLoader() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getClientId() - Method in class org.springframework.kafka.listener.ConsumerProperties
Return the client id.
getClientIdPrefix() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getClientIdPrefix() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the client id prefix for the container; it will be suffixed by '-n' to provide a unique id when concurrency is used.
getCommitCallback() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
getCommitLogLevel() - Method in class org.springframework.kafka.listener.ConsumerProperties
The level at which to log offset commits.
getCommitRetries() - Method in class org.springframework.kafka.listener.ConsumerProperties
The number of retries allowed when a RetriableCommitFailedException is thrown by the consumer.
getConcurrency() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getConcurrency() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the concurrency for this endpoint's container.
getConcurrency() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
getConfig() - Method in class org.springframework.kafka.core.KafkaAdmin
Deprecated.
getConfigurationProperties() - Method in interface org.springframework.kafka.core.ConsumerFactory
Return an unmodifiable reference to the configuration map for this factory.
getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Return an unmodifiable reference to the configuration map for this factory.
getConfigurationProperties() - Method in class org.springframework.kafka.core.KafkaAdmin
Get an unmodifiable copy of this admin's configuration.
getConfigurationProperties() - Method in interface org.springframework.kafka.core.ProducerFactory
Return an unmodifiable reference to the configuration map for this factory.
getConsumer() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
 
getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
Retrieve the consumer.
getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
Retrieve the consumer.
getConsumer() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
Retrieve the consumer.
getConsumerFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
getConsumerGroupId() - Static method in class org.springframework.kafka.support.KafkaUtils
Get the group id for the consumer bound to this thread.
getConsumerProperties() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getConsumerProperties() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Get the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
getConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
getConsumerStartTimeout() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getConsumerStartTimout() - Method in class org.springframework.kafka.listener.ContainerProperties
Deprecated.
getConsumerTaskExecutor() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getContainer(Class<T>) - Method in class org.springframework.kafka.event.KafkaEvent
Get the container for which the event was published, which will be the parent container if the source that emitted the event is a child container, or the source itself otherwise.
getContainerProperties() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Obtain the properties template for this factory - set properties as needed and they will be copied to a final properties instance for the endpoint.
getContainerProperties() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getContainerProperties() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return the container properties for this container.
getContainers() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
Return the list of KafkaMessageListenerContainers created by this container.
getContentClassIdFieldName() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getContext() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
 
getCorrelationId() - Method in class org.springframework.kafka.requestreply.CorrelationKey
 
getCurrentOffset(String, String, String, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Get the current offset and metadata for the provided group/topic/partition.
getCustomMethodArgumentResolvers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Return the list of HandlerMethodArgumentResolver.
getData() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
Get the data that failed deserialization (value or key).
getData() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
getDefaultReplyTimeout() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Return the reply timeout used if no replyTimeout is provided in the ReplyingKafkaTemplate.sendAndReceive(ProducerRecord, Duration) call.
getDefaultReplyTopicExpression() - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
Return the default expression when no SendTo value is present.
getDefaultTopic() - Method in class org.springframework.kafka.core.KafkaTemplate
The default topic for send methods where a topic is not provided.
getDelegate() - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
getDelegate() - Method in interface org.springframework.kafka.listener.DelegatingMessageListener
Return the delegate.
getDelegates() - Method in class org.springframework.kafka.support.CompositeProducerListener
 
getEmbeddedKafka() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
Return an underlying delegator EmbeddedKafkaBroker instance.
getEndOffsets(Consumer<?, ?>, String, Integer...) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Return the end offsets of the requested topic/partitions
getEndpointDescription() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return a description for this endpoint.
getEndpointDescription() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
 
getEndpointRegistry() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Return the KafkaListenerEndpointRegistry instance for this registrar, may be null.
getEosMode() - Method in class org.springframework.kafka.listener.ContainerProperties
Get the exactly once semantics mode.
getException() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
getExceptionFromHeader(ConsumerRecord<?, ?>, String, LogAccessor) - Static method in class org.springframework.kafka.listener.ListenerUtils
Extract a DeserializationException from the supplied header name, if present.
getFailedProducerRecord() - Method in exception org.springframework.kafka.core.KafkaProducerException
Return the failed producer record.
getGenericErrorHandler() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Get the configured error handler.
getGroup() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getGroup() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the group of this endpoint or null if not in a group.
getGroupId() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getGroupId() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the groupId of this endpoint - if present, overrides the group.id property of the consumer factory.
getGroupId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getGroupId() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
getGroupId() - Method in exception org.springframework.kafka.listener.ListenerExecutionFailedException
Return the consumer group.id property of the container that threw this exception.
getGroupId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return the group.id property for this container whether specifically set on the container or via a consumer property on the consumer factory.
getGroupId() - Static method in interface org.springframework.kafka.support.converter.MessageConverter
Get the thread bound group id.
getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Determine the InvocableHandlerMethod for the provided type.
getHeaders() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
Get the headers.
getHeaders() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
getHeaderValue() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
getHost() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
getId() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getId() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the id of this endpoint.
getIdClassMapping() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getIdleBetweenPolls() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getIdleEventInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
How long the container has been idle.
getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
How long the container was idle.
getIndex() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
Return the index in the batch of the failed record.
getKafkaConsumerProperties() - Method in class org.springframework.kafka.listener.ConsumerProperties
Get the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
getKafkaServer(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getKafkaServers() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getKafkaStreams() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Get a managed by this StreamsBuilderFactoryBean KafkaStreams instance.
getKey() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
 
getKeyClassIdFieldName() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getKeyDeserializer() - Method in interface org.springframework.kafka.core.ConsumerFactory
Return the configured key deserializer (if provided as an object instead of a class name in the properties).
getKeyDeserializer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
getKeySerializerSupplier() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
getKeySerializerSupplier() - Method in interface org.springframework.kafka.core.ProducerFactory
Return a supplier for a key serializer.
getListenerContainer(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Return the MessageListenerContainer with the specified id or null if no such container exists.
getListenerContainerIds() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Return the ids of the managed MessageListenerContainer instance(s).
getListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Return the managed MessageListenerContainer instance(s).
getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
The id of the listener (if @KafkaListener) or the container bean name.
getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
The id of the listener (if @KafkaListener) or the container bean name.
getListenerId() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
The id of the listener (if @KafkaListener) or the container bean name.
getListenerId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getListenerId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
The 'id' attribute of a @KafkaListener or the bean name for spring-managed containers.
getListeners() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Get the current list of listeners.
getListeners() - Method in interface org.springframework.kafka.core.ConsumerFactory
Get the current list of listeners.
getListeners() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Get the current list of listeners.
getListeners() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Get the current list of listeners.
getListeners() - Method in interface org.springframework.kafka.core.ProducerFactory
Get the current list of listeners.
getLogDir() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
 
getLogLevel() - Method in class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
Set the level at which the exception thrown by this handler is logged.
getMessage() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
 
getMessageConverter() - Method in class org.springframework.kafka.core.KafkaTemplate
Return the message converter.
getMessageConverter() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Return the MessagingMessageConverter for this listener, being able to convert Message.
getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
Return the configured handler factory.
getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Return the custom MessageHandlerMethodFactory to use, if any.
getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Return the MessageHandlerMethodFactory.
getMessageListener() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getMethod() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
 
getMethodAsString(Object) - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
 
getMethodNameFor(Object) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Return a string representation of the method that will be invoked for this payload.
getMicrometerTags() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getMonitorInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getNoPollThreshold() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getObjectMapper() - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
Return the object mapper.
getObjectMapper() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Return the object mapper.
getObjectType() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
getOffset() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
getOneRecord(String, String, String, int, boolean, boolean, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Get a single record for the group from the topic/partition.
getOrder() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
getOrder() - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanConfigurer
 
getParser() - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
Get the configured parser function.
getPartition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
getPartitions() - Method in class org.springframework.kafka.event.ConsumerPausedEvent
 
getPartitions() - Method in class org.springframework.kafka.event.ConsumerResumedEvent
 
getPartitions() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
 
getPartitionsPerTopic() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getPhase() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
getPhase() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
getPhase() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getPhase() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
getPhysicalCloseTimeout() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Get the physical close timeout.
getPhysicalCloseTimeout() - Method in interface org.springframework.kafka.core.ProducerFactory
Get the physical close timeout.
getPollTimeout() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
getPort() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
getPort() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
 
getPosition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
getPostProcessors() - Method in interface org.springframework.kafka.core.ConsumerFactory
Get the current list of post processors.
getPostProcessors() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
getPostProcessors() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
getPostProcessors() - Method in interface org.springframework.kafka.core.ProducerFactory
Get the current list of post processors.
getProducer() - Method in class org.springframework.kafka.core.KafkaResourceHolder
 
getProducerFactory() - Method in interface org.springframework.kafka.core.KafkaOperations
Return the producer factory used by this template.
getProducerFactory() - Method in class org.springframework.kafka.core.KafkaTemplate
Return the producer factory used by this template.
getProducerFactory() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
getProducerFactory() - Method in class org.springframework.kafka.transaction.ChainedKafkaTransactionManager
 
getProducerFactory() - Method in interface org.springframework.kafka.transaction.KafkaAwareTransactionManager
Get the producer factory.
getProducerFactory() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
Get the producer factory.
getProducerFactory(String) - Method in class org.springframework.kafka.core.KafkaTemplate
Return the producer factory used by this template based on the topic.
getProducerFactory(String) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
getProducerRecord() - Method in exception org.springframework.kafka.core.KafkaProducerException
getProducerRecord() - Method in class org.springframework.kafka.support.SendResult
 
getPropertyValue(Object, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Uses nested DirectFieldAccessors to obtain a property using dotted notation to traverse fields; e.g.
getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
getRawHeaders() - Method in class org.springframework.kafka.support.converter.KafkaMessageHeaders
 
getReason() - Method in class org.springframework.kafka.event.ConsumerStoppedEvent
Return the reason why the consumer was stopped.
getRecord() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
Return the failed record.
getRecordFilterStrategy() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getRecordInterceptor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getRecordMessageConverter() - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
Return the record converter used by this batch converter, if configured, or null.
getRecordMessageConverter() - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
 
getRecordMetadata() - Method in class org.springframework.kafka.support.SendResult
 
getRecords(Consumer<K, V>) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Poll the consumer for records.
getRecords(Consumer<K, V>, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Poll the consumer for records.
getRecords(Consumer<K, V>, long, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Poll the consumer for records.
getRecoveryCallback() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getRecoveryCallback() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
 
getReplyHeadersConfigurer() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Return the reply configurer.
getReplyTemplate() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getRequest() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
getResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getResult() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
 
getResult() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
getRetryTemplate() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getRetryTemplate() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
 
getScheduler() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getSeekCallbackFor(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
Return the callback for the specified topic/partition.
getSeekCallbacks() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
The map of callbacks for all currently assigned partitions.
getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
 
getSendTo() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
 
getShutdownTimeout() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getSingleRecord(Consumer<K, V>, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Poll the consumer, expecting a single record for the specified topic.
getSingleRecord(Consumer<K, V>, String, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Poll the consumer, expecting a single record for the specified topic.
getSkipPredicate(List<ConsumerRecord<?, ?>>, Exception) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
 
getSnapshotDir() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
 
getSource() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
getSource(Class<T>) - Method in class org.springframework.kafka.event.KafkaEvent
Get the container (source) that published the event.
getStreamsConfiguration() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
getSubBatchPerPartition() - Method in class org.springframework.kafka.listener.ContainerProperties
Return whether to split batches by partition; null if not set.
getSyncCommitTimeout() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
getTheProducer(String) - Method in class org.springframework.kafka.core.KafkaTemplate
 
getTimeSinceLastPoll() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
How long since the last poll.
getTopic() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
getTopic() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
getTopicPartition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
The TopicPartitions the container is listening to.
getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
The TopicPartitions the container is listening to.
getTopicPartitions() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
The TopicPartitions the container is listening to.
getTopicPartitions() - Method in class org.springframework.kafka.listener.ConsumerProperties
Return the configured TopicPartitionOffsets.
getTopicPartitionsToAssign() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return the topicPartitions for this endpoint.
getTopicPartitionsToAssign() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the topicPartitions for this endpoint.
getTopicPartitionsToAssign() - Method in class org.springframework.kafka.listener.ConsumerProperties
Deprecated.
getTopicPattern() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return the topicPattern for this endpoint.
getTopicPattern() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the topicPattern for this endpoint.
getTopicPattern() - Method in class org.springframework.kafka.listener.ConsumerProperties
Return the configured topic pattern.
getTopics() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return the topics for this endpoint.
getTopics() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the topics for this endpoint.
getTopics() - Method in class org.springframework.kafka.listener.ConsumerProperties
Return the configured topics.
getTopics() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getTopology() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Providing access to the associated Topology of this StreamsBuilderFactoryBean.
getToStringClasses() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Provide direct access to the toString() classes by subclasses.
getTransactionalResourceHolder(ProducerFactory<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
Obtain a Producer that is synchronized with the current transaction, if any.
getTransactionalResourceHolder(ProducerFactory<K, V>, String, Duration) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
Obtain a Producer that is synchronized with the current transaction, if any.
getTransactionalResourceHolder(ProducerFactory<K, V>, Duration) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
Obtain a Producer that is synchronized with the current transaction, if any.
getTransactionDefinition() - Method in class org.springframework.kafka.listener.ContainerProperties
Get the transaction definition.
getTransactionIdPrefix() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
getTransactionIdPrefix() - Method in class org.springframework.kafka.core.KafkaTemplate
 
getTransactionIdPrefix() - Method in interface org.springframework.kafka.core.ProducerFactory
Return the transaction id prefix.
getTransactionIdSuffix() - Static method in class org.springframework.kafka.support.TransactionSupport
 
getTransactionManager() - Method in class org.springframework.kafka.listener.ContainerProperties
 
getTrustedPackages() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Provide direct access to the trusted packages set for subclasses.
getType() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Returns the inferred type for conversion or, if null, the fallbackType.
getTypeMapper() - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
 
getTypeMapper() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
 
getTypeMapper() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
getTypePrecedence() - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
Return the precedence.
getTypePrecedence() - Method in interface org.springframework.kafka.support.converter.Jackson2JavaTypeMapper
 
getUntrustedType() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
getValidator() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Get the validator, if supplied.
getValue() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
 
getValueDeserializer() - Method in interface org.springframework.kafka.core.ConsumerFactory
Return the configured value deserializer (if provided as an object instead of a class name in the properties).
getValueDeserializer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
getValueSerializerSupplier() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
getValueSerializerSupplier() - Method in interface org.springframework.kafka.core.ProducerFactory
Return a supplier for a value serializer.
getZkPort() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Get the port that the embedded Zookeeper is running on or will run on.
getZookeeper() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
getZooKeeperClient() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Return the ZooKeeperClient.
getZookeeperConnectionString() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
GROUP_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
For inbound messages, the container's group.id consumer property.
groupId() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
Override the group.id property for the consumer factory with this value for this listener only.

H

handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ContainerAwareErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
Handle the exception.
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ContainerAwareErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerStoppingErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ErrorHandler
Handle the exception.
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.SeekToCurrentErrorHandler
 
handle(Exception, ConsumerRecord<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
 
handle(Exception, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.LoggingErrorHandler
 
handle(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
 
handle(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>) - Method in class org.springframework.kafka.listener.BatchLoggingErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.BatchErrorHandler
Handle the exception.
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerStoppingBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.RecoveringBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.BatchErrorHandler
Handle the exception.
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
Handle the exception.
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in interface org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable) - Method in class org.springframework.kafka.listener.RetryingBatchErrorHandler
 
handle(Exception, T) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
Handle the exception.
handle(Exception, T, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
Handle the exception.
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
 
handleError(Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.kafka.listener.ConsumerAwareListenerErrorHandler
 
handleError(Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.kafka.listener.KafkaListenerErrorHandler
Handle the error.
handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareListenerErrorHandler
 
handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.KafkaListenerErrorHandler
Handle the error.
HandlerAdapter - Class in org.springframework.kafka.listener.adapter
A wrapper for either an InvocableHandlerMethod or DelegatingInvocableHandler.
HandlerAdapter(DelegatingInvocableHandler) - Constructor for class org.springframework.kafka.listener.adapter.HandlerAdapter
 
HandlerAdapter(InvocableHandlerMethod) - Constructor for class org.springframework.kafka.listener.adapter.HandlerAdapter
 
handleResult(Object, Object, Object) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Handle the given result object returned from the listener method, sending a response message to the SendTo topic.
handleTimeout(CorrelationKey, RequestReplyFuture<K, V, Collection<ConsumerRecord<K, R>>>) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
 
handleTimeout(CorrelationKey, RequestReplyFuture<K, V, R>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Used to inform subclasses that a request has timed out so they can clean up state and, optionally, complete the future.
hasDefaultHandler() - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
 
hashCode() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
hashCode() - Method in class org.springframework.kafka.requestreply.CorrelationKey
 
hashCode() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
hashCode() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
hasKey(K) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
 
hasOffset() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
hasPartition(int) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
 
hasTimestamp() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
hasTimestamp(long) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
Matcher testing the timestamp of a ConsumerRecord assuming the topic has been set with CreateTime.
hasTimestamp(TimestampType, long) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
Matcher testing the timestamp of a ConsumerRecord
hasValue(V) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
 
HeaderEnricher<K,​V> - Class in org.springframework.kafka.streams
Manipulate the headers.
HeaderEnricher(Map<String, Expression>) - Constructor for class org.springframework.kafka.streams.HeaderEnricher
 
HeaderEnricher.Container<K,​V> - Class in org.springframework.kafka.streams
Container object for SpEL evaluation.
headerValueToAddIn(Header) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
Check if the header value should be mapped to a String, if so configured.
headerValueToAddOut(String, Object) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
Check if the value is a String and convert to byte[], if so configured.

I

id() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
The unique identifier of the container for this listener.
idIsGroup() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
When groupId is not provided, use the id (if provided) as the group.id property for the consumer.
ignoreTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Ignore type information headers and use the configured target class.
ignoreTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonSerde
Ignore type information headers and use the configured target class.
INFERRED - org.springframework.kafka.support.converter.Jackson2JavaTypeMapper.TypePrecedence
 
INFO - org.springframework.kafka.KafkaException.Level
Info.
INFO - org.springframework.kafka.support.LogIfLevelEnabled.Level
Info.
init(ProcessorContext) - Method in class org.springframework.kafka.streams.HeaderEnricher
 
init(ProcessorContext) - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
 
initialize() - Method in class org.springframework.kafka.core.KafkaAdmin
Call this method to check/add topics; this might be needed if the broker was not available when the application context was initialized, and fatalIfBrokerNotAvailable is false, or autoCreate was set to false.
initializeContainer(C, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Further initialize the specified container.
initializeContainer(ConcurrentMessageListenerContainer<K, V>, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
 
initialOffset() - Method in annotation type org.springframework.kafka.annotation.PartitionOffset
The initial offset of the PartitionOffset.partition().
initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
 
initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Subclasses can populate additional headers before they are mapped.
initTransactions() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
INSTANCE - Static variable in class org.springframework.kafka.support.JavaUtils
The singleton instance of this utility class.
INSTANCE - Static variable in class org.springframework.kafka.support.KafkaNull
Instance of KafkaNull.
instantiateAndConfigure(Map<String, ?>, boolean, Map<String, Deserializer<?>>, String, Class<?>) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
 
instantiateAndConfigure(Map<String, ?>, boolean, Map<String, Serializer<?>>, String, Class<?>) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
 
intercept(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
 
intercept(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
Perform some action on the record or return a different one.
intercept(ConsumerRecords<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
Perform some action on the records or return a different one.
intercept(ConsumerRecords<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
 
inTransaction() - Method in interface org.springframework.kafka.core.KafkaOperations
Return true if the template is currently running in a transaction on the calling thread.
inTransaction() - Method in class org.springframework.kafka.core.KafkaTemplate
Return true if the template is currently running in a transaction on the calling thread.
InvocationResult - Class in org.springframework.kafka.listener.adapter
The result of a method invocation.
InvocationResult(Object, Expression, boolean) - Constructor for class org.springframework.kafka.listener.adapter.InvocationResult
 
invoke(Object, Acknowledgment, Consumer<?, ?>, Message<?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
 
invoke(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>, Message<?>) - Method in interface org.springframework.kafka.listener.adapter.BatchToRecordAdapter.Callback
Handle each message.
invoke(Message<?>, Object...) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Invoke the method with the given message.
invoke(Message<?>, Object...) - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
 
invokeHandler(Object, Acknowledgment, Message<?>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Invoke the handler, wrapping any exception to a ListenerExecutionFailedException with a dedicated error message.
isAckAfterHandle() - Method in interface org.springframework.kafka.listener.GenericErrorHandler
Return true if the offset should be committed for a handled error (no exception thrown).
isAckAfterHandle() - Method in class org.springframework.kafka.listener.RecoveringBatchErrorHandler
 
isAckAfterHandle() - Method in class org.springframework.kafka.listener.RetryingBatchErrorHandler
 
isAckAfterHandle() - Method in class org.springframework.kafka.listener.SeekToCurrentErrorHandler
 
isAckDiscarded() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
isAckOnError() - Method in class org.springframework.kafka.listener.ContainerProperties
 
isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
Get the addTypeInfo property.
isAllowNonTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations
Return true if this template, when transactional, allows non-transactional operations.
isAllowNonTransactional() - Method in class org.springframework.kafka.core.KafkaTemplate
 
isAutoCommit() - Method in interface org.springframework.kafka.core.ConsumerFactory
Return true if consumers created by this factory use auto commit.
isAutoCommit() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
isAutoStartup() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
isAutoStartup() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
isAutoStartup() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isAutoStartup() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
isBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Return true if this endpoint creates a batch listener.
isBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return true if this endpoint creates a batch listener.
isCommitRecovered() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Whether the offset for a recovered record should be committed.
isConsumerRecordList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isConsumerRecords() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isContainerPaused() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
isContainerPaused() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
isContainerPaused() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return true if MessageListenerContainer.pause() has been called; and all consumers in this container have actually paused.
isConversionNeeded() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isDefault() - Method in annotation type org.springframework.kafka.annotation.KafkaHandler
When true, designate that this is the default fallback method if the payload type matches no other KafkaHandler method.
isDeliveryAttemptHeader() - Method in class org.springframework.kafka.listener.ContainerProperties
 
isEncodeStrings() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
 
isExistingTransaction(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
isFixTxOffsets() - Method in class org.springframework.kafka.listener.ConsumerProperties
Whether or not to correct terminal transactional offsets.
isForKey() - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
isForKey() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
isInterceptBeforeTx() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isJackson2Present() - Static method in class org.springframework.kafka.support.JacksonPresent
 
isKey() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
True if deserialization of the key failed, otherwise deserialization of the value failed.
isLogContainerConfig() - Method in class org.springframework.kafka.listener.ContainerProperties
Log the container configuration if true (INFO).
isMessageList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isMessageReturnType() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
 
isMicrometerEnabled() - Method in class org.springframework.kafka.listener.ContainerProperties
 
isMissingTopicsFatal() - Method in class org.springframework.kafka.listener.ContainerProperties
If true, the container won't start if any of the configured topics are not present on the broker.
isNegated() - Method in interface org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
Return true if this matcher is a negative matcher.
isNegated() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
 
isNegated() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
 
isOnlyLogRecordMetadata() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
isPaused() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
Return true if the consumer was paused at the time the idle event was published.
isPaused() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isPauseRequested() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isPauseRequested() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return true if MessageListenerContainer.pause() has been called; the container might not have actually paused yet.
isPending(CorrelationKey) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Return true if this correlation id is still active.
isPrimary() - Method in class org.springframework.kafka.core.ABSwitchCluster
Get whether or not the primary cluster is active.
isProcessInTransaction() - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
isProcessInTransaction() - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
 
isProducerPerConsumerPartition() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Return the producerPerConsumerPartition.
isProducerPerConsumerPartition() - Method in interface org.springframework.kafka.core.ProducerFactory
Return the producerPerConsumerPartition.
isProducerPerThread() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
isProducerPerThread() - Method in interface org.springframework.kafka.core.ProducerFactory
Return true when there is a producer per thread.
isRelativeToCurrent() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
isRunning() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
isRunning() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
isRunning() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isRunning() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
isSplitIterables() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
isSplitIterables() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
When true, Iterable return results will be split into discrete records.
isSplitIterables() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
When true, Iterable return results will be split into discrete records.
isStatefulRetry() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
isStopContainerWhenFenced() - Method in class org.springframework.kafka.listener.ContainerProperties
When true, the container will stop after a ProducerFencedException.
isStopImmediate() - Method in class org.springframework.kafka.listener.ContainerProperties
When true, the container will be stopped immediately after processing the current record.
isSubBatchPerPartition() - Method in class org.springframework.kafka.listener.ContainerProperties
Return whether to split batches by partition.
isSyncCommits() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
isTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations
Return true if the implementation supports transactions (has a transaction-capable producer factory).
isTransactional() - Method in class org.springframework.kafka.core.KafkaTemplate
 

J

Jackson2JavaTypeMapper - Interface in org.springframework.kafka.support.converter
Strategy for setting metadata on messages such that one can create the class that needs to be instantiated when receiving a message.
Jackson2JavaTypeMapper.TypePrecedence - Enum in org.springframework.kafka.support.converter
The precedence for type conversion - inferred from the method parameter or message headers.
JacksonMimeTypeModule - Class in org.springframework.kafka.support
A SimpleModule extension for MimeType serialization.
JacksonMimeTypeModule() - Constructor for class org.springframework.kafka.support.JacksonMimeTypeModule
 
JacksonPresent - Class in org.springframework.kafka.support
The utility to check if Jackson JSON processor is present in the classpath.
JacksonUtils - Class in org.springframework.kafka.support
The utilities for Jackson ObjectMapper instances.
JavaUtils - Class in org.springframework.kafka.support
Chained utility methods to simplify some Java repetitive code.
JSON_TYPES - Static variable in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Header name for java types of other headers.
JsonDeserializer<T> - Class in org.springframework.kafka.support.serializer
Generic Deserializer for receiving JSON from Kafka and return Java objects.
JsonDeserializer() - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with a default ObjectMapper.
JsonDeserializer(TypeReference<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and a default ObjectMapper.
JsonDeserializer(TypeReference<? super T>, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and useHeadersIfPresent with a default ObjectMapper.
JsonDeserializer(TypeReference<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and ObjectMapper.
JsonDeserializer(TypeReference<? super T>, ObjectMapper, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, ObjectMapper and useHeadersIfPresent.
JsonDeserializer(JavaType) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and a default ObjectMapper.
JsonDeserializer(JavaType, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and useHeadersIfPresent with a default ObjectMapper.
JsonDeserializer(JavaType, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and ObjectMapper.
JsonDeserializer(JavaType, ObjectMapper, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, ObjectMapper and useHeadersIfPresent.
JsonDeserializer(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided ObjectMapper.
JsonDeserializer(Class<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and a default ObjectMapper.
JsonDeserializer(Class<? super T>, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and useHeadersIfPresent with a default ObjectMapper.
JsonDeserializer(Class<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, and ObjectMapper.
JsonDeserializer(Class<? super T>, ObjectMapper, boolean) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
Construct an instance with the provided target type, ObjectMapper and useHeadersIfPresent.
JsonMessageConverter - Class in org.springframework.kafka.support.converter
Base class for JSON message converters; on the consumer side, it can handle byte[], Bytes and String record values.
JsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.JsonMessageConverter
 
JsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.JsonMessageConverter
 
JsonSerde<T> - Class in org.springframework.kafka.support.serializer
A Serde that provides serialization and deserialization in JSON format.
JsonSerde() - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(TypeReference<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(TypeReference<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(JavaType) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(JavaType, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(Class<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(Class<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(JsonSerializer<T>, JsonDeserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerializer<T> - Class in org.springframework.kafka.support.serializer
Generic Serializer for sending Java objects to Kafka as JSON.
JsonSerializer() - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
 
JsonSerializer(TypeReference<? super T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
 
JsonSerializer(TypeReference<? super T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
 
JsonSerializer(JavaType, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
 
JsonSerializer(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
 
JsonTypeResolver - Interface in org.springframework.kafka.support.serializer
Determine the JavaType from the topic/data/headers.
JUnitUtils - Class in org.springframework.kafka.test.utils
Utility methods for JUnit rules and conditions.
JUnitUtils.LevelsContainer - Class in org.springframework.kafka.test.utils
 

K

KAFKA_CLIENT_CONTEXT_NAME - Static variable in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
The key for the kafka client configuration entry.
KAFKA_LISTENER_ANNOTATION_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
The bean name of the internally managed Kafka listener annotation processor.
KAFKA_LISTENER_ENDPOINT_REGISTRY_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
The bean name of the internally managed Kafka listener endpoint registry.
KafkaAdmin - Class in org.springframework.kafka.core
An admin that delegates to an AdminClient to create topics defined in the application context.
KafkaAdmin(Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaAdmin
Create an instance with an AdminClient based on the supplied configuration.
KafkaAwareTransactionManager<K,​V> - Interface in org.springframework.kafka.transaction
A transaction manager that can provide a ProducerFactory.
KafkaBootstrapConfiguration - Class in org.springframework.kafka.annotation
An ImportBeanDefinitionRegistrar class that registers a KafkaListenerAnnotationBeanPostProcessor bean capable of processing Spring's @KafkaListener annotation.
KafkaBootstrapConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
 
KafkaConditions - Class in org.springframework.kafka.test.assertj
AssertJ custom Conditions.
KafkaConditions.ConsumerRecordKeyCondition<K> - Class in org.springframework.kafka.test.assertj
 
KafkaConditions.ConsumerRecordKeyValueCondition<K,​V> - Class in org.springframework.kafka.test.assertj
 
KafkaConditions.ConsumerRecordPartitionCondition - Class in org.springframework.kafka.test.assertj
 
KafkaConditions.ConsumerRecordTimestampCondition - Class in org.springframework.kafka.test.assertj
 
KafkaConditions.ConsumerRecordValueCondition<V> - Class in org.springframework.kafka.test.assertj
 
KafkaEvent - Class in org.springframework.kafka.event
Base class for events.
KafkaEvent(Object) - Constructor for class org.springframework.kafka.event.KafkaEvent
Deprecated.
KafkaEvent(Object, Object) - Constructor for class org.springframework.kafka.event.KafkaEvent
 
KafkaException - Exception in org.springframework.kafka
The Spring Kafka specific NestedRuntimeException implementation.
KafkaException(String) - Constructor for exception org.springframework.kafka.KafkaException
Construct an instance with the provided properties.
KafkaException(String, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
Construct an instance with the provided properties.
KafkaException(String, KafkaException.Level, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
Construct an instance with the provided properties.
KafkaException.Level - Enum in org.springframework.kafka
The log level for KafkaException.
KafkaExceptionLogLevelAware - Class in org.springframework.kafka.listener
A top level abstract class for classes that can be configured with a KafkaException.Level.
KafkaExceptionLogLevelAware() - Constructor for class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
 
KafkaFailureCallback<K,​V> - Interface in org.springframework.kafka.core
An enhanced FailureCallback for reporting KafkaProducerExceptions.
KafkaHandler - Annotation Type in org.springframework.kafka.annotation
Annotation that marks a method to be the target of a Kafka message listener within a class that is annotated with KafkaListener.
KafkaHeaderMapper - Interface in org.springframework.kafka.support
Header mapper for Apache Kafka.
KafkaHeaders - Class in org.springframework.kafka.support
The Kafka specific message headers constants.
KafkaHeaders() - Constructor for class org.springframework.kafka.support.KafkaHeaders
 
KafkaJaasLoginModuleInitializer - Class in org.springframework.kafka.security.jaas
Contains properties for setting up an AppConfigurationEntry that can be used for the Kafka client.
KafkaJaasLoginModuleInitializer() - Constructor for class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
KafkaJaasLoginModuleInitializer.ControlFlag - Enum in org.springframework.kafka.security.jaas
Control flag values for login configuration.
KafkaListener - Annotation Type in org.springframework.kafka.annotation
Annotation that marks a method to be the target of a Kafka message listener on the specified topics.
KafkaListenerAnnotationBeanPostProcessor<K,​V> - Class in org.springframework.kafka.annotation
Bean post-processor that registers methods annotated with KafkaListener to be invoked by a Kafka message listener container created under the covers by a KafkaListenerContainerFactory according to the parameters of the annotation.
KafkaListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
KafkaListenerConfigurationSelector - Class in org.springframework.kafka.annotation
A DeferredImportSelector implementation with the lowest order to import a KafkaBootstrapConfiguration as late as possible.
KafkaListenerConfigurationSelector() - Constructor for class org.springframework.kafka.annotation.KafkaListenerConfigurationSelector
 
KafkaListenerConfigurer - Interface in org.springframework.kafka.annotation
Optional interface to be implemented by Spring managed bean willing to customize how Kafka listener endpoints are configured.
KafkaListenerConfigUtils - Class in org.springframework.kafka.config
Configuration constants for internal sharing across subpackages.
KafkaListenerConfigUtils() - Constructor for class org.springframework.kafka.config.KafkaListenerConfigUtils
 
KafkaListenerContainerFactory<C extends MessageListenerContainer> - Interface in org.springframework.kafka.config
KafkaListenerEndpoint - Interface in org.springframework.kafka.config
Model for a Kafka listener endpoint.
KafkaListenerEndpointRegistrar - Class in org.springframework.kafka.config
Helper bean for registering KafkaListenerEndpoint with a KafkaListenerEndpointRegistry.
KafkaListenerEndpointRegistrar() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
 
KafkaListenerEndpointRegistry - Class in org.springframework.kafka.config
Creates the necessary MessageListenerContainer instances for the registered endpoints.
KafkaListenerEndpointRegistry() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
KafkaListenerErrorHandler - Interface in org.springframework.kafka.listener
An error handler which is called when a @KafkaListener method throws an exception.
KafkaListeners - Annotation Type in org.springframework.kafka.annotation
Container annotation that aggregates several KafkaListener annotations.
KafkaMatchers - Class in org.springframework.kafka.test.hamcrest
Hamcrest Matchers utilities.
KafkaMatchers.ConsumerRecordKeyMatcher<K> - Class in org.springframework.kafka.test.hamcrest
 
KafkaMatchers.ConsumerRecordPartitionMatcher - Class in org.springframework.kafka.test.hamcrest
 
KafkaMatchers.ConsumerRecordTimestampMatcher - Class in org.springframework.kafka.test.hamcrest
 
KafkaMatchers.ConsumerRecordValueMatcher<V> - Class in org.springframework.kafka.test.hamcrest
 
KafkaMessageHeaders - Class in org.springframework.kafka.support.converter
Overload of message headers configurable for adding id and timestamp headers.
KafkaMessageListenerContainer<K,​V> - Class in org.springframework.kafka.listener
Single-threaded Message listener container using the Java Consumer supporting auto-partition assignment or user-configured assignment.
KafkaMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.KafkaMessageListenerContainer
Construct an instance with the supplied configuration properties.
KafkaNull - Class in org.springframework.kafka.support
This class represents NULL Kafka payload.
KafkaOperations<K,​V> - Interface in org.springframework.kafka.core
The basic Kafka operations contract returning ListenableFutures.
KafkaOperations.OperationsCallback<K,​V,​T> - Interface in org.springframework.kafka.core
A callback for executing arbitrary operations on the KafkaOperations.
KafkaOperations.ProducerCallback<K,​V,​T> - Interface in org.springframework.kafka.core
A callback for executing arbitrary operations on the Producer.
kafkaPorts(int...) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set explicit ports on which the kafka brokers will listen.
kafkaPorts(int...) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
Set explicit ports on which the kafka brokers will listen.
KafkaProducerException - Exception in org.springframework.kafka.core
Exceptions when producing.
KafkaProducerException(ProducerRecord<?, ?>, String, Throwable) - Constructor for exception org.springframework.kafka.core.KafkaProducerException
Construct an instance with the provided properties.
KafkaReplyTimeoutException - Exception in org.springframework.kafka.requestreply
Exception when a reply is not received within a timeout.
KafkaReplyTimeoutException(String) - Constructor for exception org.springframework.kafka.requestreply.KafkaReplyTimeoutException
 
KafkaResourceFactory - Class in org.springframework.kafka.core
Base class for consumer/producer/admin creators.
KafkaResourceFactory() - Constructor for class org.springframework.kafka.core.KafkaResourceFactory
 
KafkaResourceHolder<K,​V> - Class in org.springframework.kafka.core
Kafka resource holder, wrapping a Kafka producer.
KafkaResourceHolder(Producer<K, V>, Duration) - Constructor for class org.springframework.kafka.core.KafkaResourceHolder
Construct an instance for the producer.
KafkaSendCallback<K,​V> - Interface in org.springframework.kafka.core
An enhanced ListenableFutureCallback for reporting KafkaProducerExceptions.
KafkaStreamBrancher<K,​V> - Class in org.springframework.kafka.support
Provides a method-chaining way to build branches in Kafka Streams processor topology.
KafkaStreamBrancher() - Constructor for class org.springframework.kafka.support.KafkaStreamBrancher
 
KafkaStreamsConfiguration - Class in org.springframework.kafka.config
Wrapper for StreamsBuilder properties.
KafkaStreamsConfiguration(Map<String, Object>) - Constructor for class org.springframework.kafka.config.KafkaStreamsConfiguration
 
KafkaStreamsCustomizer - Interface in org.springframework.kafka.config
Callback interface that can be used to configure KafkaStreams directly.
KafkaStreamsDefaultConfiguration - Class in org.springframework.kafka.annotation
@Configuration class that registers a StreamsBuilderFactoryBean if StreamsConfig with the name KafkaStreamsDefaultConfiguration.DEFAULT_STREAMS_CONFIG_BEAN_NAME is present in the application context.
KafkaStreamsDefaultConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
 
KafkaStreamsInfrastructureCustomizer - Interface in org.springframework.kafka.config
A customizer for infrastructure components such as the StreamsBuilder and Topology.
KafkaStreamsMicrometerListener - Class in org.springframework.kafka.streams
Creates a KafkaStreamsMetrics for the KafkaStreams.
KafkaStreamsMicrometerListener(MeterRegistry) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
Construct an instance with the provided registry.
KafkaStreamsMicrometerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
Construct an instance with the provided registry and tags.
KafkaTemplate<K,​V> - Class in org.springframework.kafka.core
A template for executing high-level operations.
KafkaTemplate(ProducerFactory<K, V>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
Create an instance using the supplied producer factory and autoFlush false.
KafkaTemplate(ProducerFactory<K, V>, boolean) - Constructor for class org.springframework.kafka.core.KafkaTemplate
Create an instance using the supplied producer factory and autoFlush setting.
KafkaTemplate(ProducerFactory<K, V>, boolean, Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
Create an instance using the supplied producer factory and autoFlush setting.
KafkaTemplate(ProducerFactory<K, V>, Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
Create an instance using the supplied producer factory and properties, with autoFlush false.
KafkaTestUtils - Class in org.springframework.kafka.test.utils
Kafka testing utilities.
KafkaTransactionManager<K,​V> - Class in org.springframework.kafka.transaction
PlatformTransactionManager implementation for a single Kafka ProducerFactory.
KafkaTransactionManager(ProducerFactory<K, V>) - Constructor for class org.springframework.kafka.transaction.KafkaTransactionManager
Create a new KafkaTransactionManager, given a ProducerFactory.
KafkaUtils - Class in org.springframework.kafka.support
Utility methods.
key(K) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
KEY_DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for key type information.
KEY_DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for key container object contents type information.
KEY_DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for key map key type information.
KEY_DEFAULT_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for the default key type if no header.
KEY_DESERIALIZER_CLASS - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Property name for the delegate key deserializer.
KEY_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Header name for deserialization exceptions.
KEY_DESERIALIZER_EXCEPTION_HEADER_PREFIX - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Header name for deserialization exceptions.
KEY_FUNCTION - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Supplier for a T when deserialization fails.
KEY_PARSER - Static variable in class org.springframework.kafka.support.serializer.ParseStringDeserializer
Property for the key parser method.
KEY_SERIALIZATION_SELECTOR - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
Name of the header containing the serialization selector for keys.
KEY_SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
Name of the configuration property containing the serialization selector map for keys with format selector:class,....
KEY_TYPE - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
Header for the type of key.
KEY_TYPE_METHOD - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
A method name to determine the JavaType to deserialize the key to: 'com.Foo.deserialize'.
keyDeserializer(boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Set to true if this deserializer is to be used as a key deserializer when configuring outside of Kafka.
keyValue(K, V) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
KSTREAM_DESERIALIZATION_RECOVERER - Static variable in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
Property name for configuring the recoverer using properties.

L

LATEST_ONLY - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
Commit the current offset during partition assignment when auto.offset.reset is 'latest'; transactional if so configured.
LATEST_ONLY_NO_TX - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
Commit the current offset during partition assignment when auto.offset.reset is 'latest'; use consumer commit even when transactions are being used.
level() - Method in annotation type org.springframework.kafka.test.condition.LogLevels
The Log4j level name to switch the categories to during the test.
LevelsContainer(Map<Class<?>, Level>, Map<String, Level>) - Constructor for class org.springframework.kafka.test.utils.JUnitUtils.LevelsContainer
 
lifecycleMonitor - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
ListenerContainerIdleEvent - Class in org.springframework.kafka.event
An event that is emitted when a container is idle if the container is configured to do so.
ListenerContainerIdleEvent(Object, Object, long, String, Collection<TopicPartition>, Consumer<?, ?>, boolean) - Constructor for class org.springframework.kafka.event.ListenerContainerIdleEvent
Construct an instance with the provided arguments.
ListenerContainerNoLongerIdleEvent - Class in org.springframework.kafka.event
An event that is emitted when a container is no longer idle if configured to publish idle events.
ListenerContainerNoLongerIdleEvent(Object, Object, long, String, Collection<TopicPartition>, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
Construct an instance with the provided arguments.
ListenerExecutionFailedException - Exception in org.springframework.kafka.listener
The listener specific KafkaException extension.
ListenerExecutionFailedException(String) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
Construct an instance with the provided properties.
ListenerExecutionFailedException(String, String, Throwable) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
Construct an instance with the provided properties.
ListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
Construct an instance with the provided properties.
ListenerInvokingBatchErrorHandler - Interface in org.springframework.kafka.listener
A batch error handler that is capable of invoking the listener during error handling.
ListenerType - Enum in org.springframework.kafka.listener
Defines the listener type.
ListenerUtils - Class in org.springframework.kafka.listener
Listener utilities.
listTopics() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
log(Supplier<CharSequence>) - Method in class org.springframework.kafka.support.LogIfLevelEnabled
 
log(Supplier<CharSequence>, Throwable) - Method in class org.springframework.kafka.support.LogIfLevelEnabled
 
Log4j2LevelAdjuster - Class in org.springframework.kafka.test.rule
A JUnit method @Rule that changes the logger level for a set of classes while a test method is running.
Log4j2LevelAdjuster(Level, Class<?>...) - Constructor for class org.springframework.kafka.test.rule.Log4j2LevelAdjuster
 
logger - Variable in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
logger - Variable in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
logger - Variable in class org.springframework.kafka.core.KafkaTemplate
 
logger - Variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
logger - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
logger - Variable in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
logger - Variable in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
 
logger - Variable in class org.springframework.kafka.listener.FailedRecordProcessor
 
logger - Variable in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
 
logger - Variable in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
 
logger - Variable in class org.springframework.kafka.support.converter.MessagingMessageConverter
 
LOGGER - Static variable in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
LogAccessor for use in default methods.
LoggingCommitCallback - Class in org.springframework.kafka.listener
Logs commit results at DEBUG level for success and ERROR for failures.
LoggingCommitCallback() - Constructor for class org.springframework.kafka.listener.LoggingCommitCallback
 
LoggingErrorHandler - Class in org.springframework.kafka.listener
The ErrorHandler implementation for logging purpose.
LoggingErrorHandler() - Constructor for class org.springframework.kafka.listener.LoggingErrorHandler
 
LoggingProducerListener<K,​V> - Class in org.springframework.kafka.support
The ProducerListener that logs exceptions thrown when sending messages.
LoggingProducerListener() - Constructor for class org.springframework.kafka.support.LoggingProducerListener
 
LogIfLevelEnabled - Class in org.springframework.kafka.support
Wrapper for a commons-logging Log supporting configurable logging levels.
LogIfLevelEnabled(LogAccessor, LogIfLevelEnabled.Level) - Constructor for class org.springframework.kafka.support.LogIfLevelEnabled
 
LogIfLevelEnabled.Level - Enum in org.springframework.kafka.support
Logging levels.
logLateArrival(ConsumerRecord<K, R>, CorrelationKey) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
LogLevels - Annotation Type in org.springframework.kafka.test.condition
Test classes annotated with this will change logging levels between tests.
LogLevelsCondition - Class in org.springframework.kafka.test.condition
JUnit condition that adjusts and reverts log levels before/after each test.
LogLevelsCondition() - Constructor for class org.springframework.kafka.test.condition.LogLevelsCondition
 

M

MANUAL - org.springframework.kafka.listener.ContainerProperties.AckMode
Listener is responsible for acking - use a AcknowledgingMessageListener; acks will be queued and offsets will be committed when all the records returned by the previous poll have been processed by the listener.
MANUAL_IMMEDIATE - org.springframework.kafka.listener.ContainerProperties.AckMode
Listener is responsible for acking - use a AcknowledgingMessageListener; the commit will be performed immediately if the Acknowledgment is acknowledged on the calling consumer thread; otherwise, the acks will be queued and offsets will be committed when all the records returned by the previous poll have been processed by the listener; results will be indeterminate if you sometimes acknowledge on the calling thread and sometimes not.
matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
 
matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
 
matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordTimestampMatcher
 
matches(Object, Description) - Method in class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordValueMatcher
 
matches(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
 
matches(String, Object) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
 
matches(ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordPartitionCondition
 
matches(ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordTimestampCondition
 
matches(ConsumerRecord<?, V>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordValueCondition
 
matches(ConsumerRecord<K, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyCondition
 
matches(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyValueCondition
 
matchHandlerMethod(Class<? extends Object>, InvocableHandlerMethod) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
 
matchHeader(String) - Method in interface org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
Return true if the header matches.
matchHeader(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
 
matchHeader(String) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
 
MESSAGE_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the message key when sending data to Kafka.
MessageConverter - Interface in org.springframework.kafka.support.converter
A top level interface for message converters.
MessageListener<K,​V> - Interface in org.springframework.kafka.listener
Listener for handling individual incoming Kafka messages.
MessageListenerContainer - Interface in org.springframework.kafka.listener
Internal abstraction used by the framework representing a message listener container.
MessagingFunction - Interface in org.springframework.kafka.streams.messaging
A function that receives a spring-messaging Message and returns a Message.
MessagingMessageConverter - Class in org.springframework.kafka.support.converter
A Messaging MessageConverter implementation for a message listener that receives individual messages.
MessagingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.MessagingMessageConverter
 
MessagingMessageListenerAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
An abstract MessageListener adapter providing the necessary infrastructure to extract the payload of a Message.
MessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
MessagingMessageListenerAdapter.ReplyExpressionRoot - Class in org.springframework.kafka.listener.adapter
Root object for reply expression evaluation.
MessagingTransformer<K,​V,​R> - Class in org.springframework.kafka.streams.messaging
A Transformer implementation that invokes a MessagingFunction converting to/from spring-messaging Message.
MessagingTransformer(MessagingFunction, MessagingMessageConverter) - Constructor for class org.springframework.kafka.streams.messaging.MessagingTransformer
 
MethodKafkaListenerEndpoint<K,​V> - Class in org.springframework.kafka.config
A KafkaListenerEndpoint providing the method to invoke to process an incoming message for this endpoint.
MethodKafkaListenerEndpoint() - Constructor for class org.springframework.kafka.config.MethodKafkaListenerEndpoint
 
metrics() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
metrics() - Method in interface org.springframework.kafka.core.KafkaOperations
See Producer.metrics().
metrics() - Method in class org.springframework.kafka.core.KafkaTemplate
 
metrics() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
metrics() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
metrics() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
metrics() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return metrics kept by this container's consumer(s), grouped by client-id.
metricsFromConsumer() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
metricsFromProducer() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
MICROMETER_PRESENT - Static variable in class org.springframework.kafka.support.KafkaUtils
True if micrometer is on the class path.
MicrometerConsumerListener<K,​V> - Class in org.springframework.kafka.core
A consumer factory listener that manages KafkaClientMetrics.
MicrometerConsumerListener(MeterRegistry) - Constructor for class org.springframework.kafka.core.MicrometerConsumerListener
Construct an instance with the provided registry.
MicrometerConsumerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.core.MicrometerConsumerListener
Construct an instance with the provided registry and tags.
MicrometerHolder - Class in org.springframework.kafka.support.micrometer
A wrapper for micrometer timers when available on the class path.
MicrometerHolder(ApplicationContext, String, String, String, Map<String, String>) - Constructor for class org.springframework.kafka.support.micrometer.MicrometerHolder
Create an instance with the provided properties.
MicrometerProducerListener<K,​V> - Class in org.springframework.kafka.core
A producer factory listener that manages KafkaClientMetrics.
MicrometerProducerListener(MeterRegistry) - Constructor for class org.springframework.kafka.core.MicrometerProducerListener
Construct an instance with the provided registry.
MicrometerProducerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.core.MicrometerProducerListener
Construct an instance with the provided registry and tags.
MultiMethodKafkaListenerEndpoint<K,​V> - Class in org.springframework.kafka.config
The MethodKafkaListenerEndpoint extension for several POJO methods based on the KafkaHandler.
MultiMethodKafkaListenerEndpoint(List<Method>, Object) - Constructor for class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
MultiMethodKafkaListenerEndpoint(List<Method>, Method, Object) - Constructor for class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
Construct an instance for the provided methods, default method and bean.

N

nack(int, long) - Method in interface org.springframework.kafka.support.Acknowledgment
Negatively acknowledge the record at an index in a batch - commit the offset(s) of records before the index and re-seek the partitions so that the record at the index and subsequent records will be redelivered after the sleep time.
nack(long) - Method in interface org.springframework.kafka.support.Acknowledgment
Negatively acknowledge the current record - discard remaining records from the poll and re-seek all partitions so that this record will be redelivered after the sleep time.
name(String) - Static method in class org.springframework.kafka.config.TopicBuilder
Create a TopicBuilder with the supplied name.
NATIVE_HEADERS - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the native headers of the consumer record; only provided if no header mapper is present.
NEVER - org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
Never commit the current offset during partition assignment.
NeverMatchHeaderMatcher(String...) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
 
NO_OFFSET - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
No offset found for a partition and no reset policy.
NonResponsiveConsumerEvent - Class in org.springframework.kafka.event
An event that is emitted when a consumer is not responding to the poll; a possible indication that the broker is down.
NonResponsiveConsumerEvent(Object, long, String, Collection<TopicPartition>, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.NonResponsiveConsumerEvent
Deprecated.
NonResponsiveConsumerEvent(Object, Object, long, String, Collection<TopicPartition>, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.NonResponsiveConsumerEvent
Construct an instance with the provided properties.
NonTrustedHeaderType() - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
NORMAL - org.springframework.kafka.event.ConsumerStoppedEvent.Reason
The consumer was stopped because the container was stopped.
noTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerde
Configure the serializer to not add type information.
noTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
Do not include type info headers.
NULL_MESSAGE - Static variable in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Message used when no conversion is needed.

O

objectMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
objectMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
 
offset() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
OFFSET - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for the partition offset.
offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
onApplicationEvent(ContextStoppedEvent) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
onApplicationEvent(ContextStoppedEvent) - Method in class org.springframework.kafka.core.KafkaTemplate
 
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in class org.springframework.kafka.listener.LoggingCommitCallback
 
onError(ProducerRecord<K, V>, Exception) - Method in class org.springframework.kafka.support.CompositeProducerListener
Deprecated.
onError(ProducerRecord<K, V>, Exception) - Method in interface org.springframework.kafka.support.ProducerListener
onError(ProducerRecord<K, V>, RecordMetadata, Exception) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
onError(ProducerRecord<K, V>, RecordMetadata, Exception) - Method in class org.springframework.kafka.support.LoggingProducerListener
 
onError(ProducerRecord<K, V>, RecordMetadata, Exception) - Method in interface org.springframework.kafka.support.ProducerListener
Invoked after an attempt to send a message has failed.
onFailure(Throwable) - Method in interface org.springframework.kafka.core.KafkaFailureCallback
 
onFailure(KafkaProducerException) - Method in interface org.springframework.kafka.core.KafkaFailureCallback
Called when the send fails.
onIdleContainer(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
onIdleContainer(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
onIdleContainer(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
If the container is configured to emit idle container events, this method is called when the container idle event is emitted - allowing a seek operation.
onMessage(List<ConsumerRecord<K, Collection<ConsumerRecord<K, R>>>>, Consumer<?, ?>) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
 
onMessage(List<ConsumerRecord<K, R>>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
onMessage(List<ConsumerRecord<K, V>>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.BatchConsumerAwareMessageListener
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingMessageListener
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Kafka MessageListener entry point.
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.AcknowledgingMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.ConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in interface org.springframework.kafka.listener.AcknowledgingMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecords<K, V>, Acknowledgment, Consumer<K, V>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
 
onMessage(ConsumerRecords<K, V>, Acknowledgment, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchMessageListener
Listener receives the original ConsumerRecords object instead of a list of ConsumerRecord.
onMessage(T) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka.
onMessage(T, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka and provides access to the Consumer.
onMessage(T, Acknowledgment) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka.
onMessage(T, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka and provides access to the Consumer.
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
When using group management, called when partition assignments change.
onPartitionsAssigned(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsAssigned(Collection) with the additional consumer parameter.
onPartitionsLost(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsLost(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsLost(Collection) with an additional consumer parameter.
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
When using group management, called when partition assignments are revoked.
onPartitionsRevokedAfterCommit(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsRevoked(Collection) with the additional consumer parameter.
onPartitionsRevokedBeforeCommit(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsRevoked(Collection) with the additional consumer parameter.
onSuccess(ProducerRecord<K, V>, RecordMetadata) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
onSuccess(ProducerRecord<K, V>, RecordMetadata) - Method in interface org.springframework.kafka.support.ProducerListener
Invoked after the successful send of a message (that is, after it has been acknowledged by the broker).
onTopOf(KStream<K, V>) - Method in class org.springframework.kafka.support.KafkaStreamBrancher
Terminating method that builds branches on top of given KStream.
OPTIONAL - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Optional - The LoginModule is not required to succeed.
org.springframework.kafka - package org.springframework.kafka
Base package for kafka
org.springframework.kafka.annotation - package org.springframework.kafka.annotation
Package for kafka annotations
org.springframework.kafka.config - package org.springframework.kafka.config
Package for kafka configuration
org.springframework.kafka.core - package org.springframework.kafka.core
Package for kafka core components
org.springframework.kafka.core.reactive - package org.springframework.kafka.core.reactive
Reactive component for consumer and producer.
org.springframework.kafka.event - package org.springframework.kafka.event
Application Events.
org.springframework.kafka.listener - package org.springframework.kafka.listener
Package for kafka listeners
org.springframework.kafka.listener.adapter - package org.springframework.kafka.listener.adapter
Provides classes for adapting listeners.
org.springframework.kafka.requestreply - package org.springframework.kafka.requestreply
Provides classes for request/reply semantics.
org.springframework.kafka.security.jaas - package org.springframework.kafka.security.jaas
Provides classes related to jaas.
org.springframework.kafka.streams - package org.springframework.kafka.streams
Package for classes related to Kafka Streams.
org.springframework.kafka.streams.messaging - package org.springframework.kafka.streams.messaging
Package for classes related to spring-messaging with Kafka Streams.
org.springframework.kafka.support - package org.springframework.kafka.support
Package for kafka support
org.springframework.kafka.support.converter - package org.springframework.kafka.support.converter
Package for kafka converters
org.springframework.kafka.support.micrometer - package org.springframework.kafka.support.micrometer
Provides classes to support Micrometer.
org.springframework.kafka.support.serializer - package org.springframework.kafka.support.serializer
 
org.springframework.kafka.test - package org.springframework.kafka.test
 
org.springframework.kafka.test.assertj - package org.springframework.kafka.test.assertj
 
org.springframework.kafka.test.condition - package org.springframework.kafka.test.condition
Provides classes for JUnit5 conditions.
org.springframework.kafka.test.context - package org.springframework.kafka.test.context
 
org.springframework.kafka.test.core - package org.springframework.kafka.test.core
 
org.springframework.kafka.test.hamcrest - package org.springframework.kafka.test.hamcrest
 
org.springframework.kafka.test.rule - package org.springframework.kafka.test.rule
 
org.springframework.kafka.test.utils - package org.springframework.kafka.test.utils
 
org.springframework.kafka.transaction - package org.springframework.kafka.transaction
Provides classes related to transactions.

P

parentOrThis() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Return this or a parent container if this has a parent.
parentOrThis() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
parseBooleanProperty(String) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
Return the parsed value if the provided property exists in the environment or system properties.
PARSER_CONTEXT - Static variable in class org.springframework.kafka.listener.adapter.AdapterUtils
Parser context for runtime SpEL using ! as the template prefix.
ParseStringDeserializer<T> - Class in org.springframework.kafka.support.serializer
Generic Deserializer for deserialization of entity from its String representation received from Kafka (a.k.a parsing).
ParseStringDeserializer() - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
Construct an instance with no parser function; a static method name must be provided in the consumer config ParseStringDeserializer.KEY_PARSER or ParseStringDeserializer.VALUE_PARSER properties.
ParseStringDeserializer(BiFunction<String, Headers, T>) - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
Construct an instance with the supplied parser function.
ParseStringDeserializer(Function<String, T>) - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
Construct an instance with the supplied parser function.
PARTIAL_RESULTS_AFTER_TIMEOUT_TOPIC - Static variable in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
Pseudo topic name for the "outer" ConsumerRecord that has the aggregated results in its value after a timeout.
partition() - Method in annotation type org.springframework.kafka.annotation.PartitionOffset
The partition within the topic to listen on.
partition() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
partition(int) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
PARTITION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic partition when sending data to Kafka.
PartitionOffset - Annotation Type in org.springframework.kafka.annotation
Used to add partition/initial offset information to a KafkaListener.
partitionOffsets() - Method in annotation type org.springframework.kafka.annotation.TopicPartition
The partitions with initial offsets within the topic.
partitions() - Method in annotation type org.springframework.kafka.annotation.TopicPartition
The partitions within the topic.
partitions() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
 
partitions(int) - Method in class org.springframework.kafka.config.TopicBuilder
Set the number of partitions (default broker 'num.partitions').
partitionsFor(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
partitionsFor(String) - Method in interface org.springframework.kafka.core.KafkaOperations
See Producer.partitionsFor(String).
partitionsFor(String) - Method in class org.springframework.kafka.core.KafkaTemplate
 
partitionsFromConsumerFor(String) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
partitionsFromProducerFor(String) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
pause() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
pause() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
pause() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Pause this container before the next poll().
pause(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
paused() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
ports() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Set explicit ports on which the kafka brokers will listen.
position(TopicPartition) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
PREFIX - Static variable in class org.springframework.kafka.support.KafkaHeaders
The prefix for Kafka headers.
primary() - Method in class org.springframework.kafka.core.ABSwitchCluster
Use the primary cluster.
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, Exception, boolean) - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, Exception, boolean) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
Deprecated.
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, Exception, boolean, ContainerProperties.EOSMode) - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
Process the remaining records.
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
 
processKafkaListener(KafkaListener, Method, Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
processListener(MethodKafkaListenerEndpoint<?, ?>, KafkaListener, Object, Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
producerAdded(String, Producer<K, V>) - Method in class org.springframework.kafka.core.MicrometerProducerListener
 
producerAdded(String, Producer<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory.Listener
A new producer was created.
ProducerFactory<K,​V> - Interface in org.springframework.kafka.core
The strategy to produce a Producer instance(s).
ProducerFactory.Listener<K,​V> - Interface in org.springframework.kafka.core
Called whenever a producer is added or removed.
ProducerFactoryUtils - Class in org.springframework.kafka.core
Helper class for managing a Spring based Kafka DefaultKafkaProducerFactory in particular for obtaining transactional Kafka resources for a given ProducerFactory.
ProducerListener<K,​V> - Interface in org.springframework.kafka.support
Listener for handling outbound Kafka messages.
ProducerPostProcessor<K,​V> - Interface in org.springframework.kafka.core
Called by producer factories to perform post processing on newly created producers.
producerProps(String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Set up test properties for an <Integer, String> producer.
producerProps(EmbeddedKafkaBroker) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Set up test properties for an <Integer, String> producer.
producerRemoved(String, Producer<K, V>) - Method in class org.springframework.kafka.core.MicrometerProducerListener
 
producerRemoved(String, Producer<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory.Listener
An exsting producer was removed.
ProjectingMessageConverter - Class in org.springframework.kafka.support.converter
A MessageConverter implementation that uses a Spring Data ProjectionFactory to bind incoming messages to projection interfaces.
ProjectingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
ProjectingMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
Create a new ProjectingMessageConverter using the given ObjectMapper.
ProjectingMessageConverter(ObjectMapper, MessagingMessageConverter) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
Create a new ProjectingMessageConverter using the given ObjectMapper.
ProjectingMessageConverter(MessagingMessageConverter) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
Create a new ProjectingMessageConverter using the given ObjectMapper.
properties() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
Kafka consumer properties; they will supersede any properties with the same name defined in the consumer factory (if the consumer factory supports property overrides).
propertyToMethodInvokingFunction(String, Class<P>, ClassLoader) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
Convert a property value (FQCN.methodName) to a BiFunction that takes a payload and headers and returns some value.
publish(ProducerRecord<Object, Object>, KafkaOperations<Object, Object>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Override this if you want more than just logging of the send result.
publishContainerStoppedEvent() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 

R

RAW_DATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the raw data received from Kafka (ConsumerRecord or ConsumerRecords).
ReactiveKafkaConsumerTemplate<K,​V> - Class in org.springframework.kafka.core.reactive
Reactive kafka consumer operations implementation.
ReactiveKafkaConsumerTemplate(ReceiverOptions<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
ReactiveKafkaProducerTemplate<K,​V> - Class in org.springframework.kafka.core.reactive
Reactive kafka producer operations implementation.
ReactiveKafkaProducerTemplate(SenderOptions<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
ReactiveKafkaProducerTemplate(SenderOptions<K, V>, RecordMessageConverter) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
receive() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
receiveAtMostOnce() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
receiveAutoAck() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
RECEIVED - Static variable in class org.springframework.kafka.support.KafkaHeaders
The prefix for Kafka headers containing 'received' values.
RECEIVED_MESSAGE_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the message key for the received message.
RECEIVED_PARTITION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic partition for the received message.
RECEIVED_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the timestamp of the consumer record.
RECEIVED_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic from which the message was received.
receiveExactlyOnce(TransactionManager) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
Returns a Flux of consumer record batches that may be used for exactly once delivery semantics.
RECORD - org.springframework.kafka.listener.ContainerProperties.AckMode
Commit the offset after each record is processed by the listener.
RECORD_METADATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the RecordMetadata object after successful send to the topic.
RecordFilterStrategy<K,​V> - Interface in org.springframework.kafka.listener.adapter
Implementations of this interface can signal that a record about to be delivered to a message listener should be discarded instead of being delivered.
RecordInterceptor<K,​V> - Interface in org.springframework.kafka.listener
An interceptor for ConsumerRecord invoked by the listener container before and after invoking the listener.
RecordMessageConverter - Interface in org.springframework.kafka.support.converter
A Kafka-specific Message converter strategy.
RecordMessagingMessageListenerAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
A MessageListener adapter that invokes a configurable HandlerAdapter; used when the factory is configured for the listener to receive individual messages.
RecordMessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
 
RecordMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
 
recordToString(ConsumerRecord<?, ?>) - Static method in class org.springframework.kafka.listener.ListenerUtils
Return the ConsumerRecord as a String; either toString() or topic-partition@offset.
recordToString(ConsumerRecord<?, ?>, boolean) - Static method in class org.springframework.kafka.listener.ListenerUtils
Return the ConsumerRecord as a String; either toString() or topic-partition@offset.
RecoveringBatchErrorHandler - Class in org.springframework.kafka.listener
An error handler that seeks to the current offset for each topic in a batch of records.
RecoveringBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Construct an instance with the default recoverer which simply logs the record after 10 (maxFailures) have occurred for a topic/partition/offset.
RecoveringBatchErrorHandler(BiConsumer<ConsumerRecord<?, ?>, Exception>) - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Construct an instance with the provided recoverer which will be called after 10 (maxFailures) have occurred for a topic/partition/offset.
RecoveringBatchErrorHandler(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
RecoveringBatchErrorHandler(BackOff) - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Construct an instance with the default recoverer which simply logs the record after the backOff returns STOP for a topic/partition/offset.
RecoveringDeserializationExceptionHandler - Class in org.springframework.kafka.streams
A DeserializationExceptionHandler that calls a ConsumerRecordRecoverer.
RecoveringDeserializationExceptionHandler() - Constructor for class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
 
RecoveringDeserializationExceptionHandler(ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
 
registerAllEndpoints() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
 
registerEndpoint(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Register a new KafkaListenerEndpoint using the default KafkaListenerContainerFactory to create the underlying container.
registerEndpoint(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Register a new KafkaListenerEndpoint alongside the KafkaListenerContainerFactory to use to create the underlying container.
registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Create a message listener container for the given KafkaListenerEndpoint.
registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>, boolean) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Create a message listener container for the given KafkaListenerEndpoint.
registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
Register the callback to use when seeking at some arbitrary time.
relativeToCurrent() - Method in annotation type org.springframework.kafka.annotation.PartitionOffset
By default, positive PartitionOffset.initialOffset() is absolute, negative is relative to the current topic end.
releaseResources(KafkaResourceHolder<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
 
RemainingRecordsErrorHandler - Interface in org.springframework.kafka.listener
An error handler that has access to the unprocessed records from the last poll (including the failed record) and the consumer, for example to adjust offsets after an error.
REMOVE_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for removing type headers (default true).
removeConfig(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
removeConfig(String) - Method in interface org.springframework.kafka.core.ProducerFactory
Remove the specified key from the configuration map.
removeDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
 
removeDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
 
removeDelegate(ProducerListener<K, V>) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
removeHeaders(Headers) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
removeHeaders(Headers) - Method in interface org.springframework.kafka.support.converter.Jackson2JavaTypeMapper
Remove the type information headers.
removeListener(StreamsBuilderFactoryBean.Listener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Remove a listener.
removeListener(ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
Remove a listener.
removeListener(ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Remove a listener.
removeListener(ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Remove a listener.
removeListener(ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
Remove a listener.
removeNotRetryableException(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Remove an exception type from the configured list.
removePostProcessor(ConsumerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
Remove a post processor.
removePostProcessor(ConsumerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
removePostProcessor(ProducerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
removePostProcessor(ProducerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
Remove a post processor.
removeProducer(DefaultKafkaProducerFactory.CloseSafeProducer<K, V>, Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Remove the single shared producer and a thread-bound instance if present.
renderProperties() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
replicas(int) - Method in class org.springframework.kafka.config.TopicBuilder
Set the number of replicas (default broker 'default.replication.factor').
replicasAssignments(Map<Integer, List<Integer>>) - Method in class org.springframework.kafka.config.TopicBuilder
Set the replica assignments.
REPLY_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing a partition number on which to send the reply.
REPLY_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the default reply topic.
ReplyExpressionRoot(Object, Object, Object) - Constructor for class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
ReplyHeadersConfigurer - Interface in org.springframework.kafka.listener.adapter
A strategy for configuring which headers, if any, should be set in a reply message.
ReplyingKafkaOperations<K,​V,​R> - Interface in org.springframework.kafka.requestreply
Request/reply operations.
ReplyingKafkaTemplate<K,​V,​R> - Class in org.springframework.kafka.requestreply
A KafkaTemplate that implements request/reply semantics.
ReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Constructor for class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
ReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>, boolean) - Constructor for class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
RequestReplyFuture<K,​V,​R> - Class in org.springframework.kafka.requestreply
A listenable future for requests/replies.
RequestReplyFuture() - Constructor for class org.springframework.kafka.requestreply.RequestReplyFuture
 
REQUIRED - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Required - The LoginModule is required to succeed.
REQUISITE - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Requisite - The LoginModule is required to succeed.
reset() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Close the Producer(s) and clear the cache of transactional Producer(s).
reset() - Method in interface org.springframework.kafka.core.ProducerFactory
Reset any state in the factory, if supported.
resolveParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
 
resolveType(String, byte[], Headers) - Method in interface org.springframework.kafka.support.serializer.JsonTypeResolver
Determine the type.
restart(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
resume() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
resume() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
resume() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Resume this container, if paused, after the next poll().
resume(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
retrieveHeader(Headers, String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
retrieveHeaderAsString(Headers, String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
RetryingBatchErrorHandler - Class in org.springframework.kafka.listener
A batch error handler that invokes the listener according to the supplied BackOff.
RetryingBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.RetryingBatchErrorHandler
Construct an instance with a default FixedBackOff (unlimited attempts with a 5 second back off).
RetryingBatchErrorHandler(BackOff, ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.listener.RetryingBatchErrorHandler
Construct an instance with the provided BackOff and ConsumerRecordRecoverer.
RetryingDeserializer<T> - Class in org.springframework.kafka.support.serializer
A deserialzer configured with a delegate and a RetryOperations to retry deserialization in case of transient errors.
RetryingDeserializer(Deserializer<T>, RetryOperations) - Constructor for class org.springframework.kafka.support.serializer.RetryingDeserializer
 
RetryingMessageListenerAdapter<K,​V> - Class in org.springframework.kafka.listener.adapter
A retrying message listener adapter for MessageListeners.
RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
Construct an instance with the provided template and delegate.
RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate, RecoveryCallback<? extends Object>) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
Construct an instance with the provided template, callback and delegate.
RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate, RecoveryCallback<? extends Object>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
Construct an instance with the provided template, callback and delegate.
returnTypeMessageOrCollectionOf(Method) - Static method in class org.springframework.kafka.support.KafkaUtils
Return true if the method return type is Message or Collection<Message<?>>.
revertLevels(String, JUnitUtils.LevelsContainer) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
 
rollback() - Method in class org.springframework.kafka.core.KafkaResourceHolder
 
RoutingKafkaTemplate - Class in org.springframework.kafka.core
A KafkaTemplate that routes messages based on the topic name.
RoutingKafkaTemplate(Map<Pattern, ProducerFactory<Object, Object>>) - Constructor for class org.springframework.kafka.core.RoutingKafkaTemplate
Construct an instance with the provided properties.

S

secondary() - Method in class org.springframework.kafka.core.ABSwitchCluster
Use the secondary cluster.
seek(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek operation.
seek(TopicPartition, long) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
seekOrRecover(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer, boolean, BiPredicate<ConsumerRecord<?, ?>, Exception>, LogAccessor, KafkaException.Level) - Static method in class org.springframework.kafka.listener.SeekUtils
Seek the remaining records, optionally recovering the first.
seekPartitions(Consumer<?, ?>, Map<TopicPartition, Long>, LogAccessor) - Static method in class org.springframework.kafka.listener.SeekUtils
Perform seek operations on each partition.
seekRelative(String, int, long, boolean) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek relative to the start, end, or current position.
seekToBeginning() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
Seek all assigned partitions to the beginning.
seekToBeginning(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek to beginning operation.
seekToBeginning(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek to beginning operation.
seekToBeginning(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
SeekToCurrentBatchErrorHandler - Class in org.springframework.kafka.listener
An error handler that seeks to the current offset for each topic in a batch of records.
SeekToCurrentBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
 
SeekToCurrentErrorHandler - Class in org.springframework.kafka.listener
An error handler that seeks to the current offset for each topic in the remaining records.
SeekToCurrentErrorHandler() - Constructor for class org.springframework.kafka.listener.SeekToCurrentErrorHandler
Construct an instance with the default recoverer which simply logs the record after 10 (maxFailures) have occurred for a topic/partition/offset.
SeekToCurrentErrorHandler(BiConsumer<ConsumerRecord<?, ?>, Exception>) - Constructor for class org.springframework.kafka.listener.SeekToCurrentErrorHandler
Construct an instance with the provided recoverer which will be called after 10 (maxFailures) have occurred for a topic/partition/offset.
SeekToCurrentErrorHandler(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.SeekToCurrentErrorHandler
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
SeekToCurrentErrorHandler(BackOff) - Constructor for class org.springframework.kafka.listener.SeekToCurrentErrorHandler
Construct an instance with the default recoverer which simply logs the record after the backOff returns STOP for a topic/partition/offset.
seekToEnd() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
Seek all assigned partitions to the end.
seekToEnd(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek to end operation.
seekToEnd(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek to end operation.
seekToEnd(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
seekToTimestamp(long) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
Seek all assigned partitions to the offset represented by the timestamp.
seekToTimestamp(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek to the first offset greater than or equal to the time stamp.
seekToTimestamp(Collection<TopicPartition>, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Perform a seek to the first offset greater than or equal to the time stamp.
SeekUtils - Class in org.springframework.kafka.listener
Seek utilities.
selectImports(AnnotationMetadata) - Method in class org.springframework.kafka.annotation.KafkaListenerConfigurationSelector
 
selfLog(String, LogAccessor) - Method in exception org.springframework.kafka.KafkaException
Log this exception at its log level.
send(String, int, long, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(String, int, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(String, Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the provided topic with the provided key and partition.
send(String, Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the provided topic with the provided key and partition.
send(String, Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the provided topic with the provided key and no partition.
send(String, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(String, Message<?>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(String, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the provided topic with no key or partition.
send(String, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
send(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the provided ProducerRecord.
send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(ProducerRecord<K, V>, Callback) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
send(Publisher<? extends SenderRecord<K, V, T>>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
send(Message<?>) - Method in interface org.springframework.kafka.core.KafkaOperations
Send a message with routing information in message headers.
send(Message<?>) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(SenderRecord<K, V, T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
sendAndReceive(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
Send a request and receive a reply with the default timeout.
sendAndReceive(ProducerRecord<K, V>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
sendAndReceive(ProducerRecord<K, V>, Duration) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
Send a request and receive a reply.
sendAndReceive(ProducerRecord<K, V>, Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
sendDefault(Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the default topic with the provided key and partition.
sendDefault(Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendDefault(Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the default topic with the provided key and partition.
sendDefault(Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendDefault(K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the default topic with the provided key and no partition.
sendDefault(K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendDefault(V) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the data to the default topic with no key or partition.
sendDefault(V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.springframework.kafka.core.KafkaOperations
When running in a transaction, send the consumer offset(s) to the transaction.
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.springframework.kafka.core.KafkaOperations
When running in a transaction, send the consumer offset(s) to the transaction.
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.springframework.kafka.core.KafkaOperations
When running in a transaction, send the consumer offset(s) to the transaction.
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendResponse(Object, String, Object, boolean) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Send the result to the topic.
SendResult<K,​V> - Class in org.springframework.kafka.support
Result for a ListenableFuture after a send.
SendResult(ProducerRecord<K, V>, RecordMetadata) - Constructor for class org.springframework.kafka.support.SendResult
 
sendTransactionally(Publisher<? extends SenderRecord<K, V, T>>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
sendTransactionally(SenderRecord<K, V, T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
SERIALIZATION_SELECTOR - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingDeserializer
SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
SerializationUtils - Class in org.springframework.kafka.support.serializer
Utilities for serialization.
serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
 
serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
 
serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
 
serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
 
serialize(String, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
serialize(String, T) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
 
serializedKeySize() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
serializedValueSize() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
serializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
 
serializer() - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
 
setAckAfterHandle(boolean) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
Set to false to prevent the container from committing the offset of a recovered record (when the error handler does not itself throw an exception).
setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.RecoveringBatchErrorHandler
 
setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.RetryingBatchErrorHandler
 
setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.SeekToCurrentErrorHandler
 
setAckCount(int) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the number of outstanding record count after which offsets should be committed when ContainerProperties.AckMode.COUNT or ContainerProperties.AckMode.COUNT_TIME is being used.
setAckDiscarded(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
setAckDiscarded(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set to true to ack discards when a filter strategy is in use.
setAckMode(ContainerProperties.AckMode) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the ack mode to use when auto ack (in the configuration properties) is false.
setAckOnError(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Deprecated.
in favor of GenericErrorHandler.isAckAfterHandle().
setAckTime(long) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the time (ms) after which outstanding offsets should be committed when ContainerProperties.AckMode.TIME or ContainerProperties.AckMode.COUNT_TIME is being used.
setAddTypeInfo(boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
Set to false to disable adding type info headers.
setAddTypeInfo(boolean) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
Set to false to disable adding type info headers.
setAdminTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set the timeout in seconds for admin operations (e.g.
setAdviceChain(Advice...) - Method in class org.springframework.kafka.listener.ContainerProperties
Set a chain of listener Advices; must not be null or have null elements.
setAfterRollbackProcessor(AfterRollbackProcessor<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set a processor to invoke after a transaction rollback; typically will seek the unprocessed topic/partition to reprocess the records.
setAfterRollbackProcessor(AfterRollbackProcessor<? super K, ? super V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Set a processor to perform seeks on unprocessed records after a rollback.
setAllowNonTransactional(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
Set to true to allow a non-transactional send when the template is transactional.
setAlwaysClientIdSuffix(boolean) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
Set to false to suppress adding a suffix to the child container's client.id when the concurrency is only 1.
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaAdmin
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaTemplate
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setAssignmentCommitOption(ContainerProperties.AssignmentCommitOption) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the assignment commit option.
setAuthorizationExceptionRetryInterval(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the interval between retries after AuthorizationException is thrown by KafkaConsumer.
setAutoCreate(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
Set to false to suppress auto creation of topics during context initialization.
setAutoStartup(boolean) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setAutoStartup(boolean) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Set the autoStartup.
setAutoStartup(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Specify an autoStartup boolean flag.
setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the autoStartup for this endpoint's container.
setBackOff(BackOff) - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
Set a BackOff to suspend the thread after performing the seek.
setBackOffFunction(BiFunction<ConsumerRecord<?, ?>, Exception, BackOff>) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Set a function to dynamically determine the BackOff to use, based on the consumer record and/or exception.
setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the batch error handler to call when the listener throws an exception.
setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Set the batch error handler to call when the listener throws an exception.
setBatchInterceptor(BatchInterceptor<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set a batch interceptor to be called before and after calling the listener.
setBatchInterceptor(BatchInterceptor<K, V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Set an interceptor to be called before calling the record listener.
setBatchListener(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set to true if this endpoint should create a batch listener.
setBatchListener(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set to true if this endpoint should create a batch listener.
setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Set the BatchMessageConverter.
setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
setBean(Object) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Set the object instance that should manage this endpoint.
setBeanClassLoader(ClassLoader) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
Making a BeanFactory available is optional; if not set, KafkaListenerConfigurer beans won't get autodetected and an endpoint registry has to be explicitly configured.
setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
A BeanFactory only needs to be available in conjunction with KafkaListenerEndpointRegistrar.setContainerFactoryBeanName(java.lang.String).
setBeanName(String) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setBeanName(String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
setBeanName(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
setBeanName(String) - Method in class org.springframework.kafka.core.KafkaTemplate
 
setBeanName(String) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setBeanResolver(BeanResolver) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set a bean resolver for runtime SpEL expressions.
setBootstrapServersSupplier(Supplier<String>) - Method in class org.springframework.kafka.core.KafkaResourceFactory
Set a supplier for the bootstrap server list to override any configured in a subclass.
setCharset(Charset) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
Set a charset to use when converting byte[] to String in method arguments.
setCharset(Charset) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
Set the charset to use when mapping String-valued headers to/from byte[].
setCharset(Charset) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
Set a charset to use when converting byte[] to String.
setCharset(Charset) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
Set a charset to use when converting String to byte[].
setClassIdFieldName(String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Configure header name for type information.
setClassifications(Map<Class<? extends Throwable>, Boolean>, boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Set an exception classifications to determine whether the exception should cause a retry (until exhaustion) or not.
setCleanupConfig(CleanupConfig) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setClientId(String) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the client id; overrides the consumer factory client.id property.
setClientIdPrefix(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the client id prefix; overrides the client id in the consumer configuration properties.
setClientIdSuffix(String) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
Set a suffix to add to the client.id consumer property (if the consumer factory supports it).
setClientSupplier(KafkaClientSupplier) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setCloseTimeout(int) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Specify the timeout in seconds for the KafkaStreams.close(Duration) operation.
setCloseTimeout(int) - Method in class org.springframework.kafka.core.KafkaAdmin
Set the close timeout in seconds.
setCloseTimeout(Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
Set the maximum time to wait when closing a producer; default 5 seconds.
setCloseTimeout(Duration) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
Set the maximum time to wait when closing a producer; default 5 seconds.
setCommitCallback(OffsetCommitCallback) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
setCommitLogLevel(LogIfLevelEnabled.Level) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the level at which to log offset commits.
setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Set to true to commit the offset for a recovered record.
setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.SeekToCurrentErrorHandler
Set to true to commit the offset for a recovered record.
setCommitRetries(int) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set number of retries allowed when a RetriableCommitFailedException is thrown by the consumer.
setCommitTimeout(Duration) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
Set the timeout to use when committing offsets.
setConcurrency(int) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
The maximum number of concurrent KafkaMessageListenerContainers running.
setConcurrency(Integer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the concurrency for this endpoint's container.
setConcurrency(Integer) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
Specify the container concurrency.
setConsumerFactory(ConsumerFactory<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Specify a ConsumerFactory to use.
setConsumerGroupId(String) - Static method in class org.springframework.kafka.support.KafkaUtils
Set the group id for the consumer bound to this thread.
setConsumerProperties(Properties) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
setConsumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the user defined ConsumerRebalanceListener implementation.
setConsumerStartTimeout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the timeout to wait for a consumer thread to start before logging an error.
setConsumerStartTimout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
Deprecated.
setConsumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the executor for threads that poll the consumer.
setContainerCustomizer(ContainerCustomizer<K, V, C>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set a customizer used to further configure a container after it has been created.
setContainerFactory(KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Set the KafkaListenerContainerFactory to use in case a KafkaListenerEndpoint is registered with a null container factory.
setContainerFactoryBeanName(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Set the bean name of the KafkaListenerContainerFactory to use in case a KafkaListenerEndpoint is registered with a null container factory.
setContentClassIdFieldName(String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Configure header name for container object contents type information.
setControlFlag(KafkaJaasLoginModuleInitializer.ControlFlag) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
setCorrelationHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set a custom header name for the correlation id.
setCorrelationIdStrategy(Function<ProducerRecord<K, V>, CorrelationKey>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set a function to be called to establish a unique correlation key for each request record.
setCustomMethodArgumentResolvers(HandlerMethodArgumentResolver...) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Add custom methods arguments resolvers to KafkaListenerAnnotationBeanPostProcessor Default empty list.
setDefaultContainerFactoryBeanName(String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
Set the name of the KafkaListenerContainerFactory to use by default.
setDefaultReplyTimeout(Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set the reply timeout used if no replyTimeout is provided in the ReplyingKafkaTemplate.sendAndReceive(ProducerRecord, Duration) call.
setDefaultTopic(String) - Method in class org.springframework.kafka.core.KafkaTemplate
Set the default topic for send methods where a topic is not provided.
setDelegates(ProducerListener<K, V>...) - Method in class org.springframework.kafka.support.CompositeProducerListener
 
setDeliveryAttemptHeader(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Set to true to populate the KafkaHeaders.DELIVERY_ATTEMPT header when the error handler or after rollback processor implements DeliveryAttemptAware.
setEmergencyStop(Runnable) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
Set a Runnable to call whenever an Error occurs on a listener thread.
setEncodeStrings(boolean) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Set to true to encode String-valued headers as JSON ("..."), by default just the raw String value is converted to a byte array using the configured charset.
setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
Set the KafkaListenerEndpointRegistry that will hold the created endpoint and manage the lifecycle of the related listener container.
setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Set the KafkaListenerEndpointRegistry instance to use.
setEosMode(ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the exactly once semantics mode.
setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the error handler to call when the listener throws an exception.
setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Set the error handler to call when the listener throws an exception.
setErrorHandler(KafkaListenerErrorHandler) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Set the KafkaListenerErrorHandler to invoke if the listener method throws an exception.
setFailedDeserializationFunction(Function<FailedDeserializationInfo, T>) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Provide an alternative supplying mechanism when deserialization fails.
setFallbackType(Class<?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set a fallback type to use when using a type-aware message converter and this adapter cannot determine the inferred type from the method.
setFatalIfBrokerNotAvailable(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
Set to true if you want the application context to fail to load if we are unable to connect to the broker during initialization, to check/add topics.
setFixTxOffsets(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
When consuming records produced by a transactional producer, and the consumer is positioned at the end of a partition, the lag can incorrectly be reported as greater than zero, due to the pseudo record used to indicate transaction commit/rollback and, possibly, the presence of rolled-back records.
setForKey(boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Set to true if this deserializer is to be used as a key deserializer when configuring outside of Kafka.
setGenerateMessageId(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Generate Message ids for produced messages.
setGenerateMessageId(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Generate Message ids for produced messages.
setGenerateTimestamp(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Generate timestamp for produced messages.
setGenerateTimestamp(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Generate timestamp for produced messages.
setGenericErrorHandler(GenericErrorHandler<?>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Set the error handler to call when the listener throws an exception.
setGroup(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the group for the corresponding listener container.
setGroupId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the group id to override the group.id property in the ContainerFactory.
setGroupId(String) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the group id for this container.
setHandlerMethod(HandlerAdapter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set the HandlerAdapter to use to invoke the method processing an incoming ConsumerRecord.
setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
Set the header mapper to map headers.
setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Set the header mapper to map headers.
setHeaders(Headers) - Method in exception org.springframework.kafka.support.serializer.DeserializationException
Set the headers.
setHeadersFunction(BiFunction<ConsumerRecord<?, ?>, Exception, Headers>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Set a function which will be called to obtain additional headers to add to the published record.
setHeaderValue(byte[]) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
setId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
setIdleBetweenPolls(long) - Method in class org.springframework.kafka.listener.ContainerProperties
The sleep interval in milliseconds used in the main loop between Consumer.poll(Duration) calls.
setIdleEventInterval(Long) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
setIncludeContents(boolean) - Method in class org.springframework.kafka.support.LoggingProducerListener
Whether the log message should include the contents (key and payload).
setInfrastructureCustomizer(KafkaStreamsInfrastructureCustomizer) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Set a customizer to configure the builder and/or topology before creating the stream.
setInterceptBeforeTx(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
When true, invoke the interceptor before the transaction starts.
setKafkaConsumerProperties(Properties) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
setKafkaOperations(KafkaOperations<K, V>) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
setKafkaStreamsCustomizer(KafkaStreamsCustomizer) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Specify a KafkaStreamsCustomizer to customize a KafkaStreams instance during StreamsBuilderFactoryBean.start().
setKafkaTemplate(KafkaTemplate<K, V>) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
setKeyClassIdFieldName(String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Configure header name for map key type information.
setKeyDeserializer(Deserializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Set the key deserializer.
setKeySerializer(Serializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set a key serializer.
setLogContainerConfig(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Set to true to instruct each container to log this configuration.
setLoginModule(String) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
setLogLevel(KafkaException.Level) - Method in class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
Set the level at which the exception thrown by this handler is logged.
setLogOnlyMetadata(boolean) - Static method in class org.springframework.kafka.listener.ListenerUtils
Set to true to only log record metadata.
setMapAllStringsOut(boolean) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
Set to true to map all String valued outbound headers to byte[].
setMaxAge(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set the maximum age for a producer; useful when using transactions and the broker might expire a transactional.id due to inactivity.
setMaxContentLogged(int) - Method in class org.springframework.kafka.support.LoggingProducerListener
The maximum amount of data to be logged for either key or password.
setMessageConverter(MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the message converter to use if dynamic argument type matching is needed.
setMessageConverter(RecordMessageConverter) - Method in class org.springframework.kafka.core.KafkaTemplate
Set the message converter to use.
setMessageConverter(RecordMessageConverter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set the MessageConverter.
setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
Set the MessageHandlerMethodFactory to use to configure the message listener responsible to serve an endpoint detected by this processor.
setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Set the MessageHandlerMethodFactory to use to configure the message listener responsible to serve an endpoint detected by this processor.
setMessageHandlerMethodFactory(MessageHandlerMethodFactory) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Set the MessageHandlerMethodFactory to use to build the InvocableHandlerMethod responsible to manage the invocation of this endpoint.
setMessageListener(Object) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the message listener; must be a MessageListener or AcknowledgingMessageListener.
setMethod(Method) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Set the method to invoke to process a message managed by this endpoint.
setMicrometerEnabled(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
Set to false to disable micrometer timers, if micrometer is on the class path.
setMicrometerEnabled(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Set to false to disable the Micrometer listener timers.
setMicrometerTags(Map<String, String>) - Method in class org.springframework.kafka.core.KafkaTemplate
Set additional tags for the Micrometer listener timers.
setMicrometerTags(Map<String, String>) - Method in class org.springframework.kafka.listener.ContainerProperties
Set additional tags for the Micrometer listener timers.
setMissingTopicsFatal(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set to false to allow the container to start even if any of the configured topics are not present on the broker.
setMissingTopicsFatal(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Set to false to allow the container to start even if any of the configured topics are not present on the broker.
setMonitorInterval(int) - Method in class org.springframework.kafka.listener.ContainerProperties
The interval between checks for a non-responsive consumer in seconds; default 30.
setNoPollThreshold(float) - Method in class org.springframework.kafka.listener.ContainerProperties
If the time since the last poll / poll timeout exceeds this value, a NonResponsiveConsumerEvent is published.
setOffset(Long) - Method in class org.springframework.kafka.support.TopicPartitionOffset
Set the offset.
setOnlyLogRecordMetadata(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set to true to only log topic-partition@offset in log messages instead of record.toString().
setOperationTimeout(int) - Method in class org.springframework.kafka.core.KafkaAdmin
Set the operation timeout in seconds.
setOptions(Map<String, String>) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
setPhase(int) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Specify a phase to use.
setPhase(int) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setPhase(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setPhase(int) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
setPhysicalCloseTimeout(int) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
The time to wait when physically closing the producer via the factory rather than closing the producer itself (when DefaultKafkaProducerFactory.reset(), #closeProducerFor(String), or DefaultKafkaProducerFactory.closeThreadBoundProducer() are invoked).
setPollTimeout(long) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the max time to block in the consumer waiting for records.
setProducerListener(ProducerListener<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
Set a ProducerListener which will be invoked when Kafka acknowledges a send operation.
setProducerPerConsumerPartition(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set to false to revert to the previous behavior of a simple incrementing transactional.id suffix for each producer instead of maintaining a producer for each group/topic/partition.
setProducerPerThread(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set to true to create a producer per thread instead of singleton that is shared by all clients.
setRawMappedHeaders(Map<String, Boolean>) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
Set the headers to not perform any conversion on (except String to byte[] for outbound).
setRecordFilterStrategy(RecordFilterStrategy<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the record filter strategy.
setRecordFilterStrategy(RecordFilterStrategy<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set a RecordFilterStrategy implementation.
setRecordInterceptor(RecordInterceptor<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set an interceptor to be called before calling the listener.
setRecordInterceptor(RecordInterceptor<K, V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Set an interceptor to be called before calling the record listener.
setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set a callback to be used with the retryTemplate.
setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
setRelativeToCurrent(boolean) - Method in class org.springframework.kafka.support.TopicPartitionOffset
Set whether the offset is relative to the current position.
setRemoveTypeHeaders(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set to false to retain type information headers after deserialization.
setReplyErrorChecker(Function<ConsumerRecord<?, ?>, Exception>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set a function to examine replies for an error returned by the server.
setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set a configurer which will be invoked when creating a reply message.
setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set a configurer which will be invoked when creating a reply message.
setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set a configurer which will be invoked when creating a reply message.
setReplyPartitionHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set a custom header name for the reply partition.
setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the KafkaTemplate to use to send replies.
setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the KafkaTemplate to use to send replies.
setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set the template to use to send any result from the method invocation.
setReplyTopic(String) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set the topic to which to send any result from the method invocation.
setReplyTopicHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set a custom header name for the reply topic.
setResetStateOnExceptionChange(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Set to true to reset the retry BackOff if the exception is a different type to the previous failure for the same record.
setResetStateOnRecoveryFailure(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Set to false to immediately attempt to recover on the next attempt instead of repeating the BackOff cycle when recovery fails.
setRetainExceptionHeader(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Set to true to retain a Java serialized DeserializationException header.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set a retryTemplate.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set a retryTemplate.
setReturnPartialOnTimeout(boolean) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
Set to true to return a partial result when a request times out.
setRunning(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setScheduler(TaskScheduler) - Method in class org.springframework.kafka.listener.ContainerProperties
A scheduler used with the monitor interval.
setSendFuture(ListenableFuture<SendResult<K, V>>) - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
 
setSharedReplyTopic(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Set to true when multiple templates are using the same topic for replies.
setShutdownTimeout(long) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the timeout for shutting down the container.
setSplitIterables(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set to false to disable splitting Iterable reply values into separate records.
setSplitIterables(boolean) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set to false to disable splitting Iterable reply values into separate records.
setStatefulRetry(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
When using a RetryTemplate Set to true to enable stateful retry.
setStatefulRetry(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
When using a RetryTemplate, set to true to enable stateful retry.
setStateListener(KafkaStreams.StateListener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setStateRestoreListener(StateRestoreListener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setStopContainerWhenFenced(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Set to true to stop the container when a ProducerFencedException is thrown.
setStopImmediate(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
Set to true to stop the container after processing the current record (when stop() is called).
setStreamsConfiguration(Properties) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
Set the streams configuration Properties on this factory.
setSubBatchPerPartition(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
When using a batch message listener whether to dispatch records by partition (with a transaction for each sub batch if transactions are in use) or the complete batch received by the poll().
setSyncCommits(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
setSyncCommitTimeout(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
Set the timeout for commitSync operations (if ConsumerProperties.isSyncCommits().
setSyncCommitTimeout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the timeout for commitSync operations (if ConsumerProperties.isSyncCommits().
setTaskScheduler(TaskScheduler) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
setTopicCheckTimeout(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
How long to wait for Admin.describeTopics(Collection) result futures to complete.
setTopicPartitions(TopicPartitionOffset...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the topicPartitions to use.
setTopicPattern(Pattern) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the topic pattern to use.
setTopics(String...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the topics to use.
setTransactionDefinition(TransactionDefinition) - Method in class org.springframework.kafka.listener.ContainerProperties
Set a transaction definition with properties (e.g.
setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set a prefix for the ProducerConfig.TRANSACTIONAL_ID_CONFIG config.
setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.KafkaTemplate
Set a transaction id prefix to override the prefix in the producer factory.
setTransactionIdPrefix(String) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
Set a transaction id prefix to override the prefix in the producer factory.
setTransactionIdSuffix(String) - Static method in class org.springframework.kafka.support.TransactionSupport
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.kafka.listener.ContainerProperties
Set the transaction manager to start a transaction; offsets are committed with semantics equivalent to ContainerProperties.AckMode.RECORD and ContainerProperties.AckMode.BATCH depending on the listener type (record or batch).
setTypeFunction(BiFunction<byte[], Headers, JavaType>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set a BiFunction that receives the data to be deserialized and the headers and returns a JavaType.
setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
Set a customized type mapper.
setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set a customized type mapper.
setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
Set a customized type mapper.
setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in interface org.springframework.kafka.support.converter.Jackson2JavaTypeMapper
Set the precedence for evaluating type information in message properties.
setTypeResolver(JsonTypeResolver) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set a JsonTypeResolver that receives the data to be deserialized and the headers and returns a JavaType.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
setUntrustedType(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
setupDelegate(Map<String, ?>, String) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
setupListenerContainer(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
setupListenerContainer(MessageListenerContainer, MessageConverter) - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Setup the specified message listener container with the model defined by this endpoint.
setupMessageListener(Object) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setupMessageListener(Object) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Setup the message listener to use.
setUseForKey(boolean) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Configure the TypeMapper to use default key type class.
setUseTypeHeaders(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set to false to ignore type information in headers and use the configured target type instead.
setUseTypeMapperForKey(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Configure the default Jackson2JavaTypeMapper to use key type headers.
setUseTypeMapperForKey(boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
Configure the default Jackson2JavaTypeMapper to use key type headers.
setValidator(Validator) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Set the validator to use if the default message handler factory is used.
setValidator(Validator) - Method in class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
Set a payload validator.
setValueDeserializer(Deserializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
Set the value deserializer.
setValueSerializer(Serializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set a value serializer.
setZkPort(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set the port to run the embedded Zookeeper on (default random).
shouldCopy(String, Object) - Method in interface org.springframework.kafka.listener.adapter.ReplyHeadersConfigurer
Return true if the header should be copied to the reply message.
shutdown() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
 
SIMPLE - org.springframework.kafka.listener.ListenerType
Simple.
SimpleKafkaHeaderMapper - Class in org.springframework.kafka.support
A simple header mapper that maps headers directly; for outbound, only byte[] headers are mapped; for inbound, headers are mapped unchanged, as byte[].
SimpleKafkaHeaderMapper() - Constructor for class org.springframework.kafka.support.SimpleKafkaHeaderMapper
Construct an instance with the default object mapper and default header patterns for outbound headers; all inbound headers are mapped.
SimpleKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.SimpleKafkaHeaderMapper
Construct an instance with a default object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
SimplePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
 
splitIterables() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
When false and the return type is an Iterable return the result as the value of a single reply record instead of individual records for each element.
SPRING_EMBEDDED_KAFKA_BROKERS - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
SPRING_EMBEDDED_ZOOKEEPER_CONNECT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
 
start() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
start() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
start() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
start() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
start() - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
Start the timer.
stop() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
stop() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
stop() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
stop() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
stop(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Stop the container.
stop(Runnable) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
stop(Runnable) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
stop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
stop(Runnable) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
streamsAdded(String, KafkaStreams) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
A new KafkaStreams was created.
streamsAdded(String, KafkaStreams) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
 
StreamsBuilderFactoryBean - Class in org.springframework.kafka.config
An AbstractFactoryBean for the StreamsBuilder instance and lifecycle control for the internal KafkaStreams instance.
StreamsBuilderFactoryBean() - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
Default constructor that creates the factory without configuration Properties.
StreamsBuilderFactoryBean(KafkaStreamsConfiguration) - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
Construct an instance with the supplied streams configuration.
StreamsBuilderFactoryBean(KafkaStreamsConfiguration, CleanupConfig) - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
Construct an instance with the supplied streams configuration and clean up configuration.
StreamsBuilderFactoryBean.Listener - Interface in org.springframework.kafka.config
Called whenever a KafkaStreams is added or removed.
StreamsBuilderFactoryBeanConfigurer - Interface in org.springframework.kafka.config
A configurer for StreamsBuilderFactoryBean.
StreamsBuilderFactoryBeanCustomizer - Interface in org.springframework.kafka.config
Deprecated.
in favor of StreamsBuilderFactoryBeanConfigurer due to a name clash with a similar class in Spring Boot.
streamsRemoved(String, KafkaStreams) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
An existing KafkaStreams was removed.
streamsRemoved(String, KafkaStreams) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
 
StringJsonMessageConverter - Class in org.springframework.kafka.support.converter
JSON Message converter - String on output, String, Bytes, or byte[] on input.
StringJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.StringJsonMessageConverter
 
StringJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.StringJsonMessageConverter
 
StringOrBytesSerializer - Class in org.springframework.kafka.support.serializer
A serializer that can handle byte[], Bytes and String.
StringOrBytesSerializer() - Constructor for class org.springframework.kafka.support.serializer.StringOrBytesSerializer
 
subscription() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
success(Object) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
Record success.
success(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
 
success(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
Called after the listener exits normally.
success(ConsumerRecords<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
Called after the listener exits normally.
success(ConsumerRecords<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
 
SUFFICIENT - org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Sufficient - The LoginModule is not required to succeed.
supportsParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
 

T

targetType - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
TIME - org.springframework.kafka.listener.ContainerProperties.AckMode
Commit pending offsets after ackTime has elapsed.
timestamp() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
timestamp(long) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
timestamp(TimestampType, long) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
TIMESTAMP - org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
Seek to the time stamp.
TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the timestamp of the producer record.
TIMESTAMP_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the type of timestamp.
timestampType() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
toClass(Headers) - Method in interface org.springframework.kafka.support.converter.ClassMapper
 
toClass(Headers) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
ToFromStringSerde<T> - Class in org.springframework.kafka.support.serializer
A Serde that delegates to a ToStringSerializer and ParseStringDeserializer.
ToFromStringSerde(ToStringSerializer<T>, ParseStringDeserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.ToFromStringSerde
Construct an instance with the provided properties.
toHeaders(Headers, Map<String, Object>) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
 
toHeaders(Headers, Map<String, Object>) - Method in interface org.springframework.kafka.support.KafkaHeaderMapper
Map from the given target message to abstracted MessageHeaders.
toHeaders(Headers, Map<String, Object>) - Method in class org.springframework.kafka.support.SimpleKafkaHeaderMapper
 
toJavaType(Headers) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
toJavaType(Headers) - Method in interface org.springframework.kafka.support.converter.Jackson2JavaTypeMapper
 
toMessage(List<ConsumerRecord<?, ?>>, Acknowledgment, Consumer<?, ?>, Type) - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
Convert a list of ConsumerRecord to a Message.
toMessage(List<ConsumerRecord<?, ?>>, Acknowledgment, Consumer<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
 
toMessage(ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
 
toMessage(ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Type) - Method in interface org.springframework.kafka.support.converter.RecordMessageConverter
Convert a ConsumerRecord to a Message.
toMessagingMessage(List, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
 
toMessagingMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
topic() - Method in annotation type org.springframework.kafka.annotation.TopicPartition
The topic to listen on.
topic() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic when sending data to Kafka.
TopicBuilder - Class in org.springframework.kafka.config
Builder for a NewTopic.
TopicPartition - Annotation Type in org.springframework.kafka.annotation
Used to add topic/partition information to a KafkaListener.
TopicPartitionOffset - Class in org.springframework.kafka.support
A configuration container to represent a topic name, partition number and, optionally, an offset for it.
TopicPartitionOffset(String, int) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
Construct an instance with no initial offset management.
TopicPartitionOffset(String, int, Long) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
Construct an instance with the provided initial offset with TopicPartitionOffset.isRelativeToCurrent() false.
TopicPartitionOffset(String, int, Long, boolean) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
Construct an instance with the provided initial offset.
TopicPartitionOffset(String, int, Long, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
Construct an instance with the provided TopicPartitionOffset.SeekPosition.
TopicPartitionOffset(String, int, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
Construct an instance with the provided TopicPartitionOffset.SeekPosition.
TopicPartitionOffset(TopicPartition, Long, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
Construct an instance with the provided TopicPartitionOffset.SeekPosition.
TopicPartitionOffset.SeekPosition - Enum in org.springframework.kafka.support
Enumeration for "special" seeks.
topicPartitions() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
The topicPartitions for this listener when using manual topic/partition assignment.
topicPattern() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
The topic pattern for this listener.
topics() - Method in annotation type org.springframework.kafka.annotation.KafkaListener
The topics for this listener.
topics() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Topics that should be created Topics may contain property place holders, e.g.
toString() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
toString() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
toString() - Method in class org.springframework.kafka.event.ConsumerFailedToStartEvent
 
toString() - Method in class org.springframework.kafka.event.ConsumerPausedEvent
 
toString() - Method in class org.springframework.kafka.event.ConsumerResumedEvent
 
toString() - Method in class org.springframework.kafka.event.ConsumerStartedEvent
 
toString() - Method in class org.springframework.kafka.event.ConsumerStartingEvent
 
toString() - Method in class org.springframework.kafka.event.ConsumerStoppedEvent
 
toString() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
 
toString() - Method in class org.springframework.kafka.event.ContainerStoppedEvent
 
toString() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
 
toString() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
 
toString() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
 
toString() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
 
toString() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
 
toString() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
toString() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
toString() - Method in class org.springframework.kafka.listener.ContainerProperties
 
toString() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
toString() - Method in class org.springframework.kafka.requestreply.CorrelationKey
 
toString() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
toString() - Method in class org.springframework.kafka.support.SendResult
 
toString() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
toString() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
toString() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
ToStringSerializer<T> - Class in org.springframework.kafka.support.serializer
Generic Serializer that relies on Object.toString() to get serialized representation of the entity.
ToStringSerializer() - Constructor for class org.springframework.kafka.support.serializer.ToStringSerializer
 
TRACE - org.springframework.kafka.KafkaException.Level
Trace.
TRACE - org.springframework.kafka.support.LogIfLevelEnabled.Level
Trace.
transactionCapable() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
transactionCapable() - Method in interface org.springframework.kafka.core.ProducerFactory
Return true if the factory supports transactions.
transactionManager() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
 
TransactionSupport - Class in org.springframework.kafka.support
Utilities for supporting transactions.
transform(K, V) - Method in class org.springframework.kafka.streams.HeaderEnricher
 
transform(K, V) - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
 
trusted(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
 
TRUSTED_PACKAGES - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for trusted deserialization packages.
trustedPackages(String...) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Add trusted packages to the default type mapper.
TYPE_ID - org.springframework.kafka.support.converter.Jackson2JavaTypeMapper.TypePrecedence
 
TYPE_MAPPINGS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property to add type mappings to the type mapper: 'foo=com.Foo,bar=com.Bar'.
TYPE_MAPPINGS - Static variable in class org.springframework.kafka.support.serializer.JsonSerializer
Kafka config property to add type mappings to the type mapper: 'foo:com.Foo,bar:com.Bar'.
typeFunction(BiFunction<byte[], Headers, JavaType>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set a BiFunction that receives the data to be deserialized and the headers and returns a JavaType.
typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
 
typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Use the supplied Jackson2JavaTypeMapper.
typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerde
Use the supplied Jackson2JavaTypeMapper.
typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
Use the supplied Jackson2JavaTypeMapper.
typeResolver(JsonTypeResolver) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Set a JsonTypeResolver that receives the data to be deserialized and the headers and returns a JavaType.

U

unrecoverableBackOff(BackOff, ThreadLocal<BackOffExecution>, ThreadLocal<Long>) - Static method in class org.springframework.kafka.listener.ListenerUtils
Sleep according to the BackOff; when the BackOffExecution returns BackOffExecution.STOP sleep for the previous backOff.
unregisterSeekCallback() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
 
unregisterSeekCallback() - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
Called when the listener consumer terminates allowing implementations to clean up state, such as thread locals.
updateConfigs(Map<String, Object>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
updateConfigs(Map<String, Object>) - Method in interface org.springframework.kafka.core.ProducerFactory
Update the producer configuration map; useful for situations such as credential rotation.
USE_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for using type headers (default true).

V

value() - Method in annotation type org.springframework.kafka.annotation.KafkaListeners
 
value() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
 
value(V) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
VALUE_DEFAULT_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for the default value type if no header.
VALUE_DESERIALIZER_CLASS - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Property name for the delegate value deserializer.
VALUE_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Header name for deserialization exceptions.
VALUE_FUNCTION - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
Supplier for a T when deserialization fails.
VALUE_PARSER - Static variable in class org.springframework.kafka.support.serializer.ParseStringDeserializer
Property for the key parser method.
VALUE_SERIALIZATION_SELECTOR - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
Name of the header containing the serialization selector for values.
VALUE_SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
Name of the configuration property containing the serialization selector map for values with format selector:class,....
VALUE_TYPE - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
Header for the type of value.
VALUE_TYPE_METHOD - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
A method name to determine the JavaType to deserialize the value to: 'com.Foo.deserialize'.
valueOf(String) - Static method in enum org.springframework.kafka.event.ConsumerStoppedEvent.Reason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.KafkaException.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.listener.ContainerProperties.AckMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.listener.ContainerProperties.EOSMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.listener.ListenerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.support.converter.Jackson2JavaTypeMapper.TypePrecedence
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.support.LogIfLevelEnabled.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.kafka.event.ConsumerStoppedEvent.Reason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.KafkaException.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.listener.ContainerProperties.AckMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.listener.ContainerProperties.AssignmentCommitOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.listener.ContainerProperties.EOSMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.listener.ListenerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.support.converter.Jackson2JavaTypeMapper.TypePrecedence
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.support.LogIfLevelEnabled.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitForAssignment(Object, int) - Static method in class org.springframework.kafka.test.utils.ContainerTestUtils
Wait until the container has the required number of assigned partitions.
wantsPollResult() - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
 
wantsPollResult() - Method in interface org.springframework.kafka.listener.BatchMessageListener
Return true if this listener wishes to receive the original ConsumerRecords object instead of a list of ConsumerRecord.
WARN - org.springframework.kafka.KafkaException.Level
Warn.
WARN - org.springframework.kafka.support.LogIfLevelEnabled.Level
Warn.

Z

zkConnectionTimeout() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Timeout for internal ZK client connection.
zkConnectionTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set connection timeout for the client to the embedded Zookeeper.
zkPort(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set an explicit port for the embedded Zookeeper.
zkPort(int) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
 
zkSessionTimeout() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Timeout for internal ZK client session.
zkSessionTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
Set session timeout for the client to the embedded Zookeeper.
zookeeperPort() - Method in annotation type org.springframework.kafka.test.context.EmbeddedKafka
Set the port on which the embedded Zookeeper should listen;
A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes All Packages