- ClassMapper - Interface in org.springframework.kafka.support.converter
-
Strategy for setting metadata on messages such that one can create the class
that needs to be instantiated when receiving a message.
- CleanupConfig - Class in org.springframework.kafka.core
-
Specifies time of KafkaStreams.cleanUp()
execution.
- CleanupConfig() - Constructor for class org.springframework.kafka.core.CleanupConfig
-
- CleanupConfig(boolean, boolean) - Constructor for class org.springframework.kafka.core.CleanupConfig
-
- cleanupOnStart() - Method in class org.springframework.kafka.core.CleanupConfig
-
- cleanupOnStop() - Method in class org.springframework.kafka.core.CleanupConfig
-
- clearConsumerGroupId() - Static method in class org.springframework.kafka.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
-
- 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
-
- configureListenerAdapter(MessagingMessageListenerAdapter<K, V>) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
- 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
-
- 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.ProjectingMessageConverter
-
- 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(String, String, String) - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Create a consumer with an explicit group id; in addition, the
client id suffix is appended to the clientIdPrefix which overrides the
client.id
property, if present.
- createConsumer() - 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
-
- createConsumer(String, 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(String, 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
-
- 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
-
- 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
-
- 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 TopicPartition
s 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
-
- 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
-
- getClientId() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Return the client id.
- getClientIdPrefix() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- getClientIdPrefix() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the client id prefix for the container; it will be suffixed by
'-n' to provide a unique id when concurrency is used.
- getCommitCallback() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- getCommitLogLevel() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
The level at which to log offset commits.
- 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
-
- 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
-
- 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
-
- 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
-
- getListenerContainerIds() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
- getListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
- 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
-
- 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 DirectFieldAccessor
s 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
-
- 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
-
- KafkaBootstrapConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
-
- KafkaConditions - Class in org.springframework.kafka.test.assertj
-
AssertJ custom Condition
s.
- 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
-
- KafkaListenerEndpoint - Interface in org.springframework.kafka.config
-
Model for a Kafka listener endpoint.
- KafkaListenerEndpointRegistrar - Class in org.springframework.kafka.config
-
- KafkaListenerEndpointRegistrar() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
- KafkaListenerEndpointRegistry - Class in org.springframework.kafka.config
-
- 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 Matcher
s 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 ListenableFuture
s.
- KafkaOperations.OperationsCallback<K,V,T> - Interface in org.springframework.kafka.core
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- onPartitionsRevokedBeforeCommit(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerAwareRebalanceListener
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
- 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.
- setClientId(String) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set the client id; overrides the consumer factory client.id property.
- setClientIdPrefix(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the client id prefix; overrides the client id in the consumer configuration
properties.
- setClientIdSuffix(String) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Set a suffix to add to the client.id
consumer property (if the consumer
factory supports it).
- setClientSupplier(KafkaClientSupplier) - Method in class org.springframework.kafka.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.
- setCommitLogLevel(LogIfLevelEnabled.Level) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set the level at which to log offset commits.
- setConcurrency(Integer) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
-
Specify the container concurrency.
- setConcurrency(int) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
- setConsumerFactory(ConsumerFactory<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- 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
-
- setContainerFactoryBeanName(String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
- setContainerFactoryBeanName(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
- 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
-
- setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
- setErrorHandler(KafkaListenerErrorHandler) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
- 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
-
- setLogContainerConfig(boolean) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set to true to instruct each container to log this configuration.
- 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
-
- 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
-
- 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
-
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- setReplyTemplate(KafkaTemplate<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- setReplyTemplate(KafkaTemplate<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- 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
-
- 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
-
Construct an instance with the supplied streams configuration.
- StreamsBuilderFactoryBean(StreamsConfig, CleanupConfig) - Constructor for class org.springframework.kafka.core.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration and
clean up configuration.
- StreamsBuilderFactoryBean(Map<String, Object>) - Constructor for class org.springframework.kafka.core.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration.
- StreamsBuilderFactoryBean(Map<String, Object>, CleanupConfig) - Constructor for class org.springframework.kafka.core.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration and
clean up configuration.
- 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
-