Index

A B C D E F G H I J K L M N O P R S T U V W Z 
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 (ConsumerRecord or ConsumerRecords).
ReactiveKafkaConsumerTemplate<K,V> - Class in org.springframework.kafka.core.reactive
Reactive kafka consumer operations implementation.
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(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
 
RECEIVED - Static variable in class org.springframework.kafka.support.KafkaHeaders
The prefix for Kafka headers containing 'received' values.
RECEIVED_MESSAGE_KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the message key for the received message.
RECEIVED_PARTITION_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic partition for the received message.
RECEIVED_TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header for holding the timestamp of the consumer record.
RECEIVED_TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
The header containing the topic from which the message was received.
receiveExactlyOnce(TransactionManager) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
Returns a Flux of 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 the RecordMetadata object after successful send to the topic.
RecordFilterStrategy<K,V> - Interface in org.springframework.kafka.listener.adapter
Implementations of this interface can signal that a record about to be delivered to a message listener should be discarded instead of being delivered.
RecordInterceptor<K,V> - Interface in org.springframework.kafka.listener
An interceptor for ConsumerRecord invoked by the listener container before and after invoking the listener.
RecordMessageConverter - Interface in org.springframework.kafka.support.converter
A Kafka-specific Message converter strategy.
RecordMessagingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
A MessageListener adapter that invokes a configurable HandlerAdapter; used when the factory is configured for the listener to receive individual messages.
RecordMessagingMessageListenerAdapter(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
 
RecordMessagingMessageListenerAdapter(Object, Method, KafkaListenerErrorHandler) - Constructor for class org.springframework.kafka.listener.adapter.RecordMessagingMessageListenerAdapter
 
recordsToString(ConsumerRecords<?, ?>) - Static method in class org.springframework.kafka.listener.ErrorHandlingUtils
Represent the records as a comma-delimited String of topic-part@offset.
recordToString(ConsumerRecord<?, ?>) - Static method in class org.springframework.kafka.listener.ListenerUtils
Return the ConsumerRecord as a String; either toString() or topic-partition@offset.
recordToString(ConsumerRecord<?, ?>, boolean) - Static method in class org.springframework.kafka.listener.ListenerUtils
Return the ConsumerRecord as a String; either toString() or topic-partition@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.
RecoveringBatchErrorHandler - Class in org.springframework.kafka.listener
Deprecated.
in favor of DefaultErrorHandler.
RecoveringBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Deprecated.
Construct an instance with the default recoverer which simply logs the record after 10 (maxFailures) have occurred for a topic/partition/offset.
RecoveringBatchErrorHandler(BiConsumer<ConsumerRecord<?, ?>, Exception>) - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Deprecated.
Construct an instance with the provided recoverer which will be called after 10 (maxFailures) have occurred for a topic/partition/offset.
RecoveringBatchErrorHandler(BiConsumer<ConsumerRecord<?, ?>, Exception>, BackOff) - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Deprecated.
Construct an instance with the provided recoverer which will be called after the backOff returns STOP for a topic/partition/offset.
RecoveringBatchErrorHandler(BackOff) - Constructor for class org.springframework.kafka.listener.RecoveringBatchErrorHandler
Deprecated.
Construct an instance with the default recoverer which simply logs the record after the backOff returns STOP for a topic/partition/offset.
RecoveringDeserializationExceptionHandler - Class in org.springframework.kafka.streams
A DeserializationExceptionHandler that calls a ConsumerRecordRecoverer.
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.
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 new KafkaListenerEndpoint using the default KafkaListenerContainerFactory to create the underlying container.
registerEndpoint(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
Register a new KafkaListenerEndpoint alongside the KafkaListenerContainerFactory to use to create the underlying container.
registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Create a message listener container for the given KafkaListenerEndpoint.
registerListenerContainer(KafkaListenerEndpoint, KafkaListenerContainerFactory<?>, boolean) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
Create a message listener container for the given KafkaListenerEndpoint.
registerSeekCallback(ConsumerSeekAware.ConsumerSeekCallback) - Method in class org.springframework.kafka.listener.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, positive PartitionOffset.initialOffset() is absolute, negative is relative to the current topic end.
releaseResources(KafkaResourceHolder<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
 
remainingRecords() - Method in class org.springframework.kafka.listener.CommonContainerStoppingErrorHandler
 
remainingRecords() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
 
remainingRecords() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
Return false if this error handler should only receive the current failed record; remaining records will be passed to the listener after the error handler returns.
remainingRecords() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
 
remainingRecords() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
 
RemainingRecordsErrorHandler - Interface in org.springframework.kafka.listener
An error handler that has access to the unprocessed records from the last poll (including the failed record) and the consumer, for example to adjust offsets after an error.
REMOVE_TYPE_INFO_HEADERS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
Kafka config property for removing type headers (default true).
removeBackoff(TopicPartition) - Method in class org.springframework.kafka.listener.PartitionPausingBackoffManager
 
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.listener.ExceptionClassifier
Remove an exception type from the configured list.
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 class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
 
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,R> - Interface in org.springframework.kafka.requestreply
Request/reply operations.
ReplyingKafkaTemplate<K,V,R> - Class in org.springframework.kafka.requestreply
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
 
RequestReplyFuture<K,V,R> - Class in org.springframework.kafka.requestreply
A listenable future for requests/replies.
RequestReplyFuture() - Constructor for class org.springframework.kafka.requestreply.RequestReplyFuture
 
RequestReplyMessageFuture<K,V> - Class in org.springframework.kafka.requestreply
A listenable future for Message replies.
RequestReplyTypedMessageFuture<K,V,P> - Class in org.springframework.kafka.requestreply
A listenable future for Message replies with a specific payload type.
REQUIRED - Enum constant in enum class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Required - The LoginModule is required to succeed.
REQUISITE - Enum constant in enum class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer.ControlFlag
Requisite - The LoginModule is required to succeed.
reset() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
Close the Producer(s) and clear the cache of transactional Producer(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.annotation.KafkaNullAwarePayloadArgumentResolver
 
resolveBean(BeanFactory) - Method in class org.springframework.kafka.support.EndpointHandlerMethod
 
resolveDestinationTopic(String, Integer, Exception, long) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
 
resolveDestinationTopic(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 the TopicPartition, 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.EmbeddedKafkaBroker
 
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(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
 
resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
resumePartition(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
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
 
RETRY_TOPIC_BOOTSTRAPPER - Static variable in class org.springframework.kafka.retrytopic.RetryTopicInternalBeanNames
RETRY_TOPIC_CONFIGURER - Static variable in class org.springframework.kafka.retrytopic.RetryTopicInternalBeanNames
RETRY_TOPIC_NAMES_PROVIDER_FACTORY - Static variable in class org.springframework.kafka.retrytopic.RetryTopicInternalBeanNames
RetryableTopic - Annotation Interface in org.springframework.kafka.annotation
Annotation to create the retry and dlt topics for a KafkaListener annotated listener.
RetryableTopicAnnotationProcessor - Class in org.springframework.kafka.annotation
Processes the provided RetryableTopic annotation returning an RetryTopicConfiguration.
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) - 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.
RetryingBatchErrorHandler - Class in org.springframework.kafka.listener
A batch error handler that invokes the listener according to the supplied BackOff.
RetryingBatchErrorHandler() - Constructor for class org.springframework.kafka.listener.RetryingBatchErrorHandler
Construct an instance with a default FixedBackOff (unlimited attempts with a 5 second back off).
RetryingBatchErrorHandler(BackOff, ConsumerRecordRecoverer) - Constructor for class org.springframework.kafka.listener.RetryingBatchErrorHandler
Construct an instance with the provided BackOff and ConsumerRecordRecoverer.
RetryingDeserializer<T> - Class in org.springframework.kafka.support.serializer
A deserialzer configured with a delegate and a RetryOperations to retry deserialization in case of transient errors.
RetryingDeserializer(Deserializer<T>, RetryOperations) - Constructor for class org.springframework.kafka.support.serializer.RetryingDeserializer
 
RetryingMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter
Deprecated.
since 2.8 - use a suitably configured error handler instead.
RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
Deprecated.
Construct an instance with the provided template and delegate.
RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate, RecoveryCallback<? extends Object>) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
Deprecated.
Construct an instance with the provided template, callback and delegate.
RetryingMessageListenerAdapter(MessageListener<K, V>, RetryTemplate, RecoveryCallback<? extends Object>, boolean) - Constructor for class org.springframework.kafka.listener.adapter.RetryingMessageListenerAdapter
Deprecated.
Construct an instance with the provided template, callback and delegate.
RetryListener - Interface in org.springframework.kafka.listener
A listener for retry activity.
retryOn(Class<? extends Throwable>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
 
retryOn(List<Class<? extends Throwable>>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
 
RetryTopicBootstrapper - Class in org.springframework.kafka.retrytopic
Bootstraps the RetryTopicConfigurer context, registering the dependency beans and configuring the ApplicationListeners.
RetryTopicBootstrapper(ApplicationContext, BeanFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicBootstrapper
 
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 create RetryTopicConfiguration instances.
RetryTopicConfigurationBuilder() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
 
RetryTopicConfigurationProvider - Class in org.springframework.kafka.annotation
Attempts to provide an instance of RetryTopicConfiguration by either creating one from a RetryableTopic annotation, 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.
RetryTopicConfigurer - Class in org.springframework.kafka.retrytopic
Configures main, retry and DLT topics based on a main endpoint and provided configurations to acomplish a distributed retry / DLT pattern in a non-blocking fashion, at the expense of ordering guarantees.
RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, BeanFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurer
Deprecated.
RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, BeanFactory, RetryTopicNamesProviderFactory) - Constructor for class org.springframework.kafka.retrytopic.RetryTopicConfigurer
 
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
 
RetryTopicInternalBeanNames - Class in org.springframework.kafka.retrytopic
Contains the internal bean names that will be used by the retryable topic configuration.
RetryTopicInternalBeanNames() - Constructor for class org.springframework.kafka.retrytopic.RetryTopicInternalBeanNames
 
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
 
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
 
returnTypeMessageOrCollectionOf(Method) - Static method in class org.springframework.kafka.support.KafkaUtils
Return true if the method return type is Message or Collection<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
A KafkaTemplate that 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.
runner(KafkaTemplate<String, String>) - Method in class org.springframework.kafka.jdocs.started.producer.Application
 
A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form