Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
S
- sameIntervalTopicReuseStrategy() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
-
Topic reuse strategy for sequential attempts made with a same backoff interval.
- sameIntervalTopicReuseStrategy(SameIntervalTopicReuseStrategy) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure the
SameIntervalTopicReuseStrategy
. - SameIntervalTopicReuseStrategy - Enum Class in org.springframework.kafka.retrytopic
-
Strategy for topic reuse when multiple, sequential retries have the same backoff interval.
- secondary() - Method in class org.springframework.kafka.core.ABSwitchCluster
-
Use the secondary cluster.
- seek(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek operation.
- seek(TopicPartition, long) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- seekOrRecover(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer, boolean, BiPredicate<ConsumerRecord<?, ?>, Exception>, LogAccessor, KafkaException.Level) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Seek the remaining records, optionally recovering the first.
- seekOrRecover(Exception, List<ConsumerRecord<?, ?>>, Consumer<?, ?>, MessageListenerContainer, boolean, RecoveryStrategy, LogAccessor, KafkaException.Level) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Seek the remaining records, optionally recovering the first.
- seekPartitions(Consumer<?, ?>, Map<TopicPartition, Long>, LogAccessor) - Static method in class org.springframework.kafka.listener.SeekUtils
-
Perform seek operations on each partition.
- seekRelative(String, int, long, boolean) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek relative to the start, end, or current position.
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- seeksAfterHandling() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Return true if this error handler performs seeks on the failed record and remaining records (or just the remaining records after a failed record is recovered).
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- seeksAfterHandling() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- seekToBeginning() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Seek all assigned partitions to the beginning.
- seekToBeginning(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to beginning operation.
- seekToBeginning(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to beginning operation.
- seekToBeginning(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- seekToEnd() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Seek all assigned partitions to the end.
- seekToEnd(String, int) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to end operation.
- seekToEnd(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to end operation.
- seekToEnd(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- seekToTimestamp(long) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Seek all assigned partitions to the offset represented by the timestamp.
- seekToTimestamp(String, int, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to the first offset greater than or equal to the time stamp.
- seekToTimestamp(Collection<TopicPartition>, long) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware.ConsumerSeekCallback
-
Perform a seek to the first offset greater than or equal to the time stamp.
- SeekUtils - Class in org.springframework.kafka.listener
-
Seek utilities.
- selectImports(AnnotationMetadata) - Method in class org.springframework.kafka.annotation.KafkaListenerConfigurationSelector
- selfLog(String, LogAccessor) - Method in exception org.springframework.kafka.KafkaException
-
Log this exception at its log level.
- send(String, int, long, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, int, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the provided topic with the provided key and partition.
- send(String, Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the provided topic with the provided key and partition.
- send(String, Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the provided topic with the provided key and partition.
- send(String, Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the provided topic with the provided key and partition.
- send(String, Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the provided topic with the provided key and no partition.
- send(String, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the provided topic with the provided key and no partition.
- send(String, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, K, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, Message<?>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(String, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the provided topic with no key or partition.
- send(String, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the provided topic with no key or partition.
- send(String, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(String, V) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(ProducerRecord<Object, Object>, KafkaOperations<Object, Object>, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Send the record.
- send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- send(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the provided
ProducerRecord
. - send(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the provided
ProducerRecord
. - send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(ProducerRecord<K, V>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(ProducerRecord<K, V>, Callback) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- send(Publisher<? extends SenderRecord<K, V, T>>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- send(Message<?>) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send a message with routing information in message headers.
- send(Message<?>) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send a message with routing information in message headers.
- send(Message<?>) - Method in class org.springframework.kafka.core.KafkaTemplate
- send(SenderRecord<K, V, T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- sendAndReceive(ProducerRecord<K, V>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request and receive a reply with the default timeout.
- sendAndReceive(ProducerRecord<K, V>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(ProducerRecord<K, V>, Duration) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request and receive a reply.
- sendAndReceive(ProducerRecord<K, V>, Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message with the default timeout.
- sendAndReceive(Message<?>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>, Duration) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message.
- sendAndReceive(Message<?>, Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>, Duration, ParameterizedTypeReference<P>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message.
- sendAndReceive(Message<?>, Duration, ParameterizedTypeReference<P>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendAndReceive(Message<?>, ParameterizedTypeReference<P>) - Method in interface org.springframework.kafka.requestreply.ReplyingKafkaOperations
-
Send a request message and receive a reply message.
- sendAndReceive(Message<?>, ParameterizedTypeReference<P>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- sendDefault(Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the default topic with the provided key and partition.
- sendDefault(Integer, Long, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the default topic with the provided key and partition.
- sendDefault(Integer, Long, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendDefault(Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the default topic with the provided key and partition.
- sendDefault(Integer, K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the default topic with the provided key and partition.
- sendDefault(Integer, K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendDefault(K, V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the default topic with the provided key and no partition.
- sendDefault(K, V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the default topic with the provided key and no partition.
- sendDefault(K, V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendDefault(V) - Method in interface org.springframework.kafka.core.KafkaOperations
-
Send the data to the default topic with no key or partition.
- sendDefault(V) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.Send the data to the default topic with no key or partition.
- sendDefault(V) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.springframework.kafka.core.KafkaOperations
-
When running in a transaction, send the consumer offset(s) to the transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.springframework.kafka.core.KafkaOperations2
-
Deprecated.When running in a transaction, send the consumer offset(s) to the transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.KafkaTemplate
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- sendResponse(Object, String, Object, boolean) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Send the result to the topic.
- SendResult<K,
V> - Class in org.springframework.kafka.support -
Result for a
CompletableFuture
after a send. - SendResult(ProducerRecord<K, V>, RecordMetadata) - Constructor for class org.springframework.kafka.support.SendResult
- sendTransactionally(Publisher<? extends SenderRecord<K, V, T>>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- sendTransactionally(SenderRecord<K, V, T>) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- SerializationUtils - Class in org.springframework.kafka.support.serializer
-
Utilities for serialization.
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- serialize(String, Object) - Method in class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
- serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
- serialize(String, Headers, Object) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- serialize(String, Headers, T) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- serialize(String, T) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- serialize(String, T) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
- serializedKeySize() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- serializedValueSize() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- serializer() - Method in class org.springframework.kafka.support.serializer.JsonSerde
- serializer() - Method in class org.springframework.kafka.support.serializer.ToFromStringSerde
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
- setAckAfterHandle(boolean) - Method in interface org.springframework.kafka.listener.CommonErrorHandler
-
Set to false to prevent the container from committing the offset of a recovered record (when the error handler does not itself throw an exception).
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
- setAckAfterHandle(boolean) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
- setAckAfterHandle(boolean) - Method in interface org.springframework.kafka.listener.GenericErrorHandler
-
Deprecated.Set to false to prevent the container from committing the offset of a recovered record (when the error handler does not itself throw an exception).
- setAckCount(int) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the number of outstanding record count after which offsets should be committed when
ContainerProperties.AckMode.COUNT
orContainerProperties.AckMode.COUNT_TIME
is being used. - setAckDiscarded(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set to true if the
AbstractKafkaListenerEndpoint.setRecordFilterStrategy(RecordFilterStrategy)
is in use. - setAckDiscarded(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to true to ack discards when a filter strategy is in use.
- setAckMode(ContainerProperties.AckMode) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the ack mode to use when auto ack (in the configuration properties) is false.
- setAckTime(long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the time (ms) after which outstanding offsets should be committed when
ContainerProperties.AckMode.TIME
orContainerProperties.AckMode.COUNT_TIME
is being used. - setAddTypeInfo(boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Set to false to disable adding type info headers.
- setAddTypeInfo(boolean) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Set to false to disable adding type info headers.
- setAdminTimeout(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the timeout in seconds for admin operations (e.g.
- setAdviceChain(Advice...) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a chain of listener
Advice
s; must not be null or have null elements. - setAfterRollbackProcessor(AfterRollbackProcessor<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a processor to invoke after a transaction rollback; typically will seek the unprocessed topic/partition to reprocess the records.
- setAfterRollbackProcessor(AfterRollbackProcessor<? super K, ? super V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set a processor to perform seeks on unprocessed records after a rollback.
- setAllowNonTransactional(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set to true to allow a non-transactional send when the template is transactional.
- setAlwaysClientIdSuffix(boolean) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
Set to false to suppress adding a suffix to the child container's client.id when the concurrency is only 1.
- setAlwaysStartAfterRefresh(boolean) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
By default, containers registered for endpoints after the context is refreshed are immediately started, regardless of their autoStartup property, to comply with the
SmartLifecycle
contract, where autoStartup is only considered during context initialization. - setAppendOriginalHeaders(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false if you don't want to append the current "original" headers (topic, partition etc.) if they are already present.
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaAdmin
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.core.KafkaTemplate
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- setApplicationContext(ApplicationContext) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setAssignmentCommitOption(ContainerProperties.AssignmentCommitOption) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the assignment commit option.
- setAsyncAcks(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to support asynchronous record acknowledgments.
- setAuthExceptionRetryInterval(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the interval between retries after and
AuthenticationException
ororg.apache.kafka.common.errors.AuthorizationException
is thrown byKafkaConsumer
. - setAutoCreate(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set to false to suppress auto creation of topics during context initialization.
- setAutoStartup(boolean) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setAutoStartup(boolean) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set to false to not automatically start.
- setAutoStartup(boolean) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Set the autoStartup.
- setAutoStartup(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify an
autoStartup boolean
flag. - setAutoStartup(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the autoStartup for this endpoint's container.
- setBackOffFunction(BiFunction<ConsumerRecord<?, ?>, Exception, BackOff>) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set a function to dynamically determine the
BackOff
to use, based on the consumer record and/or exception. - setBackOffHandler(BackOffHandler) - Method in class org.springframework.kafka.listener.ContainerPartitionPausingBackOffManagerFactory
-
Set the back off handler to use in the created handlers.
- setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setBatchErrorHandler(BatchErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setBatchInterceptor(BatchInterceptor<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a batch interceptor to be called before and after calling the listener.
- setBatchInterceptor(BatchInterceptor<K, V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set an interceptor to be called before calling the record listener.
- setBatchListener(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set to true if this endpoint should create a batch listener.
- setBatchListener(Boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to true if this endpoint should create a batch listener.
- setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the message converter to use if dynamic argument type matching is needed for batch listeners.
- setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Set the BatchMessageConverter.
- setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a
BatchToRecordAdapter
. - setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a
BatchToRecordAdapter
. - setBatchToRecordAdapter(BatchToRecordAdapter<K, V>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Set a
BatchToRecordAdapter
. - 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.mapping.AbstractJavaTypeMapper
- setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Making a
BeanFactory
available is optional; if not set,KafkaListenerConfigurer
beans won't get autodetected and anendpoint registry
has to be explicitly configured. - setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
A
BeanFactory
only needs to be available in conjunction withKafkaListenerEndpointRegistrar.setContainerFactoryBeanName(java.lang.String)
. - setBeanFactory(BeanFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- setBeanName(String) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setBeanName(String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- setBeanName(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- setBeanName(String) - Method in class org.springframework.kafka.core.KafkaTemplate
- setBeanName(String) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setBeanResolver(BeanResolver) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a bean resolver for runtime SpEL expressions.
- setBinaryCorrelation(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set to false to use the String representation of the correlation as the correlationId rather than the binary representation.
- setBlockingRetriesBackOff(BackOff) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Set a
BackOff
to be used with blocking retries. - setBlockingRetryableExceptions(Class<? extends Exception>...) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Specify the exceptions to be retried via blocking.
- setBootstrapServersSupplier(Supplier<String>) - Method in class org.springframework.kafka.core.KafkaResourceFactory
-
Set a supplier for the bootstrap server list to override any configured in a subclass.
- setCaseSensitive(boolean) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
-
Set to false to make topic name matching case insensitive.
- setCauseChainTraversing(boolean) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
-
Set the flag enabling deep exception's cause chain traversing.
- setChangeConsumerThreadName(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to true to instruct the container to change the consumer thread name during initialization.
- setChangeConsumerThreadName(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set to true to instruct the container to change the consumer thread name during initialization.
- setCharset(Charset) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set a charset to use when converting byte[] to String in method arguments and other String/byte[] conversions.
- setCharset(Charset) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Set the charset to use when mapping String-valued headers to/from byte[].
- setCharset(Charset) - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Set a charset to use when converting byte[] to
String
. - setCharset(Charset) - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Set a charset to use when converting
String
to byte[]. - setCheckDeserExWhenKeyNull(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set to true to always check for
DeserializationException
header when a null key is received. - setCheckDeserExWhenValueNull(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set to true to always check for
DeserializationException
header when a null value is received. - setClassIdFieldName(String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure header name for type information.
- setClassifications(Map<Class<? extends Throwable>, Boolean>, boolean) - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Set an exception classifications to determine whether the exception should cause a retry (until exhaustion) or not.
- setClassifications(Map<Class<? extends Throwable>, Boolean>, boolean) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- setCleanupConfig(CleanupConfig) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setClientId(String) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the client id; overrides the consumer factory client.id property.
- setClientIdPrefix(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the client id prefix; overrides the client id in the consumer configuration properties.
- setClientIdSuffix(String) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Set a suffix to add to the
client.id
consumer property (if the consumer factory supports it). - setClientSupplier(KafkaClientSupplier) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setCloseTimeout(int) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Specify the timeout in seconds for the
KafkaStreams.close(Duration)
operation. - setCloseTimeout(int) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set the close timeout in seconds.
- setCloseTimeout(Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the maximum time to wait when closing a producer; default 5 seconds.
- setCloseTimeout(Duration) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
-
Set the maximum time to wait when closing a producer; default 5 seconds.
- setCommitCallback(OffsetCommitCallback) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
- setCommitLogLevel(LogIfLevelEnabled.Level) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the level at which to log offset commits.
- setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.DefaultErrorHandler
-
Set to true to commit the offset for a recovered record.
- setCommitRecovered(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set to true to commit the offset for a recovered record.
- setCommitRetries(int) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set number of retries allowed when a
RetriableCommitFailedException
is thrown by the consumer when usingConsumerProperties.setSyncCommits(boolean)
set to true. - setCommitTimeout(Duration) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Set the timeout to use when committing offsets.
- setCommonErrorHandler(CommonErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the
CommonErrorHandler
which can handle errors for both record and batch listeners. - setCommonErrorHandler(CommonErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set the
CommonErrorHandler
which can handle errors for both record and batch listeners. - setConcurrency(int) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
The maximum number of concurrent
KafkaMessageListenerContainer
s running. - setConcurrency(Integer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the concurrency for this endpoint's container.
- setConcurrency(Integer) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
-
Specify the container concurrency.
- setConfigureDeserializers(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set to false (default true) to prevent programmatically provided deserializers (via constructor or setters) from being configured using the producer configuration, e.g.
- setConfigureSerializers(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set to false (default true) to prevent programmatically provided serializers (via constructor or setters) from being configured using the producer configuration, e.g.
- setConsumerFactory(ConsumerFactory<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify a
ConsumerFactory
to use. - setConsumerFactory(ConsumerFactory<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a consumer factory for receive operations.
- setConsumerGroupId(String) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set the group id for the consumer bound to this thread.
- setConsumerProperties(Properties) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- setConsumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the user defined
ConsumerRebalanceListener
implementation. - setConsumerRecordFormatter(Function<ConsumerRecord<?, ?>, String>) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set a formatter for logging
ConsumerRecord
s. - setConsumerStartTimeout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the timeout to wait for a consumer thread to start before logging an error.
- setContainerCustomizer(Consumer<ConcurrentMessageListenerContainer<?, ?>>) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- setContainerCustomizer(ContainerCustomizer<K, V, C>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a customizer used to further configure a container after it has been created.
- setContainerFactory(KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the
KafkaListenerContainerFactory
to use in case aKafkaListenerEndpoint
is registered with anull
container factory. - setContainerFactoryBeanName(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the bean name of the
KafkaListenerContainerFactory
to use in case aKafkaListenerEndpoint
is registered with anull
container factory. - setContentClassIdFieldName(String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure header name for container object contents type information.
- setControlFlag(KafkaJaasLoginModuleInitializer.ControlFlag) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- setCorrelationHeaderName(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a custom header name for the correlation id.
- setCorrelationHeaderName(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a custom header name for the correlation id.
- setCorrelationHeaderName(String) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a custom header name for the correlation id.
- setCorrelationHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a custom header name for the correlation id.
- setCorrelationIdStrategy(Function<ProducerRecord<K, V>, CorrelationKey>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a function to be called to establish a unique correlation key for each request record.
- setCreateOrModifyTopic(Predicate<NewTopic>) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set a predicate that returns true if a discovered
NewTopic
bean should be considered for creation or modification by this admin instance. - setCustomMethodArgumentResolvers(HandlerMethodArgumentResolver...) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Add custom methods arguments resolvers to
KafkaListenerAnnotationBeanPostProcessor
Default empty list. - setDeadLetterPublisherCreator(DeadLetterPublishingRecovererFactory.DeadLetterPublisherCreator) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Provide a
DeadLetterPublishingRecovererFactory.DeadLetterPublisherCreator
; used to create a subclass of theDeadLetterPublishingRecoverer
, instead of the default, for example, to modify the published records. - setDeadLetterPublishingRecovererCustomizer(Consumer<DeadLetterPublishingRecoverer>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set a customizer to customize the default
DeadLetterPublishingRecoverer
. - setDefaultContainerFactoryBeanName(String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set the name of the
KafkaListenerContainerFactory
to use by default. - setDefaultReplyTimeout(Duration) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set the reply timeout used if no replyTimeout is provided in the
ReplyingKafkaTemplate.sendAndReceive(ProducerRecord, Duration)
call. - setDefaultTopic(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the default topic for send methods where a topic is not provided.
- setDelegates(ProducerListener<K, V>...) - Method in class org.springframework.kafka.support.CompositeProducerListener
- setDeliveryAttemptHeader(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to populate the
KafkaHeaders.DELIVERY_ATTEMPT
header when the error handler or after rollback processor implementsDeliveryAttemptAware
. - setEmergencyStop(Runnable) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Set a
Runnable
to call whenever a fatal error occurs on the listener thread. - setEncodeStrings(boolean) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Set to true to encode String-valued headers as JSON ("..."), by default just the raw String value is converted to a byte array using the configured charset.
- setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Set the
KafkaListenerEndpointRegistry
that will hold the created endpoint and manage the lifecycle of the related listener container. - setEndpointRegistry(KafkaListenerEndpointRegistry) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the
KafkaListenerEndpointRegistry
instance to use. - setEosMode(ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the exactly once semantics mode.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setErrorHandler(KafkaListenerErrorHandler) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the
KafkaListenerErrorHandler
to invoke if the listener method throws an exception. - setErrorHandlerCustomizer(Consumer<DefaultErrorHandler>) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- setErrorHandlers(Map<Class<? extends Throwable>, CommonErrorHandler>) - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
-
Set the delegate error handlers; a
LinkedHashMap
argument is recommended so that the delegates are searched in a known order. - setExceptionHeadersCreator(DeadLetterPublishingRecoverer.ExceptionHeadersCreator) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set a
DeadLetterPublishingRecoverer.ExceptionHeadersCreator
implementation to completely take over setting the exception headers in the output record. - setFailedDeserializationFunction(Function<FailedDeserializationInfo, T>) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Provide an alternative supplying mechanism when deserialization fails.
- setFailIfSendResultIsError(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to true to enable waiting for the send result and throw an exception if it fails.
- setFallbackType(Class<?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a fallback type to use when using a type-aware message converter and this adapter cannot determine the inferred type from the method.
- setFatalIfBrokerNotAvailable(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set to true if you want the application context to fail to load if we are unable to connect to the broker during initialization, to check/add topics.
- setFixTxOffsets(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
When consuming records produced by a transactional producer, and the consumer is positioned at the end of a partition, the lag can incorrectly be reported as greater than zero, due to the pseudo record used to indicate transaction commit/rollback and, possibly, the presence of rolled-back records.
- setForKey(boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
-
Set to true if this deserializer is to be used as a key deserializer when configuring outside of Kafka.
- setGenerateMessageId(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Generate
Message
ids
for produced messages. - setGenerateMessageId(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Generate
Message
ids
for produced messages. - setGenerateTimestamp(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Generate
timestamp
for produced messages. - setGenerateTimestamp(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Generate
timestamp
for produced messages. - setGenericErrorHandler(GenericErrorHandler<?>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setGroup(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the group for the corresponding listener container.
- setGroupId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the group id to override the
group.id
property in the ContainerFactory. - setGroupId(String) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the group id for this container.
- setHandlerMethod(HandlerAdapter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the
HandlerAdapter
to use to invoke the method processing an incomingConsumerRecord
. - 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.
- setHeaderNamesSupplier(Supplier<DeadLetterPublishingRecoverer.HeaderNames>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
- setHeaders(Headers) - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
Set the headers.
- setHeadersFunction(BiFunction<ConsumerRecord<?, ?>, Exception, Headers>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set a function which will be called to obtain additional headers to add to the published record.
- setHeadersFunction(BiFunction<ConsumerRecord<?, ?>, Exception, Headers>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set a function that creates additional headers for the output record, in addition to the standard retry headers added by this factory.
- setHeaderValue(byte[]) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- setId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setIdClassMapping(Map<String, Class<?>>) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- setIdleBeforeDataMultiplier(double) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Multiply the
ContainerProperties.setIdleEventInterval(Long)
by this value until at least one record is received. - setIdleBetweenPolls(long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
The sleep interval in milliseconds used in the main loop between
Consumer.poll(Duration)
calls. - setIdleEventInterval(Long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
- setIdlePartitionEventInterval(Long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the idle partition event interval; when set, an event is emitted if a poll returns no records for a partition and this interval has elapsed since a record was returned.
- setIncludeContents(boolean) - Method in class org.springframework.kafka.support.LoggingProducerListener
-
Whether the log message should include the contents (key and payload).
- setInfrastructureCustomizer(KafkaStreamsInfrastructureCustomizer) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Set a customizer to configure the builder and/or topology before creating the stream.
- setInitialInterval(long) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setInterceptBeforeTx(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
When false, invoke the interceptor after the transaction starts.
- setKafkaAdmin(KafkaAdmin) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the
KafkaAdmin
, used to find the cluster id for observation, if present. - setKafkaAdmin(KafkaAdmin) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set the
KafkaAdmin
, used to find the cluster id for observation, if present. - setKafkaConsumerProperties(Properties) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- setKafkaHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.kafka.listener.adapter.ConvertingMessageListener
-
Set a
KafkaHeaderMapper
. - setKafkaStreamsCustomizer(KafkaStreamsCustomizer) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Specify a
KafkaStreamsCustomizer
to customize aKafkaStreams
instance duringStreamsBuilderFactoryBean.start()
. - setKeyClassIdFieldName(String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure header name for map key type information.
- setKeyDeserializer(Deserializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set the key deserializer.
- setKeyDeserializerSupplier(Supplier<Deserializer<K>>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set a supplier to supply instances of the key deserializer.
- setKeySerializer(Serializer<K>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a key serializer.
- setKeySerializerSupplier(Supplier<Serializer<K>>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a supplier to supply instances of the key serializer.
- setListenerContainerRegistry(ListenerContainerRegistry) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
-
Sets the
ListenerContainerRegistry
, that will be used to fetch theMessageListenerContainer
to back off. - setListenerInfo(byte[]) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the listener info to insert in the record header.
- setListenerInfo(byte[]) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set arbitrary information that will be added to the
KafkaHeaders.LISTENER_INFO
header of all records. - setListenerTaskExecutor(AsyncTaskExecutor) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the executor for threads that poll the consumer.
- setLogContainerConfig(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to instruct each container to log this configuration.
- setLoginModule(String) - Method in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- setLogLevel(KafkaException.Level) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- setLogLevel(KafkaException.Level) - Method in class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
-
Set the level at which the exception thrown by this handler is logged.
- setLogOnlyMetadata(boolean) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set to true to only log record metadata.
- setMainListenerId(String) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setMainListenerId(String) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set the main listener id, if this container is for a retry topic.
- setMapAllStringsOut(boolean) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Set to true to map all
String
valued outbound headers tobyte[]
. - setMaxAge(Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set the maximum age for a producer; useful when using transactions and the broker might expire a
transactional.id
due to inactivity. - setMaxContentLogged(int) - Method in class org.springframework.kafka.support.LoggingProducerListener
-
The maximum amount of data to be logged for either key or password.
- setMaxElapsedTime(long) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setMaxInterval(long) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setMessageConverter(MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- 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.
- setMessageConverter(MessageConverter) - Method in class org.springframework.kafka.listener.adapter.ConvertingMessageListener
-
Set a
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 theInvocableHandlerMethod
responsible to manage the invocation of this endpoint. - setMessageListener(Object) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the message listener; must be a
MessageListener
orAcknowledgingMessageListener
. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set a spring-messaging
SmartMessageConverter
to convert the record value to the desired type. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set the
SmartMessageConverter
to use with the defaultMessagingMessageConverter
. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the
SmartMessageConverter
to use with the defaultMessagingMessageConverter
. - setMessagingConverter(SmartMessageConverter) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Set a spring-messaging
SmartMessageConverter
to convert the record value to the desired type. - setMethod(Method) - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Set the method to invoke to process a message managed by this endpoint.
- setMicrometerEnabled(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set to false to disable micrometer timers, if micrometer is on the class path.
- setMicrometerEnabled(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to false to disable the Micrometer listener timers.
- setMicrometerTags(Map<String, String>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set additional tags for the Micrometer listener timers.
- setMicrometerTags(Map<String, String>) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set additional tags for the Micrometer listener timers.
- setMicrometerTagsProvider(Function<ConsumerRecord<?, ?>, Map<String, String>>) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a function to provide dynamic tags based on the consumer record.
- setMicrometerTagsProvider(Function<ProducerRecord<?, ?>, Map<String, String>>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a function to provide dynamic tags based on the producer record.
- setMissingTopicsFatal(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set to false to allow the container to start even if any of the configured topics are not present on the broker.
- setMissingTopicsFatal(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to prevent the container from starting if any of the configured topics are not present on the broker.
- setModifyTopicConfigs(boolean) - Method in class org.springframework.kafka.core.KafkaAdmin
-
Set to true to compare the current topic configuration properties with those in the
NewTopic
bean, and update if different. - setMonitorInterval(int) - Method in class org.springframework.kafka.listener.ContainerProperties
-
The interval between checks for a non-responsive consumer in seconds; default 30.
- setMultiplier(double) - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
- setNoPollThreshold(float) - Method in class org.springframework.kafka.listener.ContainerProperties
-
If the time since the last poll /
poll timeout
exceeds this value, a NonResponsiveConsumerEvent is published. - setObservationConvention(KafkaListenerObservationConvention) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a custom
KafkaListenerObservationConvention
. - setObservationConvention(KafkaTemplateObservationConvention) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a custom
KafkaTemplateObservationConvention
. - setObservationEnabled(boolean) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set to true to enable observation via Micrometer.
- setObservationEnabled(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to enable observation via Micrometer.
- setOffset(Long) - Method in class org.springframework.kafka.support.TopicPartitionOffset
-
Set the offset.
- setOffsetAndMetadataProvider(OffsetAndMetadataProvider) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the offset and metadata provider associated to a commit callback.
- 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
- setPartitionInfoTimeout(Duration) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Time to wait for partition information when verifying.
- setPartitionResolver(BiFunction<ConsumerRecord<?, ?>, String, Integer>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set a resolver for the partition number to publish to.
- setPauseImmediate(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to pause the container after the current record has been processed, rather than after all the records from the previous poll have been processed.
- setPhase(int) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Specify a
phase
to use. - setPhase(int) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setPhase(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setPhase(int) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set the
SmartLifecycle.getPhase()
. - setPhase(int) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- setPhysicalCloseTimeout(int) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
The time to wait when physically closing the producer via the factory rather than closing the producer itself (when
DefaultKafkaProducerFactory.reset()
,#closeProducerFor(String)
, orDefaultKafkaProducerFactory.closeThreadBoundProducer()
are invoked). - setPollTimeout(long) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the max time to block in the consumer waiting for records.
- setPollTimeoutWhilePaused(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the poll timeout to use while paused; usually a lower number than
pollTimeout
. - setProducerInterceptor(ProducerInterceptor<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a producer interceptor on this template.
- setProducerListener(ProducerListener<K, V>) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a
ProducerListener
which will be invoked when Kafka acknowledges a send operation. - setProducerPerConsumerPartition(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.no longer necessary because
org.springframework.kafka.listener.ContainerProperties.EOSMode#V1
is no longer supported. - setProducerPerThread(boolean) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set to true to create a producer per thread instead of singleton that is shared by all clients.
- setProducerRecordFormatter(Function<ProducerRecord<?, ?>, String>) - Static method in class org.springframework.kafka.support.KafkaUtils
-
Set a formatter for logging
ProducerRecord
s. - setRawMappedHeaders(Map<String, Boolean>) - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
-
Set the headers to not perform any conversion on (except
String
tobyte[]
for outbound). - setRawRecordHeader(boolean) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
-
Set to true to add the raw
List<ConsumerRecord<?, ?>>
as a headerKafkaHeaders.RAW_DATA
. - setRawRecordHeader(boolean) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
-
Set to true to add the raw
ConsumerRecord
as a headerKafkaHeaders.RAW_DATA
. - setReclassifyOnExceptionChange(boolean) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
-
Set to false to not reclassify the exception if different from the previous failure.
- setRecordFilterStrategy(RecordFilterStrategy<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the record filter strategy.
- setRecordFilterStrategy(RecordFilterStrategy<? super K, ? super V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a
RecordFilterStrategy
implementation. - setRecordInterceptor(RecordInterceptor<K, V>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set an interceptor to be called before calling the listener.
- setRecordInterceptor(RecordInterceptor<K, V>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set an interceptor to be called before calling the record listener.
- setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the message converter to use if dynamic argument type matching is needed for record listeners.
- setRelativeToCurrent(boolean) - Method in class org.springframework.kafka.support.TopicPartitionOffset
-
Set whether the offset is relative to the current position.
- setRemoveTypeHeaders(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set to false to retain type information headers after deserialization.
- setReplyErrorChecker(Function<ConsumerRecord<?, ?>, Exception>) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a function to examine replies for an error returned by the server.
- setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a configurer which will be invoked when creating a reply message.
- setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set a configurer which will be invoked when creating a reply message.
- setReplyHeadersConfigurer(ReplyHeadersConfigurer) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set a configurer which will be invoked when creating a reply message.
- setReplyPartitionHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a custom header name for the reply partition.
- setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set the
KafkaTemplate
to use to send replies. - setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the
KafkaTemplate
to use to send replies. - setReplyTemplate(KafkaTemplate<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the template to use to send any result from the method invocation.
- setReplyTopic(String) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set the topic to which to send any result from the method invocation.
- setReplyTopicHeaderName(String) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set a custom header name for the reply topic.
- setResetStateOnExceptionChange(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set to true to reset the retry
BackOff
if the exception is a different type to the previous failure for the same record. - setResetStateOnRecoveryFailure(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set to false to immediately attempt to recover on the next attempt instead of repeating the BackOff cycle when recovery fails.
- setRestartAfterAuthExceptions(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to automatically restart the container if an auth exception is detected by the container (or all child containers).
- setRetainAllRetryHeaderValues(boolean) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
-
Set to false to only retain the last value for
RetryTopicHeaders
; true by default, which retains all the values as the record transitions through topics. - setRetainExceptionHeader(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to true to retain a Java serialized
DeserializationException
header. - setRetainStandardFatal(boolean) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
-
Set to true to retain standard fatal exceptions as not retryable when configuring blocking retries.
- setRetryListeners(RetryListener...) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- setRetryListeners(RetryListener...) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Set one or more
RetryListener
to receive notifications of retries and recovery. - setReturnPartialOnTimeout(boolean) - Method in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Set to true to return a partial result when a request times out.
- setRunning(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setScheduler(TaskScheduler) - Method in class org.springframework.kafka.listener.ContainerProperties
-
A scheduler used with the monitor interval.
- setSeekAfterError(boolean) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
When true (default), the error handler will perform seeks on the failed and/or remaining records to they will be redelivered on the next poll.
- setSendFuture(CompletableFuture<SendResult<K, V>>) - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
- setSharedReplyTopic(boolean) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Set to true when multiple templates are using the same topic for replies.
- setShutdownTimeout(long) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the timeout for shutting down the container.
- setSkipSameTopicFatalExceptions(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false if you want to forward the record to the same topic even though the exception is fatal by this class' classification, e.g.
- setSplitIterables(boolean) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set to false to disable splitting
Iterable
reply values into separate records. - setSplitIterables(boolean) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Set to false to disable splitting
Iterable
reply values into separate records. - setStateListener(KafkaStreams.StateListener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setStateRestoreListener(StateRestoreListener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- setStopContainerAbnormally(boolean) - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
-
Set to false to stop the container normally.
- setStopContainerWhenFenced(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to stop the container when a
ProducerFencedException
is thrown. - setStopImmediate(boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set to true to stop the container after processing the current record (when stop() is called).
- setStopLastGroupWhenIdle(boolean) - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
-
Set to true to stop the containers in the final group when they go idle.
- setStoppedNormally(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setStreamsConfiguration(Properties) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Set the streams configuration
Properties
on this factory. - setStreamsUncaughtExceptionHandler(StreamsUncaughtExceptionHandler) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Set a
StreamsUncaughtExceptionHandler
. - setStripPreviousExceptionHeaders(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false to retain previous exception headers as well as headers for the current exception.
- setSubBatchPerPartition(Boolean) - Method in class org.springframework.kafka.listener.ContainerProperties
-
When using a batch message listener whether to dispatch records by partition (with a transaction for each sub batch if transactions are in use) or the complete batch received by the
poll()
. - setSyncCommits(boolean) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
- setSyncCommitTimeout(Duration) - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Set the timeout for commitSync operations (if
ConsumerProperties.isSyncCommits()
. - setSyncCommitTimeout(Duration) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the timeout for commitSync operations (if
ConsumerProperties.isSyncCommits()
. - setTaskScheduler(TaskScheduler) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- setThreadNameSupplier(Function<MessageListenerContainer, String>) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Set a function used to change the consumer thread name.
- setThreadNameSupplier(Function<MessageListenerContainer, String>) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Set a function used to change the consumer thread name.
- setThrowIfNoDestinationReturned(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to true to throw an exception if the destination resolver function returns a null TopicPartition.
- setTimeoutBuffer(long) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set the number of milliseconds to add to the producer configuration
delivery.timeout.ms
property to avoid timing out before the Kafka producer. - setTopicCheckTimeout(int) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
How long to wait for
Admin.describeTopics(Collection)
result futures to complete. - setTopicPartitions(TopicPartitionOffset...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the topicPartitions to use.
- setTopicPattern(Pattern) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the topic pattern to use.
- setTopics(String...) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Set the topics to use.
- setTopicSuffixingStrategy(TopicSuffixingStrategy) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure the retry topic name
TopicSuffixingStrategy
. - setTransactionDefinition(TransactionDefinition) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set a transaction definition with properties (e.g.
- setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a prefix for the
ProducerConfig.TRANSACTIONAL_ID_CONFIG
config. - setTransactionIdPrefix(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Set a transaction id prefix to override the prefix in the producer factory.
- setTransactionIdPrefix(String) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
-
Set a transaction id prefix to override the prefix in the producer factory.
- setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.kafka.listener.ContainerProperties
-
Set the transaction manager to start a transaction; if it is a
KafkaAwareTransactionManager
, offsets are committed with semantics equivalent toContainerProperties.AckMode.RECORD
andContainerProperties.AckMode.BATCH
depending on the listener type (record or batch). - setTypeFunction(BiFunction<byte[], Headers, JavaType>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
BiFunction
that receives the data to be deserialized and the headers and returns a JavaType. - setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
-
Set a customized type mapper.
- setTypeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
-
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.mapping.DefaultJackson2JavaTypeMapper
- setTypePrecedence(Jackson2JavaTypeMapper.TypePrecedence) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
-
Set the precedence for evaluating type information in message properties.
- setTypeResolver(JsonTypeResolver) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
JsonTypeResolver
that receives the data to be deserialized and the headers and returns a JavaType. - setUntrustedType(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- setupBackoffAwareMessageListenerAdapter(ConcurrentMessageListenerContainer<?, ?>, ListenerContainerFactoryConfigurer.Configuration, boolean) - Method in class org.springframework.kafka.retrytopic.ListenerContainerFactoryConfigurer
- setupDelegate(Map<String, ?>, String) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- setupListenerContainer(MessageListenerContainer, MessageConverter) - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- setupListenerContainer(MessageListenerContainer, MessageConverter) - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Setup the specified message listener container with the model defined by this endpoint.
- setupMessageListener(Object) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- setupMessageListener(Object) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Setup the message listener to use.
- setupThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- setupThreadState(Consumer<?, ?>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- setupThreadState(Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.ThreadStateProcessor
-
Call to set up thread-bound resources which will be available for the entire duration of enclosed operation involving a
Consumer
. - setUseForKey(boolean) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
-
Configure the TypeMapper to use default key type class.
- setUseTypeHeaders(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set to false to ignore type information in headers and use the configured target type instead.
- setUseTypeMapperForKey(boolean) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Configure the default Jackson2JavaTypeMapper to use key type headers.
- setUseTypeMapperForKey(boolean) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Configure the default Jackson2JavaTypeMapper to use key type headers.
- setValidator(Validator) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Set the validator to use if the default message handler factory is used.
- setValidator(Validator) - Method in class org.springframework.kafka.config.MultiMethodKafkaListenerEndpoint
-
Set a payload validator.
- setValueDeserializer(Deserializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set the value deserializer.
- setValueDeserializerSupplier(Supplier<Deserializer<V>>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Set a supplier to supply instances of the value deserializer.
- setValueSerializer(Serializer<V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a value serializer.
- setValueSerializerSupplier(Supplier<Serializer<V>>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Set a supplier to supply instances of the value serializer.
- setVerifyPartition(boolean) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set to false to disable partition verification.
- setWaitForSendResultTimeout(Duration) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Set the minimum time to wait for message sending.
- setZkPort(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Set the port to run the embedded Zookeeper on (default random).
- shouldCopy(String, Object) - Method in interface org.springframework.kafka.listener.adapter.ReplyHeadersConfigurer
-
Return true if the header should be copied to the reply message.
- shouldRetryOn(Integer, Throwable) - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- shutdown() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- SIMPLE - Enum constant in enum class org.springframework.kafka.listener.ListenerType
-
Simple.
- SimpleKafkaHeaderMapper - Class in org.springframework.kafka.support
-
A simple header mapper that maps headers directly; for outbound, only byte[] headers are mapped; for inbound, headers are mapped unchanged, as byte[].
- SimpleKafkaHeaderMapper() - Constructor for class org.springframework.kafka.support.SimpleKafkaHeaderMapper
-
Construct an instance with the default object mapper and default header patterns for outbound headers; all inbound headers are mapped.
- SimpleKafkaHeaderMapper(String...) - Constructor for class org.springframework.kafka.support.SimpleKafkaHeaderMapper
-
Construct an instance with a default object mapper and the provided header patterns for outbound headers; all inbound headers are mapped.
- SimplePatternBasedHeaderMatcher(String) - Constructor for class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
- SINGLE_TOPIC - Enum constant in enum class org.springframework.kafka.retrytopic.FixedDelayStrategy
-
Deprecated.Uses a single topic to achieve non-blocking retry.
- SINGLE_TOPIC - Enum constant in enum class org.springframework.kafka.retrytopic.SameIntervalTopicReuseStrategy
-
Uses a single retry topic for sequential attempts with the same interval.
- SingleRecordHeader(String, byte[]) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.SingleRecordHeader
-
Construct an instance.
- SingleRecordHeader(ByteBuffer, ByteBuffer) - Constructor for class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.SingleRecordHeader
-
Construct an instance.
- source() - Method in record class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
-
Returns the value of the
source
record component. - splitIterables() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
-
When false and the return type is an
Iterable
return the result as the value of a single reply record instead of individual records for each element. - SPRING_EMBEDDED_KAFKA_BROKERS - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- SPRING_EMBEDDED_ZOOKEEPER_CONNECT - Static variable in class org.springframework.kafka.test.EmbeddedKafkaBroker
- start() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- start() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- start() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- start() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- start() - Method in class org.springframework.kafka.listener.ContainerGroup
- start() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- start() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- start() - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Start the timer.
- stop() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- stop() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- stop() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- stop() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- stop() - Method in class org.springframework.kafka.listener.ContainerGroup
- stop() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- stop() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- stop(boolean) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Stop the container.
- stop(Runnable) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- stop(Runnable) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- stop(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- stop(Runnable) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- stopAbnormally(Runnable) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- stopAbnormally(Runnable) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Stop the container after some exception so that
MessageListenerContainer.isInExpectedState()
will return false. - stoppableSleep(MessageListenerContainer, long) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Sleep for the desired timeout, as long as the container continues to run.
- streamsAdded(String, KafkaStreams) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
-
A new
KafkaStreams
was created. - streamsAdded(String, KafkaStreams) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- StreamsBuilderFactoryBean - Class in org.springframework.kafka.config
-
An
AbstractFactoryBean
for theStreamsBuilder
instance and lifecycle control for the internalKafkaStreams
instance. - StreamsBuilderFactoryBean() - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Default constructor that creates the factory without configuration
Properties
. - StreamsBuilderFactoryBean(KafkaStreamsConfiguration) - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration.
- StreamsBuilderFactoryBean(KafkaStreamsConfiguration, CleanupConfig) - Constructor for class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Construct an instance with the supplied streams configuration and clean up configuration.
- StreamsBuilderFactoryBean.Listener - Interface in org.springframework.kafka.config
-
Called whenever a
KafkaStreams
is added or removed. - StreamsBuilderFactoryBeanConfigurer - Interface in org.springframework.kafka.config
-
A configurer for
StreamsBuilderFactoryBean
. - streamsRemoved(String, KafkaStreams) - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBean.Listener
-
An existing
KafkaStreams
was removed. - streamsRemoved(String, KafkaStreams) - Method in class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- StringJsonMessageConverter - Class in org.springframework.kafka.support.converter
-
JSON Message converter - String on output, String, Bytes, or byte[] on input.
- StringJsonMessageConverter() - Constructor for class org.springframework.kafka.support.converter.StringJsonMessageConverter
- StringJsonMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.StringJsonMessageConverter
- StringOrBytesSerializer - Class in org.springframework.kafka.support.serializer
- StringOrBytesSerializer() - Constructor for class org.springframework.kafka.support.serializer.StringOrBytesSerializer
- subscription() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- success(Object) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Record success.
- success(Object, Object) - Method in class org.springframework.kafka.support.micrometer.MicrometerHolder
-
Record success.
- success(ConsumerRecord<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
- success(ConsumerRecord<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
-
Called after the listener exits normally.
- success(ConsumerRecords<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
-
Called after the listener exits normally.
- success(ConsumerRecords<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
- SUFFICIENT - Enum constant in enum class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
-
Sufficient - The
LoginModule
is not required to succeed. - suffix() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- SUFFIX_WITH_DELAY_VALUE - Enum constant in enum class org.springframework.kafka.retrytopic.TopicSuffixingStrategy
-
Suffixes the topics the delay value for the topic.
- SUFFIX_WITH_INDEX_VALUE - Enum constant in enum class org.springframework.kafka.retrytopic.TopicSuffixingStrategy
-
Suffixes the topics with their index in the retry topics.
- Suffixer - Class in org.springframework.kafka.support
-
Utility class that suffixes strings.
- Suffixer(String) - Constructor for class org.springframework.kafka.support.Suffixer
- SuffixingRetryTopicNamesProvider(DestinationTopic.Properties) - Constructor for class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- SuffixingRetryTopicNamesProviderFactory - Class in org.springframework.kafka.retrytopic
-
Retry and dead letter naming handling that add a suffix to each name.
- SuffixingRetryTopicNamesProviderFactory() - Constructor for class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory
- SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider - Class in org.springframework.kafka.retrytopic
- suffixTopicsWithIndexValues() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure the retry topic names to be suffixed with ordinal index values.
- supportsContext(Observation.Context) - Method in interface org.springframework.kafka.support.micrometer.KafkaListenerObservationConvention
- supportsContext(Observation.Context) - Method in interface org.springframework.kafka.support.micrometer.KafkaTemplateObservationConvention
- supportsParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
AbstractKafkaListenerContainerFactory.setCommonErrorHandler(CommonErrorHandler)