Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
R
- RAW_DATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing the raw data received from Kafka (ConsumerRecordorConsumerRecords).
- ReactiveKafkaConsumerTemplate<K,V> - Class in org.springframework.kafka.core.reactive
- 
Reactive kafka consumer operations implementation.
- ReactiveKafkaConsumerTemplate(KafkaReceiver<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- ReactiveKafkaConsumerTemplate(ReceiverOptions<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- ReactiveKafkaProducerTemplate<K,V> - Class in org.springframework.kafka.core.reactive
- 
Reactive kafka producer operations implementation.
- ReactiveKafkaProducerTemplate(KafkaSender<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- ReactiveKafkaProducerTemplate(KafkaSender<K, V>, RecordMessageConverter) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- ReactiveKafkaProducerTemplate(SenderOptions<K, V>) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- ReactiveKafkaProducerTemplate(SenderOptions<K, V>, RecordMessageConverter) - Constructor for class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- receive() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- receive(String, int, long) - Method in interface org.springframework.kafka.core.KafkaOperations
- 
Receive a single record with the default poll timeout (5 seconds).
- receive(String, int, long, Duration) - Method in interface org.springframework.kafka.core.KafkaOperations
- 
Receive a single record.
- receive(String, int, long, Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
- receive(Collection<TopicPartitionOffset>) - Method in interface org.springframework.kafka.core.KafkaOperations
- 
Receive a multiple records with the default poll timeout (5 seconds).
- receive(Collection<TopicPartitionOffset>, Duration) - Method in interface org.springframework.kafka.core.KafkaOperations
- 
Receive multiple records.
- receive(Collection<TopicPartitionOffset>, Duration) - Method in class org.springframework.kafka.core.KafkaTemplate
- receiveAtMostOnce() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- receiveAutoAck() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- receiveBatch() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- RECEIVED - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The prefix for Kafka headers containing 'received' values.
- RECEIVED_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing the record key from the received message.
- RECEIVED_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing the topic partition from the received message.
- RECEIVED_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header for holding the timestamp of the consumer record.
- RECEIVED_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing the topic from which the message was received.
- receiveExactlyOnce(TransactionManager) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- 
Returns aFluxof consumer record batches that may be used for exactly once delivery semantics.
- RECORD - Enum constant in enum class org.springframework.kafka.listener.ContainerProperties.AckMode
- 
Commit the offset after each record is processed by the listener.
- RECORD_METADATA - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing theRecordMetadataobject after successful send to the topic.
- RecordFilterStrategy<K,V> - Interface in org.springframework.kafka.listener.adapter
- 
Implementations of this interface can signal that a record about to be delivered to a message listener should be discarded instead of being delivered.
- RecordInterceptor<K,V> - Interface in org.springframework.kafka.listener
- 
An interceptor forConsumerRecordinvoked by the listener container before and after invoking the listener.
- RecordMessageConverter - Interface in org.springframework.kafka.support.converter
- 
A Kafka-specificMessageconverter strategy.
- RecordMessagingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
- 
AMessageListeneradapter that invokes a configurableHandlerAdapter; used when the factory is configured for the listener to receive individual messages.
- RecordMessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
- RecordMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
- recordsToString(ConsumerRecords<?, ?>) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
- 
Represent the records as a comma-delimited String oftopic-part@offset.
- recovered(ConsumerRecord<?, ?>, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
- 
Called after a failing record was successfully recovered.
- recovered(ConsumerRecord<?, ?>, Exception, MessageListenerContainer, Consumer<?, ?>) - Method in interface org.springframework.kafka.listener.RecoveryStrategy
- 
Return true if the record should be skipped because it was successfully recovered.
- recovered(ConsumerRecords<?, ?>, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
- 
Called after a failing record was successfully recovered.
- RecoveringDeserializationExceptionHandler - Class in org.springframework.kafka.streams
- 
ADeserializationExceptionHandlerthat calls aConsumerRecordRecoverer.
- RecoveringDeserializationExceptionHandler() - Constructor for class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- RecoveringDeserializationExceptionHandler(ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- recoveryFailed(ConsumerRecord<?, ?>, Exception, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
- 
Called after a recovery attempt failed.
- recoveryFailed(ConsumerRecords<?, ?>, Exception, Exception) - Method in interface org.springframework.kafka.listener.RetryListener
- 
Called after a recovery attempt failed.
- RecoveryStrategy - Interface in org.springframework.kafka.listener
- 
Called to determine whether a record should be skipped.
- registerAllEndpoints() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
- registerDestinationTopic(String, String, DestinationTopic.Properties, DestinationTopicProcessor.Context) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- registerDestinationTopic(String, String, DestinationTopic.Properties, DestinationTopicProcessor.Context) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicProcessor
- 
Register the destination topic.
- registerEndpoint(KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- 
Register a newKafkaListenerEndpointusing the defaultKafkaListenerContainerFactoryto create the underlying container.
- registerEndpoint(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- 
Register a newKafkaListenerEndpointalongside theKafkaListenerContainerFactoryto use to create the underlying container.
- registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.kafka.aot.KafkaRuntimeHints
- registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- 
Create a message listener container for the givenKafkaListenerEndpoint.
- registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>, boolean) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- 
Create a message listener container for the givenKafkaListenerEndpoint.
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in interface org.springframework.kafka.listener.ConsumerSeekAware
- 
Register the callback to use when seeking at some arbitrary time.
- relativeToCurrent() - Element in annotation interface org.springframework.kafka.annotation.PartitionOffset
- 
By default, positivePartitionOffset.initialOffset()is absolute, negative is relative to the current topic end.
- releaseResources(KafkaResourceHolder<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
- releaseSuffix(String, String) - Method in class org.springframework.kafka.core.DefaultTransactionIdSuffixStrategy
- releaseSuffix(String, String) - Method in interface org.springframework.kafka.core.TransactionIdSuffixStrategy
- 
Release the suffix for the transactional producer.
- REMOVE_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- 
Kafka config property for removing type headers (default true).
- removeClassification(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.ExceptionClassifier
- 
Remove an exception type from the configured list.
- removeClassification(Class<? extends Exception>) - Method in class org.springframework.kafka.listener.FailedBatchProcessor
- removeConfig(String) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Remove the specified key from the configuration map.
- removeConfig(String) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- removeConfig(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- removeConfig(String) - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Remove the specified key from the configuration map.
- removeContainer(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ContainerGroup
- 
Remove a container from the group.
- removeDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
- removeDelegate(String) - Method in class org.springframework.kafka.support.serializer.DelegatingSerializer
- removeDelegate(Pattern) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- removeDelegate(ProducerListener<K, V>) - Method in class org.springframework.kafka.support.CompositeProducerListener
- removeHeaders(Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- removeHeaders(Headers) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- 
Remove the type information headers.
- removeListener(StreamsBuilderFactoryBean.Listener) - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- 
Remove a listener.
- removeListener(ConsumerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Remove a listener.
- removeListener(ConsumerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- 
Remove a listener.
- removeListener(ProducerFactory.Listener<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
Remove a listener.
- removeListener(ProducerFactory.Listener<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Remove a listener.
- removeNotRetryableException(Class<? extends Exception>) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- 
Remove an exception type from the configured list.
- removePostProcessor(ConsumerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ConsumerFactory
- 
Remove a post processor.
- removePostProcessor(ConsumerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- removePostProcessor(ProducerPostProcessor<K, V>) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- removePostProcessor(ProducerPostProcessor<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Remove a post processor.
- removeProducer(DefaultKafkaProducerFactory.CloseSafeProducer<K, V>, Duration) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
Remove the single shared producer and a thread-bound instance if present.
- renderProperties() - Method in class org.springframework.kafka.listener.ConsumerProperties
- replicas(int) - Method in class org.springframework.kafka.config.TopicBuilder
- 
Set the number of replicas (default broker 'default.replication.factor').
- replicasAssignments(Map<Integer, List<Integer>>) - Method in class org.springframework.kafka.config.TopicBuilder
- 
Set the replica assignments.
- replicationFactor() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
- 
The replication factor for the automatically created topics.
- REPLY_PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing a partition number on which to send the reply.
- REPLY_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing the default reply topic.
- ReplyExpressionRoot(Object, Object, Object) - Constructor for record class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- 
Creates an instance of aReplyExpressionRootrecord class.
- ReplyHeadersConfigurer - Interface in org.springframework.kafka.listener.adapter
- 
A strategy for configuring which headers, if any, should be set in a reply message.
- ReplyingKafkaOperations<K,V, - Interface in org.springframework.kafka.requestreplyR> 
- 
Request/reply operations.
- ReplyingKafkaTemplate<K,V, - Class in org.springframework.kafka.requestreplyR> 
- 
A KafkaTemplate that implements request/reply semantics.
- ReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Constructor for class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- ReplyingKafkaTemplate(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>, boolean) - Constructor for class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- request() - Method in record class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- 
Returns the value of therequestrecord component.
- RequestReplyFuture<K,V, - Class in org.springframework.kafka.requestreplyR> 
- 
ACompletableFuturefor requests/replies.
- RequestReplyFuture() - Constructor for class org.springframework.kafka.requestreply.RequestReplyFuture
- RequestReplyMessageFuture<K,V> - Class in org.springframework.kafka.requestreply
- 
A listenable future forMessagereplies.
- RequestReplyTypedMessageFuture<K,V, - Class in org.springframework.kafka.requestreplyP> 
- 
A listenable future forMessagereplies with a specific payload type.
- REQUIRED - Enum constant in enum class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
- 
Required - TheLoginModuleis required to succeed.
- REQUISITE - Enum constant in enum class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
- 
Requisite - TheLoginModuleis required to succeed.
- reset() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- 
Close theProducer(s) and clear the cache of transactionalProducer(s).
- reset() - Method in interface org.springframework.kafka.core.ProducerFactory
- 
Reset any state in the factory, if supported.
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.kafka.listener.adapter.ContinuationHandlerMethodArgumentResolver
- resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.kafka.listener.adapter.KafkaNullAwarePayloadArgumentResolver
- resolveBean(BeanFactory) - Method in class org.springframework.kafka.support.EndpointHandlerMethod
- resolveDestinationTopic(String, String, Integer, Exception, long) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- resolveDestinationTopic(String, String, Integer, Exception, long) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicResolver
- 
Resolves the destination topic for the failed message.
- resolveParameter(ParameterContext, ExtensionContext) - Method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- resolveTopicPartition(ConsumerRecord<?, ?>, DestinationTopic) - Method in class org.springframework.kafka.retrytopic.DeadLetterPublishingRecovererFactory
- 
Creates and returns theTopicPartition, where the original record should be forwarded.
- resolveType(String, byte[], Headers) - Method in interface org.springframework.kafka.support.serializer.JsonTypeResolver
- 
Determine the type.
- restart(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- result() - Method in record class org.springframework.kafka.listener.adapter.InvocationResult
- 
Returns the value of theresultrecord component.
- result() - Method in record class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- 
Returns the value of theresultrecord component.
- resume() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- resume() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- resume() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- resume() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
- 
Resume this container, if paused, after the next poll().
- resume(String) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
- 
Resume the listener container by given id.
- resume(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- resume(MessageListenerContainer) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
- 
Resume the listener container.
- resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- resumePartition(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
- 
Resume this partition, if paused, after the next poll().
- retrieveHeader(Headers, String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- retrieveHeaderAsString(Headers, String) - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- retrieveQueryableStore(String, QueryableStoreType<T>) - Method in class org.springframework.kafka.streams.KafkaStreamsInteractiveQueryService
- 
Retrieve and return a queryable store by name created in the application.
- RETRY_TOPIC_CONFIGURER_BEAN_NAME - Static variable in class org.springframework.kafka.retrytopic.RetryTopicBeanNames
- 
The bean name of the internally managed retry topic configurer.
- RetryableTopic - Annotation Interface in org.springframework.kafka.annotation
- 
Annotation to create the retry and dlt topics for aKafkaListenerannotated listener.
- RetryableTopicAnnotationProcessor - Class in org.springframework.kafka.annotation
- 
Processes the providedRetryableTopicannotation returning anRetryTopicConfiguration.
- RetryableTopicAnnotationProcessor(BeanFactory) - Constructor for class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
- 
Construct an instance using the provided parameters and default resolver, expression context.
- RetryableTopicAnnotationProcessor(BeanFactory, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
- 
Construct an instance using the provided parameters.
- retryBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable, BackOff, CommonErrorHandler, BiConsumer<ConsumerRecords<?, ?>, Exception>, LogAccessor, KafkaException.Level, List<RetryListener>, BinaryExceptionClassifier, boolean) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
- 
Retry a complete batch by pausing the consumer and then, in a loop, poll the consumer, wait for the next back off, then call the listener.
- RetryingDeserializer<T> - Class in org.springframework.kafka.support.serializer
- 
A deserializer configured with a delegate and aRetryOperationsto retry deserialization in case of transient errors.
- RetryingDeserializer(Deserializer<T>, RetryOperations) - Constructor for class org.springframework.kafka.support.serializer.RetryingDeserializer
- RetryListener - Interface in org.springframework.kafka.listener
- 
A listener for retry activity.
- retryOn(Class<? extends Exception>...) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport.BlockingRetriesConfigurer
- 
Set the exceptions that should be retried by the blocking retry mechanism.
- retryOn(Class<? extends Throwable>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- 
Configure the behavior to retry on the providedThrowable.
- retryOn(List<Class<? extends Throwable>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- 
Configure the behavior to retry on the providedThrowables.
- RetryTopicBeanNames - Class in org.springframework.kafka.retrytopic
- 
The bean names for the non-blocking topic-based delayed retries feature.
- RetryTopicComponentFactory - Class in org.springframework.kafka.retrytopic
- 
Provide the component instances that will be used withRetryTopicConfigurationSupport.
- RetryTopicComponentFactory() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- RetryTopicConfiguration - Class in org.springframework.kafka.retrytopic
- 
Contains the provided configuration for the retryable topics.
- RetryTopicConfigurationBuilder - Class in org.springframework.kafka.retrytopic
- 
Builder class to createRetryTopicConfigurationinstances.
- RetryTopicConfigurationBuilder() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- RetryTopicConfigurationProvider - Class in org.springframework.kafka.annotation
- 
Attempts to provide an instance ofRetryTopicConfigurationby either creating one from aRetryableTopicannotation, or from the bean container if no annotation is available.
- RetryTopicConfigurationProvider(BeanFactory) - Constructor for class org.springframework.kafka.annotation.RetryTopicConfigurationProvider
- 
Construct an instance using the provided bean factory and default resolver and bean expression context.
- RetryTopicConfigurationProvider(BeanFactory, BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.kafka.annotation.RetryTopicConfigurationProvider
- 
Construct an instance using the provided parameters.
- RetryTopicConfigurationSupport - Class in org.springframework.kafka.retrytopic
- 
This is the main class providing the configuration behind the non-blocking, topic-based delayed retries feature.
- RetryTopicConfigurationSupport() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- RetryTopicConfigurationSupport.BlockingRetriesConfigurer - Class in org.springframework.kafka.retrytopic
- 
Configure blocking retries to be used along non-blocking.
- RetryTopicConfigurationSupport.CustomizersConfigurer - Class in org.springframework.kafka.retrytopic
- 
Configure customizers for components instantiated by the retry topics feature.
- retryTopicConfigurer(KafkaConsumerBackoffManager, DestinationTopicResolver, ObjectProvider<RetryTopicComponentFactory>, BeanFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Return a globalRetryTopicConfigurerfor configuring retry topics forKafkaListenerEndpointinstances with a correspondingRetryTopicConfiguration.
- retryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryConfigurer, ListenerContainerFactoryResolver, RetryTopicNamesProviderFactory) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- 
Create theRetryTopicConfigurerthat will serve as an entry point for configuring non-blocking topic-based delayed retries for a givenKafkaListenerEndpoint, by processing the appropriateRetryTopicConfiguration.
- RetryTopicConfigurer - Class in org.springframework.kafka.retrytopic
- 
Configures main, retry and DLT topics based on a main endpoint and provided configurations to accomplish a distributed retry / DLT pattern in a non-blocking fashion, at the expense of ordering guarantees.
- RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, RetryTopicNamesProviderFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- 
Create an instance with the provided properties.
- RetryTopicConfigurer.EndpointProcessor - Interface in org.springframework.kafka.retrytopic
- RetryTopicConstants - Class in org.springframework.kafka.retrytopic
- 
Constants for the RetryTopic functionality.
- RetryTopicConstants() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConstants
- RetryTopicHeaders - Class in org.springframework.kafka.retrytopic
- 
Contains the headers that will be used in the forwarded messages.
- RetryTopicHeaders() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicHeaders
- retryTopicNamesProviderFactory() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- 
Create theRetryTopicNamesProviderFactoryinstance that will be used to provide the property names for the retry topics'KafkaListenerEndpoint.
- RetryTopicNamesProviderFactory - Interface in org.springframework.kafka.retrytopic
- 
Handles the naming related to the retry and dead letter topics.
- RetryTopicNamesProviderFactory.RetryTopicNamesProvider - Interface in org.springframework.kafka.retrytopic
- RetryTopicSchedulerWrapper - Class in org.springframework.kafka.retrytopic
- 
A wrapper class for aTaskSchedulerto use for scheduling container resumption when a partition has been paused for a retry topic.
- RetryTopicSchedulerWrapper(TaskScheduler) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper
- 
Create a wrapper for the supplied scheduler.
- retryTopicSuffix() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
- 
The suffix that will be appended to the main topic in order to generate the retry topics.
- retryTopicSuffix(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
- 
Configure the suffix to add to the retry topics.
- returnTypeMessageOrCollectionOf(Method) - Static method in class org.springframework.kafka.support.KafkaUtils
- 
Return true if the method return type isMessageorCollection<Message<?>>.
- revertLevels(String, JUnitUtils.LevelsContainer) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
- rollback() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- RoutingKafkaTemplate - Class in org.springframework.kafka.core
- 
AKafkaTemplatethat routes messages based on the topic name.
- RoutingKafkaTemplate(Map<Pattern, ProducerFactory<Object, Object>>) - Constructor for class org.springframework.kafka.core.RoutingKafkaTemplate
- 
Construct an instance with the provided properties.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form