Index

A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

R

RAW_DATA - Static variable in class org.springframework.pulsar.support.PulsarHeaders
Raw message data as bytes.
REACTIVE_PULSAR_LISTENER_ANNOTATION_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.pulsar.config.PulsarAnnotationSupportBeanNames
The bean name of the internally managed Pulsar listener annotation processor.
REACTIVE_PULSAR_LISTENER_ENDPOINT_REGISTRY_BEAN_NAME - Static variable in class org.springframework.pulsar.config.PulsarAnnotationSupportBeanNames
The bean name of the internally managed Pulsar listener endpoint registry.
ReactiveMessageConsumerBuilderCustomizer<T> - Interface in org.springframework.pulsar.reactive.core
Callback interface that can be implemented to customize the builder that is used by the ReactivePulsarConsumerFactory to create consumers.
ReactiveMessageReaderBuilderCustomizer<T> - Interface in org.springframework.pulsar.reactive.core
The interface to customize a ReactiveMessageReaderBuilder.
ReactiveMessageSenderBuilderCustomizer<T> - Interface in org.springframework.pulsar.reactive.core
The interface to customize a ReactiveMessageSenderBuilder.
ReactivePulsarBootstrapConfiguration - Class in org.springframework.pulsar.reactive.config.annotation
An ImportBeanDefinitionRegistrar class that registers a ReactivePulsarListenerAnnotationBeanPostProcessor bean capable of processing Spring's @ReactivePulsarListener annotation.
ReactivePulsarBootstrapConfiguration() - Constructor for class org.springframework.pulsar.reactive.config.annotation.ReactivePulsarBootstrapConfiguration
 
ReactivePulsarConsumerFactory<T> - Interface in org.springframework.pulsar.reactive.core
Pulsar reactive consumer factory interface.
ReactivePulsarContainerProperties<T> - Class in org.springframework.pulsar.reactive.listener
Contains runtime properties for a reactive listener container.
ReactivePulsarContainerProperties() - Constructor for class org.springframework.pulsar.reactive.listener.ReactivePulsarContainerProperties
 
ReactivePulsarListener - Annotation Interface in org.springframework.pulsar.reactive.config.annotation
Annotation that marks a method to be the target of a Pulsar message listener on the specified topics.
ReactivePulsarListenerAnnotationBeanPostProcessor<V> - Class in org.springframework.pulsar.reactive.config.annotation
Bean post-processor that registers methods annotated with ReactivePulsarListener to be invoked by a Pulsar message listener container created under the covers by a ReactivePulsarListenerContainerFactory according to the parameters of the annotation.
ReactivePulsarListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.pulsar.reactive.config.annotation.ReactivePulsarListenerAnnotationBeanPostProcessor
 
ReactivePulsarListenerConfigurationSelector - Class in org.springframework.pulsar.reactive.config.annotation
A DeferredImportSelector implementation with the lowest order to import ReactivePulsarBootstrapConfiguration as late as possible.
ReactivePulsarListenerConfigurationSelector() - Constructor for class org.springframework.pulsar.reactive.config.annotation.ReactivePulsarListenerConfigurationSelector
 
ReactivePulsarListenerContainerFactory<T> - Interface in org.springframework.pulsar.reactive.config
Factory for Pulsar reactive message listener containers.
ReactivePulsarListenerEndpoint<T> - Interface in org.springframework.pulsar.reactive.config
Model for a Pulsar reactive listener endpoint.
ReactivePulsarListenerEndpointAdapter<T> - Class in org.springframework.pulsar.reactive.config
Deprecated, for removal: This API element is subject to removal in a future version.
for removal in favor of ReactivePulsarListenerEndpoint
ReactivePulsarListenerEndpointAdapter() - Constructor for class org.springframework.pulsar.reactive.config.ReactivePulsarListenerEndpointAdapter
Deprecated.
 
ReactivePulsarListenerEndpointRegistry<T> - Class in org.springframework.pulsar.reactive.config
Creates the necessary ReactivePulsarMessageListenerContainer instances for the registered endpoints.
ReactivePulsarListenerEndpointRegistry() - Constructor for class org.springframework.pulsar.reactive.config.ReactivePulsarListenerEndpointRegistry
 
ReactivePulsarListenerMessageConsumerBuilderCustomizer<T> - Interface in org.springframework.pulsar.reactive.config.annotation
Callback interface that can be implemented by a bean to customize the builder that is used to create the underlying Pulsar reactive message consumer used by a ReactivePulsarListener to receive messages.
ReactivePulsarListeners - Annotation Interface in org.springframework.pulsar.reactive.config.annotation
Container annotation that aggregates several ReactivePulsarListener annotations.
ReactivePulsarMessageHandler - Interface in org.springframework.pulsar.reactive.listener
Reactive message handler used by DefaultReactivePulsarMessageListenerContainer.
ReactivePulsarMessageListenerContainer<T> - Interface in org.springframework.pulsar.reactive.listener
Internal abstraction used by the framework representing a reactive message listener container.
ReactivePulsarOneByOneMessageHandler<T> - Interface in org.springframework.pulsar.reactive.listener
Message handler class with a ReactivePulsarOneByOneMessageHandler.received(org.apache.pulsar.client.api.Message<T>) method for use in ReactiveMessagePipelineBuilder.messageHandler(java.util.function.Function<org.apache.pulsar.client.api.Message<T>, org.reactivestreams.Publisher<java.lang.Void>>).
ReactivePulsarOperations<T> - Interface in org.springframework.pulsar.reactive.core
The Pulsar reactive send operations contract.
ReactivePulsarOperations.SendManyMessageBuilder<T> - Interface in org.springframework.pulsar.reactive.core
 
ReactivePulsarOperations.SendMessageBuilder<O,T> - Interface in org.springframework.pulsar.reactive.core
Builder that can be used to configure and send a message.
ReactivePulsarOperations.SendOneMessageBuilder<T> - Interface in org.springframework.pulsar.reactive.core
 
ReactivePulsarReaderFactory<T> - Interface in org.springframework.pulsar.reactive.core
The strategy to create a ReactiveMessageReader instance(s).
ReactivePulsarRuntimeHints - Class in org.springframework.pulsar.reactive.aot
RuntimeHintsRegistrar for Spring for Apache Pulsar (reactive).
ReactivePulsarRuntimeHints() - Constructor for class org.springframework.pulsar.reactive.aot.ReactivePulsarRuntimeHints
 
ReactivePulsarSenderFactory<T> - Interface in org.springframework.pulsar.reactive.core
The strategy to create a ReactiveMessageSender instance(s).
ReactivePulsarStreamingHandler<T> - Interface in org.springframework.pulsar.reactive.listener
Message handler class with a ReactivePulsarStreamingHandler.received(reactor.core.publisher.Flux<org.apache.pulsar.client.api.Message<T>>) method for use in ReactiveMessagePipelineBuilder.streamingMessageHandler(java.util.function.Function<reactor.core.publisher.Flux<org.apache.pulsar.client.api.Message<T>>, org.reactivestreams.Publisher<org.apache.pulsar.reactive.client.api.MessageResult<java.lang.Void>>>).
ReactivePulsarTemplate<T> - Class in org.springframework.pulsar.reactive.core
A template for executing high-level reactive Pulsar operations.
ReactivePulsarTemplate(ReactivePulsarSenderFactory<T>) - Constructor for class org.springframework.pulsar.reactive.core.ReactivePulsarTemplate
Construct a template instance that uses the default schema resolver and topic resolver.
ReactivePulsarTemplate(ReactivePulsarSenderFactory<T>, SchemaResolver, TopicResolver) - Constructor for class org.springframework.pulsar.reactive.core.ReactivePulsarTemplate
Construct a template instance with a custom schema resolver and a custom topic resolver.
readerBuilderCustomizer - Variable in class org.springframework.pulsar.reader.AbstractPulsarMessageReaderContainer
 
ReaderBuilderCustomizer<T> - Interface in org.springframework.pulsar.core
Callback interface that can be implemented to customize the ReaderBuilder that is used by the PulsarReaderFactory to create readers.
ReaderContainerFactory<C extends PulsarMessageReaderContainer,E extends PulsarReaderEndpoint<C>> - Interface in org.springframework.pulsar.config
Base container factory interface for PulsarMessageReaderContainer.
readerCustomizer() - Element in annotation interface org.springframework.pulsar.annotation.PulsarReader
The bean name or a SpEL expression that resolves to a PulsarReaderReaderBuilderCustomizer to use to configure the reader.
ReaderFailedToStartEvent - Class in org.springframework.pulsar.event
Event to publish when the reader is failed to start.
ReaderFailedToStartEvent(Object, Object) - Constructor for class org.springframework.pulsar.event.ReaderFailedToStartEvent
Construct an instance with the provided source and container.
ReaderStartedEvent - Class in org.springframework.pulsar.event
Event to publish when the reader is started.
ReaderStartedEvent(Object, Object) - Constructor for class org.springframework.pulsar.event.ReaderStartedEvent
Construct an instance with the provided source and container.
ReaderStartingEvent - Class in org.springframework.pulsar.event
Event to publish while the reader is starting.
ReaderStartingEvent(Object, Object) - Constructor for class org.springframework.pulsar.event.ReaderStartingEvent
Construct an instance with the provided source and container.
received(Consumer<T>, List<Message<T>>) - Method in interface org.springframework.pulsar.listener.PulsarBatchAcknowledgingMessageListener
 
received(Consumer<T>, List<Message<T>>) - Method in interface org.springframework.pulsar.listener.PulsarBatchMessageListener
 
received(Consumer<T>, List<Message<T>>, Acknowledgement) - Method in interface org.springframework.pulsar.listener.PulsarBatchAcknowledgingMessageListener
 
received(Consumer<T>, List<Message<T>>, Acknowledgement) - Method in interface org.springframework.pulsar.listener.PulsarBatchMessageListener
 
received(Consumer<T>, Message<T>) - Method in interface org.springframework.pulsar.listener.PulsarAcknowledgingMessageListener
 
received(Consumer<T>, Message<T>) - Method in interface org.springframework.pulsar.listener.PulsarBatchMessageListener
 
received(Consumer<T>, Message<T>, Acknowledgement) - Method in interface org.springframework.pulsar.listener.PulsarAcknowledgingMessageListener
 
received(Consumer<T>, Message<T>, Acknowledgement) - Method in interface org.springframework.pulsar.listener.PulsarRecordMessageListener
 
received(Consumer<V>, List<Message<V>>, Acknowledgement) - Method in class org.springframework.pulsar.listener.adapter.PulsarBatchMessagesToSpringMessageListenerAdapter
 
received(Consumer<V>, Message<V>, Acknowledgement) - Method in class org.springframework.pulsar.listener.adapter.PulsarRecordMessageToSpringMessageListenerAdapter
 
received(Message<T>) - Method in interface org.springframework.pulsar.reactive.listener.ReactivePulsarOneByOneMessageHandler
Callback passed to ReactiveMessagePipelineBuilder.messageHandler(java.util.function.Function<org.apache.pulsar.client.api.Message<T>, org.reactivestreams.Publisher<java.lang.Void>>) that will be called for each received message.
received(Message<V>) - Method in class org.springframework.pulsar.reactive.listener.adapter.PulsarReactiveOneByOneMessagingMessageListenerAdapter
 
received(Reader<V>, Message<V>) - Method in class org.springframework.pulsar.listener.adapter.PulsarRecordMessageToSpringMessageReaderAdapter
 
received(Flux<Message<T>>) - Method in interface org.springframework.pulsar.reactive.listener.ReactivePulsarStreamingHandler
Callback passed to ReactiveMessagePipelineBuilder.streamingMessageHandler(java.util.function.Function<reactor.core.publisher.Flux<org.apache.pulsar.client.api.Message<T>>, org.reactivestreams.Publisher<org.apache.pulsar.reactive.client.api.MessageResult<java.lang.Void>>>) that will be applied to the flux of received message.
received(Flux<Message<V>>) - Method in class org.springframework.pulsar.reactive.listener.adapter.PulsarReactiveStreamingMessagingMessageListenerAdapter
 
RECORD - Enum constant in enum class org.springframework.pulsar.listener.AckMode
Record ack mode.
recovererForConsumer(Consumer<T>) - Method in class org.springframework.pulsar.listener.PulsarDeadLetterPublishingRecoverer
 
recovererForConsumer(Consumer<T>) - Method in interface org.springframework.pulsar.listener.PulsarMessageRecovererFactory
Provides a message recoverer PulsarMessageRecoverer.
recoverMessage(Consumer<T>, Message<T>, Exception) - Method in class org.springframework.pulsar.listener.DefaultPulsarConsumerErrorHandler
 
recoverMessage(Consumer<T>, Message<T>, Exception) - Method in interface org.springframework.pulsar.listener.PulsarConsumerErrorHandler
Recover the message based on the implementation provided.
recoverMessage(Message<T>, Exception) - Method in interface org.springframework.pulsar.listener.PulsarMessageRecoverer
Recover a failed message, for e.g.
REDELIVERY_COUNT - Static variable in class org.springframework.pulsar.support.PulsarHeaders
Redelivery count.
registerAllEndpoints() - Method in class org.springframework.pulsar.config.PulsarListenerEndpointRegistrar
 
registerAllEndpoints() - Method in class org.springframework.pulsar.config.PulsarReaderEndpointRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.pulsar.annotation.PulsarBootstrapConfiguration
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.springframework.pulsar.reactive.config.annotation.ReactivePulsarBootstrapConfiguration
 
registerDestructionCallback(String, Runnable) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor.ListenerScope
 
registerEndpoint(ListenerEndpoint, ListenerContainerFactory<?, ?>) - Method in class org.springframework.pulsar.config.PulsarListenerEndpointRegistrar
 
registerEndpoint(PulsarReaderEndpoint, ReaderContainerFactory<?, ?>) - Method in class org.springframework.pulsar.config.PulsarReaderEndpointRegistrar
 
registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.pulsar.aot.PulsarRuntimeHints
 
registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.pulsar.reactive.aot.ReactivePulsarRuntimeHints
 
registerListenerContainer(E, ListenerContainerFactory<? extends C, E>) - Method in class org.springframework.pulsar.config.GenericListenerEndpointRegistry
 
registerListenerContainer(E, ListenerContainerFactory<? extends C, E>, boolean) - Method in class org.springframework.pulsar.config.GenericListenerEndpointRegistry
 
registerReaderContainer(E, ReaderContainerFactory<? extends C, E>) - Method in class org.springframework.pulsar.config.GenericReaderEndpointRegistry
 
registerReaderContainer(E, ReaderContainerFactory<? extends C, E>, boolean) - Method in class org.springframework.pulsar.config.GenericReaderEndpointRegistry
 
remove(String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor.ListenerScope
 
removeCustomMapping(Class<?>) - Method in class org.springframework.pulsar.core.DefaultSchemaResolver
Removes the custom mapping from message type to schema.
removeCustomMapping(Class<?>) - Method in class org.springframework.pulsar.core.DefaultTopicResolver
Removes the custom mapping from message type to topic.
removeListener(String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor.ListenerScope
 
REPLICATED_FROM - Static variable in class org.springframework.pulsar.support.PulsarHeaders
Cluster where the message is replicated from.
resolve(String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolveArgument(MethodParameter, Message<?>) - Method in class org.springframework.pulsar.annotation.PulsarNullAwarePayloadArgumentResolver
 
resolveAsString(Object, List<String>) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolveContextualObject(String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor.ListenerScope
 
Resolved<T> - Class in org.springframework.pulsar.core
A resolved value or an exception if it could not be resolved.
resolveExpression(String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolveExpressionAsBoolean(String, String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolveExpressionAsInteger(String, String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolveExpressionAsString(String, String) - Method in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolver - Variable in class org.springframework.pulsar.annotation.AbstractPulsarAnnotationsBeanPostProcessor
 
resolveSchema(Class<?>) - Method in interface org.springframework.pulsar.core.SchemaResolver
Get the schema to use for a message type.
resolveSchema(Class<?>, boolean) - Method in class org.springframework.pulsar.core.DefaultSchemaResolver
 
resolveSchema(Class<?>, boolean) - Method in interface org.springframework.pulsar.core.SchemaResolver
Get the schema to use for a message type.
resolveSchema(SchemaType, Class<?>, Class<?>) - Method in interface org.springframework.pulsar.core.SchemaResolver
Get the schema to use given a schema type and schema type information.
resolveSchema(SchemaType, ResolvableType) - Method in class org.springframework.pulsar.core.DefaultSchemaResolver
 
resolveSchema(SchemaType, ResolvableType) - Method in interface org.springframework.pulsar.core.SchemaResolver
Get the schema to use given a schema type and a message type.
resolveSchema(T) - Method in interface org.springframework.pulsar.core.SchemaResolver
Get the schema to use for a particular message.
resolveTopic(String, Class<?>, Supplier<String>) - Method in class org.springframework.pulsar.core.DefaultTopicResolver
 
resolveTopic(String, Class<?>, Supplier<String>) - Method in interface org.springframework.pulsar.core.TopicResolver
Resolve the topic name to use for the given message type.
resolveTopic(String, Supplier<String>) - Method in class org.springframework.pulsar.core.DefaultTopicResolver
 
resolveTopic(String, Supplier<String>) - Method in interface org.springframework.pulsar.core.TopicResolver
Resolve the topic name to use.
resolveTopic(String, T, Supplier<String>) - Method in class org.springframework.pulsar.core.DefaultTopicResolver
 
resolveTopic(String, T, Supplier<String>) - Method in interface org.springframework.pulsar.core.TopicResolver
Resolve the topic name to use for the given message.
resolveTopicName(String) - Method in class org.springframework.pulsar.core.DefaultPulsarProducerFactory
 
resolveToString(String) - Method in class org.springframework.pulsar.core.DefaultExpressionResolver
Resolve the given expression as a string value.
resolveToString(String) - Method in interface org.springframework.pulsar.core.ExpressionResolver
Resolve the given expression as a string value.
resume() - Method in class org.springframework.pulsar.listener.AbstractPulsarMessageListenerContainer
 
resume() - Method in interface org.springframework.pulsar.listener.PulsarMessageListenerContainer
Resume this container, if paused.
rollback() - Method in class org.springframework.pulsar.transaction.PulsarResourceHolder
 
running - Variable in class org.springframework.pulsar.core.AbstractPulsarMessageContainer
 
A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form