- 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.
- 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
-
- 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
-
- getCommitCallback() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- getConcurrency() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
- getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConsumerFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- 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
-
- getDefaultTopic() - Method in class org.springframework.kafka.core.KafkaTemplate
-
The default topic for send methods where a topic is not
providing.
- getEndpointDescription() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return a description for this endpoint.
- getEndpointDescription() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
- getEndpointDescription() - Method in class org.springframework.kafka.config.SimpleKafkaListenerEndpoint
-
- getEndpointRegistry() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
- getErrorHandler() - 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.
- getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Determine the InvocableHandlerMethod
for the provided type.
- 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.
- 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
-
- 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 @RabbitListener
) or the container bean name.
- getListenerTaskExecutor() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- 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.config.SimpleKafkaListenerEndpoint
-
Return the
MessageListener
to invoke when a message matching
the endpoint is received.
- 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.
- 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
-
- getPauseAfter() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- getPhase() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
- 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
-
- 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
-
- getQueueDepth() - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- 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.
- getRecoveryCallback() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- getRecoveryCallback() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
-
- getResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- getRetryTemplate() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- getRetryTemplate() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
-
- 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.
- 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.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
-
- 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_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.
- 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.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
.
- KafkaHeaders - Class in org.springframework.kafka.support
-
The Kafka specific message headers constants.
- KafkaHeaders() - Constructor for class org.springframework.kafka.support.KafkaHeaders
-
- 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
-
- 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.ConsumerRecordValueMatcher<V> - Class in org.springframework.kafka.test.hamcrest
-
- 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.
- KafkaProducerException - Exception in org.springframework.kafka.core
-
Exceptions when producing.
- KafkaProducerException(ProducerRecord<?, ?>, String, Throwable) - Constructor for exception org.springframework.kafka.core.KafkaProducerException
-
- KafkaRule - Interface in org.springframework.kafka.test.rule
-
Common functionality for the Kafka JUnit rules
- 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.
- key(K) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
-
- 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, int, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the provided topic with the provided partition and no key.
- send(String, int, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the provided topic with the provided key and partition.
- 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, int, V) - Method in class org.springframework.kafka.core.KafkaTemplate
-
- send(String, int, 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(int, 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(int, 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.
- 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, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
- 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 the container should ack messages that throw exceptions or not.
- setAckTime(long) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
- setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify an autoStartup boolean
flag.
- setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
- setBean(Object) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the object instance that should manage this endpoint.
- 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
-
- 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).
- 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
-
- setConsumerFactory(ConsumerFactory<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- 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
-
- setDefaultTopic(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the default topic for send methods where a topic is not
providing.
- setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
- setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
- setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set the error handler to call when the listener throws an exception.
- 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.MessagingMessageConverter
-
Generate timestamp
for produced messages.
- setGroup(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the group for the corresponding listener 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
.
- setId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- 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).
- setKeyDeserializer(Deserializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
- setKeySerializer(Serializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
- setListenerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set the executor for threads that invoke the listener.
- 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(MessageConverter) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the message converter to use.
- setMessageConverter(MessageConverter) - 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(MessageListener<K, V>) - Method in class org.springframework.kafka.config.SimpleKafkaListenerEndpoint
-
Set the
MessageListener
to invoke when a message matching
the endpoint is received.
- 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.
- setPauseAfter(long) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
- setPauseEnabled(boolean) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set to true to avoid rebalancing when this consumer is slow or throws a
qualifying exception - pause the consumer.
- setPhase(int) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify a phase
to use.
- setPhase(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
- 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.
- setQueueDepth(int) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set the queue depth for handoffs from the consumer thread to the listener
thread.
- 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<Void>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
- setRecoveryCallback(RecoveryCallback<Void>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
- 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
-
- setShutdownTimeout(long) - Method in class org.springframework.kafka.listener.config.ContainerProperties
-
Set the timeout for shutting down the container.
- 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.
- 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
-
- SimpleKafkaListenerEndpoint<K,V> - Class in org.springframework.kafka.config
-
- SimpleKafkaListenerEndpoint() - Constructor for class org.springframework.kafka.config.SimpleKafkaListenerEndpoint
-
- SPRING_EMBEDDED_KAFKA_BROKERS - 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.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() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
- stop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
- 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
-