Skip navigation links
Spring Kafka
A B C D E F G H I J K L M N O P R S T V W 

A

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
 
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(ContainerProperties) - Constructor for class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
AbstractMessageListenerContainer.AckMode - Enum in org.springframework.kafka.listener
The offset commit behavior enumeration.
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.
acknowledge() - Method in interface org.springframework.kafka.support.Acknowledgment
Invoked when the message for which the acknowledgment has been created has been processed.
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.
ADD_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonSerializer
Kafka config property for to disable adding type headers.
addHeader(Headers, String, Class<?>) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
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
 
after() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
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.test.rule.KafkaEmbedded
 
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
 
apply(Statement, FrameworkMethod, Object) - Method in class org.springframework.kafka.test.rule.Log4jLevelAdjuster
 

B

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.
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
 
BatchMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
 
BEAN_NAME - Static variable in class org.springframework.kafka.test.rule.KafkaEmbedded
 
before() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
bounce(BrokerAddress) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
bounce(int, boolean) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Deprecated.
bounce(int) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Deprecated.
BrokerAddress - Class in org.springframework.kafka.test.core
Encapsulates the address of a Kafka broker.
BrokerAddress(String, int) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
 
BrokerAddress(String) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
 
BrokerAddress(BrokerEndPoint) - Constructor for class org.springframework.kafka.test.core.BrokerAddress
 
brokerProperties(Map<String, String>) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Specify the properties to configure Kafka Broker before start, e.g.

C

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.
clearConsumerGroupId() - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
Clear the group id for the consumer bound to this thread.
close() - Method in class org.springframework.kafka.core.KafkaResourceHolder
 
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
 
closeProducer(Producer<K, V>, boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
 
commit() - Method in class org.springframework.kafka.core.KafkaResourceHolder
 
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<K, V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
Construct an instance with the supplied configuration properties.
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
 
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
 
consumeFromAllEmbeddedTopics(Consumer<?, ?>) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Subscribe a consumer to all the embedded topics.
consumeFromAnEmbeddedTopic(Consumer<?, ?>, String) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Subscribe a consumer to one of the embedded topics.
consumeFromEmbeddedTopics(Consumer<?, ?>, String...) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
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.
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, for example to adjust offsets after an error.
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<K,V> - Interface in org.springframework.kafka.core
The strategy to produce a Consumer instance(s).
consumerProps(String, String, KafkaEmbedded) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Set up test properties for an <Integer, String> consumer.
consumerProps(String, String, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Set up test properties for an <Integer, String> consumer.
ConsumerRecordKeyCondition(K) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyCondition
 
ConsumerRecordKeyMatcher(K) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordKeyMatcher
 
ConsumerRecordPartitionCondition(int) - Constructor for class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordPartitionCondition
 
ConsumerRecordPartitionMatcher(int) - Constructor for class org.springframework.kafka.test.hamcrest.KafkaMatchers.ConsumerRecordPartitionMatcher
 
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
 
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.
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.
ContainerProperties - Class in org.springframework.kafka.listener.config
Contains runtime properties for a listener container.
ContainerProperties(String...) - Constructor for class org.springframework.kafka.listener.config.ContainerProperties
 
ContainerProperties(Pattern) - Constructor for class org.springframework.kafka.listener.config.ContainerProperties
 
ContainerProperties(TopicPartitionInitialOffset...) - Constructor for class org.springframework.kafka.listener.config.ContainerProperties
 
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
 
ContainerStoppingBatchErrorHandler(Executor) - Constructor for class org.springframework.kafka.listener.ContainerStoppingBatchErrorHandler
 
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.
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.
convert(JsonNode, DeserializationContext) - Method in class org.springframework.kafka.support.MimeTypeJsonDeserializer
 
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.StringJsonMessageConverter
 
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() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
createConsumer(String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
createConsumer(String, String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
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
 
createInstance() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
createKafkaConsumer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
createKafkaConsumer(String, String) - 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
 
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.
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
 
createProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
createProducer() - Method in interface org.springframework.kafka.core.ProducerFactory
 
createSimpleLoggingConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Return default implementation of ConsumerRebalanceListener instance.
createTransactionalProducer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 

D

DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
Default header name for type information.
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_KEY_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for the default key type if no header.
DEFAULT_PHASE - Static variable in class org.springframework.kafka.listener.AbstractMessageListenerContainer
The default SmartLifecycle phase for listener containers 2147483547.
DEFAULT_PORT - Static variable in class org.springframework.kafka.test.core.BrokerAddress
 
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_VALUE_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for the default value type if no header.
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 a new Consumer instance for provided Map configs and optional Deserializer keyDeserializer, valueDeserializer implementations on each DefaultKafkaConsumerFactory.createConsumer() invocation.
DefaultKafkaConsumerFactory(Map<String, Object>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
DefaultKafkaConsumerFactory(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
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(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(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.NonTrustedHeaderType - Class in org.springframework.kafka.support
Represents a header that could not be decoded due to an untrusted type.
DefaultKafkaHeaderMapper.SimplePatternBasedHeaderMatcher - Class in org.springframework.kafka.support
A pattern-based header matcher that matches if the specified header matches the specified simple pattern.
defaultKafkaListenerEndpointRegistry() - Method in class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
 
DefaultKafkaProducerFactory<K,V> - Class in org.springframework.kafka.core
The ProducerFactory implementation for the singleton shared Producer instance.
DefaultKafkaProducerFactory(Map<String, Object>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
DefaultKafkaProducerFactory(Map<String, Object>, Serializer<K>, Serializer<V>) - Constructor for class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
defaultKafkaStreamsBuilder(ObjectProvider<StreamsConfig>) - Method in class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
 
delegate - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
delegateType - Variable in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
 
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
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.
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
 
deserialize(String, Headers, byte[]) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
 
deserialize(String, byte[]) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
 
deserializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
 
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.security.jaas.KafkaJaasLoginModuleInitializer
 
destroy() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
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
 
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
 
doResume(Object, Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
doRollback(DefaultTransactionStatus) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
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
 

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.
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.
equals(Object) - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
equals(Object) - Method in class org.springframework.kafka.test.core.BrokerAddress
 
ErrorHandler - Interface in org.springframework.kafka.listener
Handles errors thrown during the execution of a MessageListener.
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<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.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.StringJsonMessageConverter
 

F

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 interface org.springframework.kafka.core.KafkaOperations
Flush the producer.
flush() - Method in class org.springframework.kafka.core.KafkaTemplate
Flush the producer.
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.
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.
getAckCount() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getAckMode() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getAckTime() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getApplicationEventPublisher() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
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.
getBatchMessageConverter() - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
Return the BatchMessagingMessageConverter for this listener, being able to convert Message.
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
 
getBrokerAddress(int) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getBrokerAddresses() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getBrokerAddresses() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 
getBrokersAsString() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getBrokersAsString() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 
getClassIdFieldName() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getClassLoader() - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
getCommitCallback() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getConcurrency() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
getConfig() - 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.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.
getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
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.core.ProducerFactoryUtils
Get the group id for the consumer bound to this thread.
getConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getConsumerTaskExecutor() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
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
 
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
 
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.
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.
getGenericErrorHandler() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
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.config.ContainerProperties
 
getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Determine the InvocableHandlerMethod for the provided type.
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
 
getIdleEventInterval() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
How long the container has been idle.
getKafkaServer(int) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getKafkaServers() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getKafkaServers() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 
getKafkaStreams() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
Get a managed by this StreamsBuilderFactoryBean KafkaStreams instance.
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
 
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.NonResponsiveConsumerEvent
The id of the listener (if @KafkaListener) or the container bean name.
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.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.config.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.
getMonitorInterval() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getNoPollThreshold() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getObjectMapper() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
Return the object mapper.
getObjectType() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
getOrder() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
getPartitionsPerTopic() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getPartitionsPerTopic() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 
getPhase() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
getPhase() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
getPhase() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
getPollTimeout() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
getPort() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
getPosition() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
getProducer() - Method in class org.springframework.kafka.core.KafkaResourceHolder
 
getProducerFactory() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
Get the producer factory.
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
 
getRecordFilterStrategy() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
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.
getRecoveryCallback() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
getRecoveryCallback() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
 
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
 
getResourceFactory() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
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.config.ContainerProperties
 
getShutdownTimeout() - Method in class org.springframework.kafka.listener.config.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.
getSource() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
getTimeSinceLastPoll() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
How long since the last poll.
getTopicPartitions() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return the topicPartitions for this endpoint.
getTopicPartitions() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
Return the topicPartitions for this endpoint.
getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
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.config.ContainerProperties
 
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.config.ContainerProperties
 
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.config.ContainerProperties
 
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.
getTransactionManager() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
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.StringJsonMessageConverter
 
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
 
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
 
getZkClient() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getZkClient() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 
getZookeeper() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getZookeeperConnectionString() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
getZookeeperConnectionString() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 

H

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, ConsumerRecord<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
 
handle(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
 
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
Handle the exception.
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ContainerAwareErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in interface org.springframework.kafka.listener.ContainerAwareErrorHandler
Handle the exception.
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerStoppingBatchErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerStoppingErrorHandler
 
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(Exception, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.LoggingErrorHandler
 
handle(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RemainingRecordsErrorHandler
Handle the exception.
handle(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.SeekToCurrentBatchErrorHandler
 
handle(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer) - Method in class org.springframework.kafka.listener.SeekToCurrentErrorHandler
 
handleError(Message<?>, ListenerExecutionFailedException) - Method in interface org.springframework.kafka.listener.ConsumerAwareListenerErrorHandler
 
handleError(Message<?>, ListenerExecutionFailedException, Consumer<?, ?>) - 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.KafkaListenerErrorHandler
Handle the error.
HandlerAdapter - Class in org.springframework.kafka.listener.adapter
A wrapper for either an InvocableHandlerMethod or DelegatingInvocableHandler.
HandlerAdapter(InvocableHandlerMethod) - Constructor for class org.springframework.kafka.listener.adapter.HandlerAdapter
 
HandlerAdapter(DelegatingInvocableHandler) - 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.
hashCode() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
hashCode() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
hasKey(K) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
 
hasPartition(int) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
 
hasTimestamp(long) - Static method in class org.springframework.kafka.test.hamcrest.KafkaMatchers
Matcher testing the timestamp of a ConsumerRecord asssuming 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
 

I

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) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Further initialize the specified container.
initializeContainer(ConcurrentMessageListenerContainer<K, V>) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
 
initialOffset() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Subclasses can populate additional headers before they are mapped.
initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.StringJsonMessageConverter
 
INSTANCE - Static variable in class org.springframework.kafka.support.KafkaNull
Instance of KafkaNull.
inTransaction() - Method in class org.springframework.kafka.core.KafkaTemplate
 
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.
isAckDiscarded() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
isAckOnError() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 
isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
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.core.StreamsBuilderFactoryBean
 
isAutoStartup() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
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.
isConsumerRecordList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isEmbedded() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
isEmbedded() - Method in interface org.springframework.kafka.test.rule.KafkaRule
 
isExistingTransaction(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
isInterestedInSuccess() - Method in interface org.springframework.kafka.support.ProducerListener
Return true if this listener is interested in success as well as failure.
isInterestedInSuccess() - Method in class org.springframework.kafka.support.ProducerListenerAdapter
 
isJackson2Present() - Static method in class org.springframework.kafka.support.JacksonPresent
 
isMessageList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isNegated() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
 
isRelativeToCurrent() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
isRunning() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
isRunning() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
isRunning() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
isRunning() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isSyncCommits() - Method in class org.springframework.kafka.listener.config.ContainerProperties
 

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.
JacksonPresent - Class in org.springframework.kafka.support
The utility to check if Jackson JSON processor is present in the classpath.
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
 
JsonDeserializer(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
 
JsonDeserializer(Class<T>) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
 
JsonDeserializer(Class<T>, ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonDeserializer
 
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(Class<T>) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerde
 
JsonSerde(Class<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(ObjectMapper) - Constructor for class org.springframework.kafka.support.serializer.JsonSerializer
 

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.
KafkaBootstrapConfiguration - Class in org.springframework.kafka.annotation
@Configuration 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.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
 
KafkaEmbedded - Class in org.springframework.kafka.test.rule
The KafkaRule implementation for the embedded Kafka Broker and Zookeeper.
KafkaEmbedded(int) - Constructor for class org.springframework.kafka.test.rule.KafkaEmbedded
 
KafkaEmbedded(int, boolean, String...) - Constructor for class org.springframework.kafka.test.rule.KafkaEmbedded
Create embedded Kafka brokers.
KafkaEmbedded(int, boolean, int, String...) - Constructor for class org.springframework.kafka.test.rule.KafkaEmbedded
Create embedded Kafka brokers.
KafkaEvent - Class in org.springframework.kafka.event
Base class for events.
KafkaEvent(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
 
KafkaException(String, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
 
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
 
kafkaListenerAnnotationProcessor() - Method in class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
 
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
Factory of MessageListenerContainer based on a KafkaListenerEndpoint definition.
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 {code @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<K, V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.KafkaMessageListenerContainer
Construct an instance with the supplied configuration properties.
KafkaMessageListenerContainer(ConsumerFactory<K, V>, ContainerProperties, TopicPartitionInitialOffset...) - Constructor for class org.springframework.kafka.listener.KafkaMessageListenerContainer
Construct an instance with the supplied configuration properties and specific topics/partitions/initialOffsets.
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.
KafkaProducerException - Exception in org.springframework.kafka.core
Exceptions when producing.
KafkaProducerException(ProducerRecord<?, ?>, String, Throwable) - Constructor for exception org.springframework.kafka.core.KafkaProducerException
 
KafkaResourceHolder<K,V> - Class in org.springframework.kafka.core
Kafka resource holder, wrapping a Kafka producer.
KafkaResourceHolder(Producer<K, V>) - Constructor for class org.springframework.kafka.core.KafkaResourceHolder
Construct an instance for the producer.
KafkaRule - Interface in org.springframework.kafka.test.rule
Common functionality for the Kafka JUnit rules
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
 
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.
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 ConnectionFactory.
key(K) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 

L

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, long, String, Collection<TopicPartition>, Consumer<?, ?>) - Constructor for class org.springframework.kafka.event.ListenerContainerIdleEvent
 
ListenerExecutionFailedException - Exception in org.springframework.kafka.listener
The listener specific KafkaException extension.
ListenerExecutionFailedException(String) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
 
ListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.kafka.listener.ListenerExecutionFailedException
 
ListenerType - Enum in org.springframework.kafka.listener
Defines the listener type.
ListenerUtils - Class in org.springframework.kafka.listener
Listener utilities.
Log4jLevelAdjuster - Class in org.springframework.kafka.test.rule
A JUnit method @Rule that changes the logger level for a set of classes or packages while a test method is running.
Log4jLevelAdjuster(Level, Class<?>...) - Constructor for class org.springframework.kafka.test.rule.Log4jLevelAdjuster
 
Log4jLevelAdjuster(Level, String...) - Constructor for class org.springframework.kafka.test.rule.Log4jLevelAdjuster
 
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.support.converter.BatchMessagingMessageConverter
 
logger - Variable in class org.springframework.kafka.support.converter.MessagingMessageConverter
 
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
 

M

matches(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
 
matches(ConsumerRecord<K, ?>) - Method in class org.springframework.kafka.test.assertj.KafkaConditions.ConsumerRecordKeyCondition
 
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(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
 
matchHandlerMethod(Class<? extends Object>, InvocableHandlerMethod) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
 
matchHeader(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.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.
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.
MessagingMessageListenerAdapter.ResultHolder - Class in org.springframework.kafka.listener.adapter
Result holder.
METADATA_PROPAGATION_TIMEOUT - Static variable in class org.springframework.kafka.test.rule.KafkaEmbedded
 
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 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.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.
MimeTypeJsonDeserializer - Class in org.springframework.kafka.support
MimeType deserializer.
MimeTypeJsonDeserializer(ObjectMapper) - Constructor for class org.springframework.kafka.support.MimeTypeJsonDeserializer
 
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
 

N

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.
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
 

O

objectMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
objectMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
 
OFFSET - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for the partition offset.
onApplicationEvent(ContextRefreshedEvent) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
onError(String, Integer, K, V, Exception) - Method in class org.springframework.kafka.support.LoggingProducerListener
 
onError(String, Integer, K, V, Exception) - Method in interface org.springframework.kafka.support.ProducerListener
Invoked after an attempt to send a message has failed.
onError(String, Integer, K, V, Exception) - Method in class org.springframework.kafka.support.ProducerListenerAdapter
 
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(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.AcknowledgingConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.AcknowledgingMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in interface org.springframework.kafka.listener.AcknowledgingMessageListener
Invoked with data from kafka.
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>>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringBatchMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.FilteringMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, 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
Kafka MessageListener entry point.
onMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Acknowledgment) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
 
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingConsumerAwareMessageListener
 
onMessage(List<ConsumerRecord<K, V>>) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingMessageListener
Invoked with data from kafka.
onMessage(List<ConsumerRecord<K, V>>, Acknowledgment) - Method in interface org.springframework.kafka.listener.BatchAcknowledgingMessageListener
 
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 interface org.springframework.kafka.listener.BatchConsumerAwareMessageListener
 
onMessage(ConsumerRecord<K, V>) - Method in interface org.springframework.kafka.listener.ConsumerAwareMessageListener
Invoked with data from kafka.
onMessage(ConsumerRecord<K, V>, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ConsumerAwareMessageListener
 
onMessage(T) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka.
onMessage(T, Acknowledgment) - 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 for operations such as pause/resume.
onMessage(T, Acknowledgment, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.GenericMessageListener
Invoked with data from kafka and provides access to the Consumer for operations such as pause/resume.
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(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
The same as ConsumerAwareRebalanceListener.onPartitionsAssigned(Collection) with the additional consumer parameter.
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
onPartitionsAssigned(Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
When using group management, called when partition assignments change.
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
 
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(String, Integer, 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).
onSuccess(String, Integer, K, V, RecordMetadata) - Method in class org.springframework.kafka.support.ProducerListenerAdapter
 
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.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.listener.config - package org.springframework.kafka.listener.config
Container configuration.
org.springframework.kafka.security.jaas - package org.springframework.kafka.security.jaas
Provides classes related to jaas.
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.serializer - package org.springframework.kafka.support.serializer
 
org.springframework.kafka.test.assertj - package org.springframework.kafka.test.assertj
 
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

partition() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
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.
partitionsFor(String) - Method in interface org.springframework.kafka.core.KafkaOperations
See Producer.partitionsFor(String).
partitionsFor(String) - Method in class org.springframework.kafka.core.KafkaTemplate
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
 
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
 
ProducerFactory<K,V> - Interface in org.springframework.kafka.core
The strategy to produce a Producer instance(s).
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.
ProducerListenerAdapter<K,V> - Class in org.springframework.kafka.support
No-op implementation of ProducerListener, to be used as base class for other implementations.
ProducerListenerAdapter() - Constructor for class org.springframework.kafka.support.ProducerListenerAdapter
 
producerProps(KafkaEmbedded) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Set up test properties for an <Integer, String> producer.

R

RAW_DATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the raw data received from Kafka (ConsumerRecord or ConsumerRecords).
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.
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.
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
 
registerAllEndpoints() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
 
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.
registerEndpoint(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Register a new KafkaListenerEndpoint using the default KafkaListenerContainerFactory 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.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.
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.
ReplyExpressionRoot(Object, Object, Object) - Constructor for class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
restart(int) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
ResultHolder(Object, Expression) - Constructor for class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ResultHolder
 
retrieveHeader(Headers, String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
retrieveHeaderAsString(Headers, String) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
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.
rollback() - Method in class org.springframework.kafka.core.KafkaResourceHolder
 

S

seek(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Queue a seek operation to the consumer.
seekToBeginning(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Queue a seekToBeginning operation to the consumer.
SeekToCurrentBatchErrorHandler - Class in org.springframework.kafka.listener
An error handler that seeks to the current offset for each topic in 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
 
seekToEnd(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
Queue a seekToEnd operation to the consumer.
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, 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, 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, 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(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations
Send the provided ProducerRecord.
send(Message<?>) - Method in interface org.springframework.kafka.core.KafkaOperations
Send a message with routing information in message headers.
send(String, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(String, Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
 
send(Message<?>) - 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(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(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, 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(V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendDefault(K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendDefault(Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
sendDefault(Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
 
senderProps(String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
Set up test properties for an <Integer, String> producer.
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.springframework.kafka.core.KafkaOperations
When running in a transaction (usually synchronized with some other transaction), send the consumer offset(s) to the transaction.
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.springframework.kafka.core.KafkaOperations
When running in a transaction (usually synchronized with some other 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.KafkaTemplate
 
sendResponse(Object, String) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
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
 
serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
serialize(String, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
serializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
 
setAckCount(int) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the number of outstanding record count after which offsets should be committed when AbstractMessageListenerContainer.AckMode.COUNT or AbstractMessageListenerContainer.AckMode.COUNT_TIME is being used.
setAckDiscarded(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set to true to ack discards when a filter strategy is in use.
setAckDiscarded(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set to true if the recordFilterStrategy is in use.
setAckMode(AbstractMessageListenerContainer.AckMode) - Method in class org.springframework.kafka.listener.config.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.config.ContainerProperties
Set whether or not the container should commit offsets (ack messages) where the listener throws exceptions.
setAckTime(long) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the time (ms) after which outstanding offsets should be committed when AbstractMessageListenerContainer.AckMode.TIME or AbstractMessageListenerContainer.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.
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaAdmin
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
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.AbstractKafkaListenerContainerFactory
Specify an autoStartup boolean flag.
setAutoStartup(boolean) - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the batch error handler to call when the listener throws an exception.
setBatchListener(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set to true if this endpoint should create a batch listener.
setBatchListener(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
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.
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.listener.AbstractMessageListenerContainer
 
setBeanResolver(BeanResolver) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Set a bean resolver for runtime SpEL expressions.
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.core.StreamsBuilderFactoryBean
 
setCloseTimeout(int) - Method in class org.springframework.kafka.core.KafkaAdmin
Set the close timeout in seconds.
setCloseTimeout(int) - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
Specify the timeout in seconds for the KafkaStreams.close(long, TimeUnit) operation.
setCommitCallback(OffsetCommitCallback) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
setConcurrency(Integer) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
Specify the container concurrency.
setConcurrency(int) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
The maximum number of concurrent KafkaMessageListenerContainers running.
setConsumerFactory(ConsumerFactory<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Specify a ConsumerFactory to use.
setConsumerGroupId(String) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
Set the group id for the consumer bound to this thread.
setConsumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the user defined ConsumerRebalanceListener implementation.
setConsumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the executor for threads that poll the consumer.
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.annotation.KafkaListenerAnnotationBeanPostProcessor
Set the name of the KafkaListenerContainerFactory to use by default.
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.
setControlFlag(KafkaJaasLoginModuleInitializer.ControlFlag) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
setDefaultTopic(String) - Method in class org.springframework.kafka.core.KafkaTemplate
Set the default topic for send methods where a topic is not provided.
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.
setErrorHandler(KafkaListenerErrorHandler) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
Set the KafkaListenerErrorHandler to invoke if the listener method throws an exception.
setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the error handler to call when the listener throws an exception.
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.
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.
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 connectionFactory.
setGroupId(String) - Method in class org.springframework.kafka.listener.config.ContainerProperties
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.
setId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.kafka.support.converter.AbstractJavaTypeMapper
 
setIdleEventInterval(Long) - Method in class org.springframework.kafka.listener.config.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).
setKafkaPorts(int...) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Set explicit ports on which the kafka brokers will listen.
setKeyDeserializer(Deserializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
setKeySerializer(Serializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
setLoginModule(String) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
 
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.config.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.
setMonitorInterval(int) - Method in class org.springframework.kafka.listener.config.ContainerProperties
The interval between checks for a non-responsive consumer in seconds; default .
setNoPollThreshold(float) - Method in class org.springframework.kafka.listener.config.ContainerProperties
If the time since the last poll / poll timeout exceeds this value, a NonResponsiveConsumerEvent is published.
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.core.StreamsBuilderFactoryBean
 
setPhase(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setPhysicalCloseTimeout(int) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
The time to wait when physically closing the producer (when DefaultKafkaProducerFactory.stop() or DefaultKafkaProducerFactory.destroy() is invoked).
setPollTimeout(long) - Method in class org.springframework.kafka.listener.config.ContainerProperties
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.
setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the record filter strategy.
setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set a RecordFilterStrategy implementation.
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
Set a callback to be used with the retryTemplate.
setReplyTemplate(KafkaTemplate<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Set the KafkaTemplate to use to send replies.
setReplyTemplate(KafkaTemplate<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Set the KafkaTemplate to use to send replies.
setReplyTemplate(KafkaTemplate<K, V>) - 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.
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.
setRunning(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
setScheduler(TaskScheduler) - Method in class org.springframework.kafka.listener.config.ContainerProperties
A scheduler used with the monitor interval.
setShutdownTimeout(long) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the timeout for shutting down the container.
setStateListener(KafkaStreams.StateListener) - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
setSyncCommits(boolean) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
setTopicPartitions(TopicPartitionInitialOffset...) - 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.
setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Set the transactional.id prefix.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.kafka.listener.config.ContainerProperties
Set the transaction manager to start a transaction; only AbstractMessageListenerContainer.AckMode.RECORD and AbstractMessageListenerContainer.AckMode.BATCH (default) are supported with transactions.
setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.converter.StringJsonMessageConverter
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
Set the precedence for evaluating type information in message properties.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
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.
setValueDeserializer(Deserializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
setValueSerializer(Serializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
SimplePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.kafka.support.DefaultKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
 
SPRING_EMBEDDED_KAFKA_BROKERS - Static variable in class org.springframework.kafka.test.rule.KafkaEmbedded
 
SPRING_EMBEDDED_ZOOKEEPER_CONNECT - Static variable in class org.springframework.kafka.test.rule.KafkaEmbedded
 
start() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
start() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
start() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
start() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
startZookeeper() - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
 
stop() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
stop(Runnable) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
stop() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
stop(Runnable) - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
stop() - Method in class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
stop() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
stop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
StreamsBuilderFactoryBean - Class in org.springframework.kafka.core
An AbstractFactoryBean for the StreamsBuilder instance and lifecycle control for the internal KafkaStreams instance.
StreamsBuilderFactoryBean(StreamsConfig) - Constructor for class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
StreamsBuilderFactoryBean(Map<String, Object>) - Constructor for class org.springframework.kafka.core.StreamsBuilderFactoryBean
 
StringJsonMessageConverter - Class in org.springframework.kafka.support.converter
JSON Message converter - String on output, String 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
 

T

targetType - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the timestamp of the producer record.
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_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the type of timestamp.
toClass(Headers) - Method in interface org.springframework.kafka.support.converter.ClassMapper
 
toClass(Headers) - Method in class org.springframework.kafka.support.converter.DefaultJackson2JavaTypeMapper
 
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.
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 - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic when sending data to Kafka.
topic() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
TopicPartition - Annotation Type in org.springframework.kafka.annotation
Used to add topic/partition information to a KafkaListener.
topicPartition() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
TopicPartitionInitialOffset - Class in org.springframework.kafka.support
A configuration container to represent a topic name, partition number and, optionally, an initial offset for it.
TopicPartitionInitialOffset(String, int) - Constructor for class org.springframework.kafka.support.TopicPartitionInitialOffset
Construct an instance with no initial offset management.
TopicPartitionInitialOffset(String, int, Long) - Constructor for class org.springframework.kafka.support.TopicPartitionInitialOffset
Construct an instance with the provided initial offset with TopicPartitionInitialOffset.isRelativeToCurrent() false.
TopicPartitionInitialOffset(String, int, Long, boolean) - Constructor for class org.springframework.kafka.support.TopicPartitionInitialOffset
Construct an instance with the provided initial offset.
TopicPartitionInitialOffset(String, int, TopicPartitionInitialOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionInitialOffset
Construct an instance with the provided TopicPartitionInitialOffset.SeekPosition.
TopicPartitionInitialOffset.SeekPosition - Enum in org.springframework.kafka.support
Enumeration for "special" seeks.
toString() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
toString() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
 
toString() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
 
toString() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ResultHolder
 
toString() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
toString() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
toString() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
 
toString() - Method in class org.springframework.kafka.support.TopicPartitionInitialOffset
 
toString() - Method in class org.springframework.kafka.test.core.BrokerAddress
 
transactionCapable() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
transactionCapable() - Method in interface org.springframework.kafka.core.ProducerFactory
 
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.
typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
 
typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
 

V

value(V) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
 
valueOf(String) - Static method in enum org.springframework.kafka.listener.AbstractMessageListenerContainer.AckMode
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.TopicPartitionInitialOffset.SeekPosition
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.kafka.listener.AbstractMessageListenerContainer.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.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.TopicPartitionInitialOffset.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.
waitUntilSynced(String, int) - Method in class org.springframework.kafka.test.rule.KafkaEmbedded
Deprecated.
A B C D E F G H I J K L M N O P R S T V W 
Skip navigation links
Spring Kafka