A B C D E F G H I K L M N O P R S T U V
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- accessMode(ProducerAccessMode) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the type of access mode that the producer requires on the topic.
- acknowledge(Message<V>) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns an empty value and signals that the message must be acknowledged.
- acknowledge(MessageId) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns an empty value and signals that the message must be acknowledged.
- acknowledge(MessageId) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Returns an empty value and signals that the message must be acknowledged.
- acknowledge(MessageId, T) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns the processed value and signals that the message must be acknowledged.
- acknowledge(MessageId, T) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Returns the processed value and signals that the message must be acknowledged.
- acknowledgeAndReturn(Message<V>) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns a message and signals that it must be acknowledged.
- acknowledgeAsynchronously(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
When set to true, ignores the acknowledge operation completion and makes it asynchronous from the message consuming processing to improve performance by allowing the acknowledges and message processing to interleave.
- acknowledgementsGroupTime(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the duration for grouping the acknowledgement messages.
- acknowledgeScheduler(Scheduler) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the scheduler to use to handle acknowledgements.
- ackTimeout(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the timeout for unacknowledged messages, truncated to the nearest millisecond.
- ackTimeoutTickTime(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the granularity of the ack-timeout redelivery.
- ApiImplementationFactory - Class in org.apache.pulsar.reactive.client.internal.api
-
Internal API implementation.
- applySpec(ReactiveMessageConsumerSpec) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Updates this spec from the defined values of another spec.
- applySpec(ReactiveMessageConsumerSpec) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Apply a consumer spec to configure the consumer.
- applySpec(ReactiveMessageReaderSpec) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Updates this spec from the defined values of another spec.
- applySpec(ReactiveMessageReaderSpec) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Applies a reader spec to configure the reader.
- applySpec(ReactiveMessageSenderSpec) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Updates this spec from the defined values of another spec.
- applySpec(ReactiveMessageSenderSpec) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Applies a sender spec to configure the sender.
- autoAckOldestChunkedMessageOnQueueFull(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets whether non-chunked messages are silently acknowledged when
maxPendingChunkedMessage
is reached. - autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets whether the consumer shall automatically subscribe to new partitions added to the topic.
- autoUpdatePartitions(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
If enabled, the sender will automatically discover new partitions of partitioned topics at runtime.
- autoUpdatePartitionsInterval(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the interval for checking partitions updates (default: 1 minute).
- autoUpdatePartitionsInterval(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the interval of partitions updates (default: 1 minute).
B
- batcherBuilder(BatcherBuilder) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the batcher builder of the sender.
- batchIndexAckEnabled(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Enables or disables the batch index acknowledgment.
- batchingEnabled(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets whether batching of messages is enabled for the sender.
- batchingMaxBytes(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the maximum number of bytes permitted in a batch.
- batchingMaxMessages(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the maximum number of messages permitted in a batch.
- batchingMaxPublishDelay(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the time period within which the messages sent will be batched default: 1 ms if batched messages are enabled.
- build() - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Builds the
MessageSpec
. - build() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Builds the reactive message consumer.
- build() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
-
Builds the pipeline instance.
- build() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Builds the reactive reader.
- build() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Builds the reactive message sender.
- builder(T) - Static method in interface org.apache.pulsar.reactive.client.api.MessageSpec
-
Creates a message spec builder from a value.
C
- cache(ReactiveMessageSenderCache) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the cache to use for the sender.
- chunkingEnabled(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets whether chunking of messages is enabled If enabled, when the message size is higher than the maximum allowed publishing payload size on the broker, then the sender will split the message into multiple chunks and publish them to the broker separately and in order.
- clone() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Creates and returns a copy of this reactive consumer builder.
- clone() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Creates and returns a copy of this reactive reader builder.
- clone() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Creates and returns a copy of this reactive sender builder.
- close() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipeline
-
Closes the reactive pipeline.
- COMPLETE - org.apache.pulsar.reactive.client.api.EndOfStreamAction
-
Complete at end of stream.
- compressionType(CompressionType) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the compression type for the sender.
- concurrency(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder
-
Sets the concurrency for the pipeline.
- configure(TypedMessageBuilder<T>) - Method in interface org.apache.pulsar.reactive.client.internal.api.InternalMessageSpec
-
Configures the message from this message spec.
- consumeMany(Function<Flux<Message<T>>, Publisher<MessageResult<R>>>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumer
-
Consumes messages continuously.
- consumeNothing() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumer
-
Creates the Pulsar Consumer and immediately closes it.
- consumeOne(Function<Message<T>, Publisher<MessageResult<R>>>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumer
-
Consumes one message.
- consumerName(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the consumer name.
- correlationMetadata(Object) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Attach a correlation metadata to the message spec to be able to correlate a sending operation and the sending operation result.
- createMessageSpecBuilder(T) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Creates a message spec builder from a value.
- createReactiveMessageHandlerPipelineBuilder(ReactiveMessageConsumer<T>) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Creates a builder for building a
ReactiveMessagePipeline
. - createValueOnlyMessageSpec(T) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Creates a message spec from a value.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the action the consumer will take in case of decryption failures.
- cryptoFailureAction(ConsumerCryptoFailureAction) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the action the reader will take in case of decryption failures.
- cryptoFailureAction(ProducerCryptoFailureAction) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the action the sender will take in case of encryption failures.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the key reader to be used to decrypt the message payloads.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the key reader to be used to decrypt the message payloads.
- cryptoKeyReader(CryptoKeyReader) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the key reader to be used to encrypt the message payloads.
D
- deadLetterPolicy(DeadLetterPolicy) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets a dead letter policy for the consumer.
- DEFAULT_MAX_PENDING_SUBSCRIPTIONS - Static variable in class org.apache.pulsar.reactive.client.internal.api.InflightLimiter
-
Default limit for pending Reactive Stream subscriptions.
- deliverAfter(long, TimeUnit) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Request to deliver the message only after the specified relative delay.
- deliverAt(long) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Deliver the message only at or after the specified absolute timestamp.
- disableReplication() - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Disable geo-replication for this message.
- dispose() - Method in class org.apache.pulsar.reactive.client.internal.api.InflightLimiter
E
- encryptionKeys(Set<String>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the public encryption key names, used by the producer to encrypt the data key.
- endOfStreamAction(EndOfStreamAction) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the action to perform once the end of the stream is reached.
- EndOfStreamAction - Enum in org.apache.pulsar.reactive.client.api
-
Action to perform once the end of the stream is reached.
- equals(Object) - Method in class org.apache.pulsar.reactive.client.api.InstantStartAtSpec
- equals(Object) - Method in class org.apache.pulsar.reactive.client.api.MessageIdStartAtSpec
- equals(Object) - Method in class org.apache.pulsar.reactive.client.api.MessageSendResult
- errorLogger(BiConsumer<Message<T>, Throwable>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder
-
Sets a function which will be called when the message handler emits an error.
- eventTime(long) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Set the event time for a given message.
- expireTimeOfIncompleteChunkedMessage(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the duration after which incomplete chunked messages are expired (happens for instance if the producer fails to publish all the chunks).
F
- fillInStackTrace() - Method in exception org.apache.pulsar.reactive.client.api.ReactiveMessageSendingException
G
- generatedSubscriptionNamePrefix(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the generated subscription name prefix.
- getAccessMode() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getAccessMode() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getAccessMode() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the type of access mode that the producer requires on the topic.
- getAcknowledgeAsynchronously() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAcknowledgeAsynchronously() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAcknowledgeAsynchronously() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether to ignore the acknowledge operation completion and make it asynchronous from the message consuming processing to improve performance by allowing the acknowledges and message processing to interleave.
- getAcknowledgementsGroupTime() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAcknowledgementsGroupTime() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAcknowledgementsGroupTime() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the duration used to group acknowledgements.
- getAcknowledgeScheduler() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAcknowledgeScheduler() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAcknowledgeScheduler() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the scheduler to use to handle acknowledgements.
- getAckTimeout() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAckTimeout() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAckTimeout() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the timeout duration for unacknowledged messages.
- getAckTimeoutTickTime() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAckTimeoutTickTime() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAckTimeoutTickTime() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the tick time of the ack-timeout redelivery.
- getAutoAckOldestChunkedMessageOnQueueFull() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAutoAckOldestChunkedMessageOnQueueFull() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAutoAckOldestChunkedMessageOnQueueFull() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether to automatically acknowledge pending chunked messages when maxPendingChunkedMessage is reached.
- getAutoUpdatePartitions() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAutoUpdatePartitions() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getAutoUpdatePartitions() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAutoUpdatePartitions() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getAutoUpdatePartitions() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether the consumer shall subscribe automatically to new partitions of partitioned topics.
- getAutoUpdatePartitions() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets whether partitioned producer will automatically discover new partitions at runtime.
- getAutoUpdatePartitionsInterval() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getAutoUpdatePartitionsInterval() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getAutoUpdatePartitionsInterval() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getAutoUpdatePartitionsInterval() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getAutoUpdatePartitionsInterval() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the interval of updating partitions when autoUpdatePartitions is enabled.
- getAutoUpdatePartitionsInterval() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the interval of partitions updates if autoUpdatePartitions is enabled.
- getBatcherBuilder() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getBatcherBuilder() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getBatcherBuilder() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the batcher builder of the producer.
- getBatchIndexAckEnabled() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getBatchIndexAckEnabled() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getBatchIndexAckEnabled() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether batch index acknowledgement is enabled.
- getBatchingEnabled() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getBatchingEnabled() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getBatchingEnabled() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets whether automatic batching of messages is enabled for the producer.
- getBatchingMaxBytes() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getBatchingMaxBytes() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getBatchingMaxBytes() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the maximum number of bytes permitted in a batch.
- getBatchingMaxMessages() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getBatchingMaxMessages() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getBatchingMaxMessages() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the maximum number of messages permitted in a batch.
- getBatchingMaxPublishDelay() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getBatchingMaxPublishDelay() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getBatchingMaxPublishDelay() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the time period within which the messages sent will be batched.
- getChunkingEnabled() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getChunkingEnabled() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getChunkingEnabled() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets whether chunking of messages is enabled.
- getCompressionType() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getCompressionType() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getCompressionType() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the compression type for the producer.
- getConsumerName() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getConsumerName() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getConsumerName() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the consumer name.
- getCorrelationMetadata() - Method in class org.apache.pulsar.reactive.client.api.MessageSendResult
-
Gets the correlation metadata of the message spec that was sent.
- getCorrelationMetadata() - Method in interface org.apache.pulsar.reactive.client.api.MessageSpec
-
Gets the correlation metadata of this message spec.
- getCorrelationMetadata() - Method in exception org.apache.pulsar.reactive.client.api.ReactiveMessageSendingException
-
Returns the correlation metadata of the message that failed to be sent.
- getCryptoFailureAction() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getCryptoFailureAction() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getCryptoFailureAction() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getCryptoFailureAction() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getCryptoFailureAction() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getCryptoFailureAction() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getCryptoFailureAction() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the action the consumer will take in case of decryption failures.
- getCryptoFailureAction() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the action the reader will take in case of decryption failures.
- getCryptoFailureAction() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the action the producer will take in case of encryption failures.
- getCryptoKeyReader() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getCryptoKeyReader() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getCryptoKeyReader() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getCryptoKeyReader() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getCryptoKeyReader() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getCryptoKeyReader() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getCryptoKeyReader() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the key reader to be used to decrypt the message payloads.
- getCryptoKeyReader() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the key reader to be used to decrypt the message payloads.
- getCryptoKeyReader() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the key reader to be used to encrypt the message payloads.
- getDeadLetterPolicy() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getDeadLetterPolicy() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getDeadLetterPolicy() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the dead letter policy for the consumer.
- getEncryptionKeys() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getEncryptionKeys() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getEncryptionKeys() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the public encryption key names, used by producer to encrypt the data key.
- getException() - Method in class org.apache.pulsar.reactive.client.api.MessageSendResult
-
Gets the exception if any.
- getExpireTimeOfIncompleteChunkedMessage() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getExpireTimeOfIncompleteChunkedMessage() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getExpireTimeOfIncompleteChunkedMessage() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the time interval to expire incomplete chunks if a consumer fails to receive all the chunks.
- getGeneratedSubscriptionNamePrefix() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getGeneratedSubscriptionNamePrefix() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getGeneratedSubscriptionNamePrefix() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the generated subscription name prefix.
- getHashingScheme() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getHashingScheme() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getHashingScheme() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the hashing function determining the partition where to publish a particular message on partitioned topics.
- getInitialSequenceId() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getInitialSequenceId() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getInitialSequenceId() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the baseline for the sequence ids for messages published by the producer.
- getInstant() - Method in class org.apache.pulsar.reactive.client.api.InstantStartAtSpec
-
Gets the instant from when to start reading from.
- getKeyHashRanges() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getKeyHashRanges() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getKeyHashRanges() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the key hash ranges of the reader.
- getKeySharedPolicy() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getKeySharedPolicy() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getKeySharedPolicy() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the policy used for
SubscriptionType.Key_Shared
subscriptions. - getLazyStartPartitionedProducers() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getLazyStartPartitionedProducers() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getLazyStartPartitionedProducers() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets whether producers register and connect immediately to the owner broker of each partition or start lazily on demand.
- getMaxPendingChunkedMessage() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getMaxPendingChunkedMessage() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getMaxPendingChunkedMessage() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the maximum number of messages in the queue holding pending chunked messages.
- getMaxPendingMessages() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getMaxPendingMessages() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getMaxPendingMessages() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the maximum size of the queue holding the messages pending to receive an acknowledgment from the broker.
- getMaxPendingMessagesAcrossPartitions() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getMaxPendingMessagesAcrossPartitions() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getMaxPendingMessagesAcrossPartitions() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the maximum number of pending messages across all the partitions.
- getMaxTotalReceiverQueueSizeAcrossPartitions() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getMaxTotalReceiverQueueSizeAcrossPartitions() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getMaxTotalReceiverQueueSizeAcrossPartitions() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the max total receiver queue size across partitions.
- getMessage() - Method in exception org.apache.pulsar.reactive.client.api.ReactiveMessageSendingException
- getMessageId() - Method in class org.apache.pulsar.reactive.client.api.MessageIdStartAtSpec
-
Gets the message id from which to start reading from.
- getMessageId() - Method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Gets the id of the message to acknowledge or negatively acknowledge.
- getMessageId() - Method in class org.apache.pulsar.reactive.client.api.MessageSendResult
-
Gets the ID assigned to the message.
- getMessageRouter() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getMessageRouter() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getMessageRouter() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the custom message router.
- getMessageRoutingMode() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getMessageRoutingMode() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getMessageRoutingMode() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the message routing logic for producers on partitioned topics.
- getMessageSpec() - Method in class org.apache.pulsar.reactive.client.api.MessageSendResult
-
Gets the message spec that was sent.
- getMessageSpec() - Method in exception org.apache.pulsar.reactive.client.api.ReactiveMessageSendingException
-
Returns the message that failed to be sent.
- getMultiSchema() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getMultiSchema() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getMultiSchema() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets whether the multiple schema mode is enabled.
- getMutableSpec() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Converts this builder to a mutable reactive consumer spec.
- getMutableSpec() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Gets the mutable spec of this builder.
- getMutableSpec() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Converts this builder to a mutable reactive sender spec with the same settings.
- getNegativeAckRedeliveryDelay() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getNegativeAckRedeliveryDelay() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getNegativeAckRedeliveryDelay() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the delay to wait before re-delivering messages that have failed to be processed.
- getPriorityLevel() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getPriorityLevel() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getPriorityLevel() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the priority level for the consumer to which a broker gives more priority while dispatching messages.
- getProducerName() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getProducerName() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getProducerName() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the name of the producer.
- getProperties() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getProperties() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getProperties() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getProperties() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getProperties() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the consumer properties.
- getProperties() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the properties of the producer.
- getReadCompacted() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getReadCompacted() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getReadCompacted() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getReadCompacted() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getReadCompacted() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether to read messages from the compacted topic rather than reading the full message backlog of the topic.
- getReadCompacted() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets whether to read messages from the compacted topic rather than reading the full message backlog of the topic.
- getReaderName() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getReaderName() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getReaderName() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the reader name.
- getReceiverQueueSize() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getReceiverQueueSize() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getReceiverQueueSize() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getReceiverQueueSize() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getReceiverQueueSize() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the size of the consumer receive queue.
- getReceiverQueueSize() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the size of the reader receive queue.
- getReplicateSubscriptionState() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getReplicateSubscriptionState() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getReplicateSubscriptionState() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether the subscription shall be replicated.
- getRetryLetterTopicEnable() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getRetryLetterTopicEnable() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getRetryLetterTopicEnable() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets whether the retries are enabled.
- getRoundRobinRouterBatchingPartitionSwitchFrequency() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getRoundRobinRouterBatchingPartitionSwitchFrequency() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getRoundRobinRouterBatchingPartitionSwitchFrequency() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message.
- getSendTimeout() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getSendTimeout() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getSendTimeout() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the send timeout.
- getSubscriptionInitialPosition() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getSubscriptionInitialPosition() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getSubscriptionInitialPosition() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the subscription initial position.
- getSubscriptionMode() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getSubscriptionMode() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getSubscriptionMode() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the subscription mode.
- getSubscriptionName() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getSubscriptionName() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getSubscriptionName() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getSubscriptionName() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getSubscriptionName() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the subscription name.
- getSubscriptionName() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the subscription name.
- getSubscriptionProperties() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getSubscriptionProperties() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getSubscriptionProperties() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the properties for the subscription.
- getSubscriptionType() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getSubscriptionType() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getSubscriptionType() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the subscription type.
- getTopicName() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- getTopicName() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
- getTopicName() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderSpec
-
Gets the topic to publish on.
- getTopicNames() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getTopicNames() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- getTopicNames() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getTopicNames() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
- getTopicNames() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the topics to subscribe to.
- getTopicNames() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderSpec
-
Gets the topics to read from.
- getTopicsPattern() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getTopicsPattern() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getTopicsPattern() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the topics pattern of the topics to subscribe to.
- getTopicsPatternAutoDiscoveryPeriod() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getTopicsPatternAutoDiscoveryPeriod() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getTopicsPatternAutoDiscoveryPeriod() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the topics auto discovery period when using a topic pattern.
- getTopicsPatternSubscriptionMode() - Method in class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- getTopicsPatternSubscriptionMode() - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
- getTopicsPatternSubscriptionMode() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerSpec
-
Gets the type of topics to subscribe to when using a topic pattern - Persistent, Non-Persistent, or both.
- getValue() - Method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Gets the value processed by the message processing.
- getValue() - Method in interface org.apache.pulsar.reactive.client.api.MessageSpec
-
Gets the value of this message spec.
- groupByProcessingGroup(Flux<Message<T>>, MessageGroupingFunction, int) - Static method in class org.apache.pulsar.reactive.client.internal.api.GroupOrderedMessageProcessors
-
Splits the flux of messages by message key into the given number of groups.
- GroupOrderedMessageProcessors - Class in org.apache.pulsar.reactive.client.internal.api
-
Functions for implementing In-order parallel processing for Pulsar messages using Project Reactor.
- groupOrderedProcessing(MessageGroupingFunction) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder
-
Sets a function to group messages to be sent to the same message handler.
H
- handlingTimeout(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder
-
Sets the timeout for the message handler function.
- hashCode() - Method in class org.apache.pulsar.reactive.client.api.InstantStartAtSpec
- hashCode() - Method in class org.apache.pulsar.reactive.client.api.MessageIdStartAtSpec
- hashCode() - Method in class org.apache.pulsar.reactive.client.api.MessageSendResult
- hashingScheme(HashingScheme) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the hashing scheme used to choose the partition on where to publish a particular message.
I
- identity() - Static method in interface org.apache.pulsar.reactive.client.internal.api.PublisherTransformer
-
Gets a
PublisherTransformer
that returns the inputPublisher
without modification. - ImmutableReactiveMessageConsumerSpec - Class in org.apache.pulsar.reactive.client.api
-
Immutable spec for a
ReactiveMessageConsumer
. - ImmutableReactiveMessageConsumerSpec(List<String>, Pattern, RegexSubscriptionMode, Duration, String, SubscriptionMode, SubscriptionType, SubscriptionInitialPosition, KeySharedPolicy, Boolean, Map<String, String>, String, Map<String, String>, Integer, Boolean, Boolean, Duration, Duration, Duration, Boolean, Scheduler, Duration, DeadLetterPolicy, Boolean, Integer, Integer, Boolean, Duration, CryptoKeyReader, ConsumerCryptoFailureAction, Integer, Boolean, Duration) - Constructor for class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
- ImmutableReactiveMessageConsumerSpec(ReactiveMessageConsumerSpec) - Constructor for class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageConsumerSpec
-
Constructs a ImmutableReactiveMessageConsumerSpec from another
ReactiveMessageConsumerSpec
. - ImmutableReactiveMessageReaderSpec - Class in org.apache.pulsar.reactive.client.api
-
Immutable spec for a
ReactiveMessageReader
. - ImmutableReactiveMessageReaderSpec(List<String>, String, String, String, Integer, Boolean, List<Range>, CryptoKeyReader, ConsumerCryptoFailureAction) - Constructor for class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
- ImmutableReactiveMessageReaderSpec(ReactiveMessageReaderSpec) - Constructor for class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageReaderSpec
-
Constructs a ImmutableReactiveMessageConsumerSpec from another
ReactiveMessageConsumerSpec
. - ImmutableReactiveMessageSenderSpec - Class in org.apache.pulsar.reactive.client.api
-
Immutable spec for a
ReactiveMessageSender
. - ImmutableReactiveMessageSenderSpec(String, String, Duration, Integer, Integer, MessageRoutingMode, HashingScheme, ProducerCryptoFailureAction, MessageRouter, Duration, Integer, Integer, Integer, Boolean, BatcherBuilder, Boolean, CryptoKeyReader, Set<String>, CompressionType, Long, Boolean, Duration, Boolean, ProducerAccessMode, Boolean, Map<String, String>) - Constructor for class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- ImmutableReactiveMessageSenderSpec(ReactiveMessageSenderSpec) - Constructor for class org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
-
Constructs a ImmutableReactiveMessageConsumerSpec from another
ReactiveMessageConsumerSpec
. - InflightLimiter - Class in org.apache.pulsar.reactive.client.internal.api
-
Transformer class that limits the number of reactive streams subscription requests to keep the number of pending messages under a defined limit.
- InflightLimiter(int) - Constructor for class org.apache.pulsar.reactive.client.internal.api.InflightLimiter
-
Constructs an InflightLimiter with a maximum number of in-flight messages.
- InflightLimiter(int, int, Scheduler, int) - Constructor for class org.apache.pulsar.reactive.client.internal.api.InflightLimiter
-
Constructs an InflightLimiter.
- initialSequenceId(long) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the baseline for the sequence ids for messages published by the producer.
- InstantStartAtSpec - Class in org.apache.pulsar.reactive.client.api
-
Spec for a
ReactiveMessageReader
to start reading from a given instant in time. - InstantStartAtSpec(Instant) - Constructor for class org.apache.pulsar.reactive.client.api.InstantStartAtSpec
-
Constructs a
InstantStartAtSpec
. - InternalMessageSpec<T> - Interface in org.apache.pulsar.reactive.client.internal.api
-
Internal interface for the spec of a message to be sent.
- isAcknowledgeMessage() - Method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Gets whether the message must be acknowledged.
- isDisposed() - Method in class org.apache.pulsar.reactive.client.internal.api.InflightLimiter
- isInclusive() - Method in class org.apache.pulsar.reactive.client.api.MessageIdStartAtSpec
-
Gets whether the message with the message id must be included.
- isRunning() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipeline
-
Gets whether the reactive pipeline is running.
K
- key(String) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Sets the key of the message for routing policy.
- keyBytes(byte[]) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Sets the bytes of the key of the message for routing policy.
- keyHashRanges(List<Range>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the key hash ranges of the reader.
- keySharedPolicy(KeySharedPolicy) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the KeyShared subscription policy for the consumer.
L
- lazyStartPartitionedProducers(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets whether to start partitioned producers lazily.
M
- maxConcurrentSenderSubscriptions(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the maximum number of concurrent subscriptions for the sender.
- maxInflight(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder
-
Sets a global limit to the number of messages in-flight over all the concurrent handlers.
- maxInflight(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the maximum number of in-flight messages for the sender.
- maxPendingChunkedMessage(Integer) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the maximum pending chunked messages.
- maxPendingMessages(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the maximum size of the queues holding the messages pending to receive an acknowledgment from the broker.
- maxPendingMessagesAcrossPartitions(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the maximum number of pending messages across all the partitions.
- maxTotalReceiverQueueSizeAcrossPartitions(Integer) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the maximum total receiver queue size across partitions.
- messageConsumer(Schema<T>) - Method in interface org.apache.pulsar.reactive.client.api.ReactivePulsarClient
-
Creates a builder for building a
ReactiveMessageConsumer
. - MessageGroupingFunction - Interface in org.apache.pulsar.reactive.client.api
-
Function to group messages that will be processed by the same instance of concurrent message handler.
- messageHandler(Function<Message<T>, Publisher<Void>>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
-
Sets a handler function that processes messages one-by-one.
- MessageIdStartAtSpec - Class in org.apache.pulsar.reactive.client.api
-
Spec for a
ReactiveMessageReader
to start reading from a given message id. - MessageIdStartAtSpec(MessageId, boolean) - Constructor for class org.apache.pulsar.reactive.client.api.MessageIdStartAtSpec
-
Contructs a
MessageIdStartAtSpec
. - messagePipeline() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumer
-
Creates a builder for building a
ReactiveMessagePipeline
. - messageReader(Schema<T>) - Method in interface org.apache.pulsar.reactive.client.api.ReactivePulsarClient
-
Creates a builder for building a
ReactiveMessageReader
. - MessageResult<T> - Interface in org.apache.pulsar.reactive.client.api
-
Result of a message processing.
- messageRouter(MessageRouter) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets a custom message routing policy by passing an implementation of
MessageRouter
. - messageRoutingMode(MessageRoutingMode) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the routing mode for a partitioned producer.
- messageSender(Schema<T>) - Method in interface org.apache.pulsar.reactive.client.api.ReactivePulsarClient
-
Creates a builder for building a
ReactiveMessageSender
. - MessageSendResult<T> - Class in org.apache.pulsar.reactive.client.api
-
Result of a message sending.
- MessageSendResult(MessageId, MessageSpec<T>, Throwable) - Constructor for class org.apache.pulsar.reactive.client.api.MessageSendResult
-
Creates a new instance.
- MessageSpec<T> - Interface in org.apache.pulsar.reactive.client.api
-
Interface for the spec of a message to be sent.
- MessageSpecBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for
MessageSpec
. - multiSchema(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets whether to enable the multiple schema mode for the producer.
- MutableReactiveMessageConsumerSpec - Class in org.apache.pulsar.reactive.client.api
-
Mutable spec for a
ReactiveMessageConsumer
. - MutableReactiveMessageConsumerSpec() - Constructor for class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Constructs a default MutableReactiveMessageConsumerSpec.
- MutableReactiveMessageConsumerSpec(ReactiveMessageConsumerSpec) - Constructor for class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Constructs a MutableReactiveMessageConsumerSpec from another
ReactiveMessageConsumerSpec
. - MutableReactiveMessageReaderSpec - Class in org.apache.pulsar.reactive.client.api
-
Mutable spec for a
ReactiveMessageReader
. - MutableReactiveMessageReaderSpec() - Constructor for class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Constructs a default MutableReactiveMessageReaderSpec.
- MutableReactiveMessageReaderSpec(ReactiveMessageReaderSpec) - Constructor for class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Constructs a MutableReactiveMessageReaderSpec from another
ReactiveMessageReaderSpec
. - MutableReactiveMessageSenderSpec - Class in org.apache.pulsar.reactive.client.api
-
Mutable spec for a
ReactiveMessageSender
. - MutableReactiveMessageSenderSpec() - Constructor for class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Constructs a default MutableReactiveMessageSenderSpec.
- MutableReactiveMessageSenderSpec(ReactiveMessageSenderSpec) - Constructor for class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Constructs a MutableReactiveMessageSenderSpec from another
ReactiveMessageSenderSpec
.
N
- negativeAcknowledge(Message<V>) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns an empty value and signals that the message must be negatively acknowledged.
- negativeAcknowledge(MessageId) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns an empty value and signals that the message must be negatively acknowledged.
- negativeAcknowledge(MessageId) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Returns an empty value and signals that the message must be negatively acknowledged.
- negativeAcknowledge(MessageId, T) - Static method in interface org.apache.pulsar.reactive.client.api.MessageResult
-
Returns the processed value and signals that the message must be negatively acknowledged.
- negativeAcknowledge(MessageId, T) - Static method in class org.apache.pulsar.reactive.client.internal.api.ApiImplementationFactory
-
Returns the processed value and signals that the message must be negatively acknowledged.
- negativeAckRedeliveryDelay(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the delay to wait before re-delivering messages that have failed to be processed.
O
- of(T) - Static method in interface org.apache.pulsar.reactive.client.api.MessageSpec
-
Creates a message spec from a value.
- ofEarliest() - Static method in class org.apache.pulsar.reactive.client.api.StartAtSpec
-
Gets a spec to start from the oldest message available in the topic.
- ofInstant(Instant) - Static method in class org.apache.pulsar.reactive.client.api.StartAtSpec
-
Gets a spec to start from an instant in time.
- ofLatest() - Static method in class org.apache.pulsar.reactive.client.api.StartAtSpec
-
Gets a spec to start from the next message that will be available in the topic.
- ofLatestInclusive() - Static method in class org.apache.pulsar.reactive.client.api.StartAtSpec
-
Gets a spec to start from the most recently published message in the topic, including that message.
- ofMessageId(MessageId) - Static method in class org.apache.pulsar.reactive.client.api.StartAtSpec
-
Gets a spec to start from a message id, not including that message.
- ofMessageId(MessageId, boolean) - Static method in class org.apache.pulsar.reactive.client.api.StartAtSpec
-
Gets a spec to start from a message id.
- orderingKey(byte[]) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Sets the ordering key of the message for message dispatch in
SubscriptionType.Key_Shared
mode. - org.apache.pulsar.reactive.client.api - package org.apache.pulsar.reactive.client.api
- org.apache.pulsar.reactive.client.internal.api - package org.apache.pulsar.reactive.client.internal.api
P
- pipelineRetrySpec(Retry) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
-
Sets a retry spec that will be used in case of failures in the pipeline.
- POLL - org.apache.pulsar.reactive.client.api.EndOfStreamAction
-
Continue polling for new messages when end of stream is reached.
- priorityLevel(Integer) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the priority level for the consumer.
- processGroupsInOrderConcurrently(Flux<Message<T>>, MessageGroupingFunction, Function<? super Message<T>, ? extends Publisher<? extends R>>, Scheduler, int) - Static method in class org.apache.pulsar.reactive.client.internal.api.GroupOrderedMessageProcessors
-
Processes the messages concurrently with the targeted concurrency.
- processGroupsInOrderInParallel(Flux<Message<T>>, MessageGroupingFunction, Function<? super Message<T>, ? extends Publisher<? extends R>>, Scheduler, int) - Static method in class org.apache.pulsar.reactive.client.internal.api.GroupOrderedMessageProcessors
-
Processes the messages in parallel with the targeted parallelism.
- producerName(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets a name for the producers created under this sender.
- properties(Map<String, String>) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Add all the properties in the provided map.
- properties(Map<String, String>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the properties for the consumer.
- properties(Map<String, String>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the properties to the producer.
- property(String, String) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Sets a new property on a message.
- property(String, String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Adds a property to the consumer.
- property(String, String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Adds a property to the producer.
- PublisherTransformer - Interface in org.apache.pulsar.reactive.client.internal.api
-
Class to transform a
Publisher
to anotherPublisher
.
R
- ReactiveMessageConsumer<T> - Interface in org.apache.pulsar.reactive.client.api
-
Reactive message consumer interface.
- ReactiveMessageConsumerBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for
ReactiveMessageConsumer
. - ReactiveMessageConsumerSpec - Interface in org.apache.pulsar.reactive.client.api
-
Spec for a
ReactiveMessageConsumer
. - ReactiveMessagePipeline - Interface in org.apache.pulsar.reactive.client.api
-
Reactive message pipeline interface.
- ReactiveMessagePipelineBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for
ReactiveMessagePipeline
. - ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for a pipeline that handles messages with concurrent one-by-one messages handlers.
- ReactiveMessagePipelineBuilder.OneByOneMessagePipelineBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for a pipeline that handles messages one-by-one.
- ReactiveMessageReader<T> - Interface in org.apache.pulsar.reactive.client.api
-
Reactive message reader interface.
- ReactiveMessageReaderBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for
ReactiveMessageReader
. - ReactiveMessageReaderSpec - Interface in org.apache.pulsar.reactive.client.api
-
Spec for a
ReactiveMessageReader
. - ReactiveMessageSender<T> - Interface in org.apache.pulsar.reactive.client.api
-
Reactive message sender interface.
- ReactiveMessageSenderBuilder<T> - Interface in org.apache.pulsar.reactive.client.api
-
Builder interface for
ReactiveMessageSender
. - ReactiveMessageSenderCache - Interface in org.apache.pulsar.reactive.client.api
-
Marker interface for a cache that combines multiple sent messages to share the same Pulsar producer in the Pulsar client implementation level.
- ReactiveMessageSenderSpec - Interface in org.apache.pulsar.reactive.client.api
-
Spec for
ReactiveMessageSender
configuration. - ReactiveMessageSendingException - Exception in org.apache.pulsar.reactive.client.api
-
A wrapper exception used by
ReactiveMessageSender.sendMany(Publisher)
. - ReactiveMessageSendingException(Throwable, MessageSpec<?>) - Constructor for exception org.apache.pulsar.reactive.client.api.ReactiveMessageSendingException
-
Creates a new instance.
- ReactivePulsarClient - Interface in org.apache.pulsar.reactive.client.api
-
Apache Pulsar Reactive Client interface.
- readCompacted(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets whether the consumer will read messages from the compacted topic rather than reading the full message backlog of the topic.
- readCompacted(Boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets whether the reader will read messages from the compacted topic rather than reading the full message backlog of the topic.
- readerName(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the reader name.
- readMany() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReader
-
Read messages continuously.
- readOne() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReader
-
Read one message.
- receiverQueueSize(Integer) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the size of the consumer receiver queue.
- receiverQueueSize(Integer) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the size of the reader receiver queue.
- replicateSubscriptionState(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets whether the subscription shall be replicated.
- replicationClusters(List<String>) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Override the geo-replication clusters for this message.
- resolveProcessingGroup(Message<?>, int) - Method in interface org.apache.pulsar.reactive.client.api.MessageGroupingFunction
-
Resolves a processing group for a message.
- retryLetterTopicEnable(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets whether automatic routing to retry letter topic and dead letter topic are enabled.
- roundRobinRouterBatchingPartitionSwitchFrequency(int) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message default: 10.
S
- sendMany(Publisher<MessageSpec<T>>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSender
-
Send multiple messages and get the sending results in the same order as the messages sent.
- sendOne(MessageSpec<T>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSender
-
Send one message.
- sendTimeout(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the send timeout (default: 30 seconds) for this sender.
- sequenceId(long) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Specify a custom sequence id for the message being published.
- setAccessMode(ProducerAccessMode) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the type of access mode that the producer requires on the topic.
- setAcknowledgeAsynchronously(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether to ignore the acknowledge operation completion and make it asynchronous from the message consuming processing to improve performance by allowing the acknowledges and message processing to interleave.
- setAcknowledgementsGroupTime(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the duration used to group acknowledgements.
- setAcknowledgeScheduler(Scheduler) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the scheduler to use to handle acknowledgements.
- setAckTimeout(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the timeout duration for unacknowledged messages.
- setAckTimeoutTickTime(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the tick time of the ack-timeout redelivery.
- setAutoAckOldestChunkedMessageOnQueueFull(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether to automatically acknowledge pending chunked messages when maxPendingChunkedMessage is reached.
- setAutoUpdatePartitions(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether the consumer shall subscribe automatically to new partitions of partitioned topics.
- setAutoUpdatePartitions(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets whether partitioned producer will automatically discover new partitions at runtime.
- setAutoUpdatePartitionsInterval(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the interval of updating partitions when autoUpdatePartitions is enabled.
- setAutoUpdatePartitionsInterval(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the interval of partitions updates if autoUpdatePartitions is enabled.
- setBatcherBuilder(BatcherBuilder) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the batcher builder of the producer.
- setBatchIndexAckEnabled(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether batch index acknowledgement is enabled.
- setBatchingEnabled(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets whether automatic batching of messages is enabled for the producer.
- setBatchingMaxBytes(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the maximum number of bytes permitted in a batch.
- setBatchingMaxMessages(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the maximum number of messages permitted in a batch.
- setBatchingMaxPublishDelay(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the time period within which the messages sent will be batched.
- setChunkingEnabled(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets whether chunking of messages is enabled.
- setCompressionType(CompressionType) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the compression type for the producer.
- setConsumerName(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the consumer name.
- setCryptoFailureAction(ConsumerCryptoFailureAction) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the action the consumer will take in case of decryption failures.
- setCryptoFailureAction(ConsumerCryptoFailureAction) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the action the reader will take in case of decryption failures.
- setCryptoFailureAction(ProducerCryptoFailureAction) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the action the producer will take in case of encryption failures.
- setCryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the key reader to be used to decrypt the message payloads.
- setCryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the key reader to be used to decrypt the message payloads.
- setCryptoKeyReader(CryptoKeyReader) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the key reader to be used to encrypt the message payloads.
- setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the dead letter policy for the consumer.
- setEncryptionKeys(Set<String>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the public encryption key names, used by producer to encrypt the data key.
- setExpireTimeOfIncompleteChunkedMessage(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the time interval to expire incomplete chunks if a consumer fails to receive all the chunks.
- setGeneratedSubscriptionNamePrefix(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the generated subscription name prefix.
- setHashingScheme(HashingScheme) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the hashing function determining the partition where to publish a particular message on partitioned topics.
- setInitialSequenceId(Long) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the baseline for the sequence ids for messages published by the producer.
- setKeyHashRanges(List<Range>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the key hash ranges of the reader.
- setKeySharedPolicy(KeySharedPolicy) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the policy used for
SubscriptionType.Key_Shared
subscriptions. - setLazyStartPartitionedProducers(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets whether producers register and connect immediately to the owner broker of each partition or start lazily on demand.
- setMaxPendingChunkedMessage(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the maximum number of messages in the queue holding pending chunked messages.
- setMaxPendingMessages(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the maximum size of the queue holding the messages pending to receive an acknowledgment from the broker.
- setMaxPendingMessagesAcrossPartitions(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the maximum number of pending messages across all the partitions.
- setMaxTotalReceiverQueueSizeAcrossPartitions(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the maximum total receiver queue size across partitions.
- setMessageRouter(MessageRouter) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets a custom message router.
- setMessageRoutingMode(MessageRoutingMode) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the message routing logic for producers on partitioned topics.
- setMultiSchema(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets whether the multiple schema mode is enabled.
- setNegativeAckRedeliveryDelay(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the delay to wait before re-delivering messages that have failed to be processed.
- setPriorityLevel(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the priority level for the consumer to which a broker gives more priority while dispatching messages.
- setProducerName(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the name of the producer.
- setProperties(Map<String, String>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the consumer properties.
- setProperties(Map<String, String>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the properties of the producer.
- setReadCompacted(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether to read messages from the compacted topic rather than reading the full message backlog of the topic.
- setReadCompacted(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets whether to read messages from the compacted topic rather than reading the full message backlog of the topic.
- setReaderName(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the reader name.
- setReceiverQueueSize(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the size of the consumer receive queue.
- setReceiverQueueSize(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the size of the reader receive queue.
- setReplicateSubscriptionState(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether the subscription shall be replicated.
- setRetryLetterTopicEnable(Boolean) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets whether the retries are enabled.
- setRoundRobinRouterBatchingPartitionSwitchFrequency(Integer) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message.
- setSendTimeout(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the send timeout.
- setSubscriptionInitialPosition(SubscriptionInitialPosition) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the subscription initial position.
- setSubscriptionMode(SubscriptionMode) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the subscription mode.
- setSubscriptionName(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the subscription name.
- setSubscriptionName(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the subscription name.
- setSubscriptionProperties(Map<String, String>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the properties for the subscription.
- setSubscriptionType(SubscriptionType) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the subscription type.
- setTopicName(String) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageSenderSpec
-
Sets the topic to publish on.
- setTopicNames(List<String>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the topics to subscribe to.
- setTopicNames(List<String>) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageReaderSpec
-
Sets the topics to read from.
- setTopicsPattern(Pattern) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the topics pattern of the topics to subscribe to.
- setTopicsPatternAutoDiscoveryPeriod(Duration) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the topics auto discovery period when using a topic pattern.
- setTopicsPatternSubscriptionMode(RegexSubscriptionMode) - Method in class org.apache.pulsar.reactive.client.api.MutableReactiveMessageConsumerSpec
-
Sets the type of topics to subscribe to when using a topic pattern - Persistent, Non-Persistent, or both.
- start() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipeline
-
Starts the reactive pipeline.
- startAtSpec(StartAtSpec) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the position where to start reading from.
- StartAtSpec - Class in org.apache.pulsar.reactive.client.api
-
Spec to specify to a
ReactiveMessageReader
from where to start reading. - stop() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipeline
-
Stops the reactive pipeline.
- stopOnError(boolean) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets whether an error when sending an individual message of the
ReactiveMessageSender.sendMany(Publisher)
operation should stop the full stream or not. - streamingMessageHandler(Function<Flux<Message<T>>, Publisher<MessageResult<Void>>>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
-
Sets a handler function that processes the stream of messages.
- subscriptionInitialPosition(SubscriptionInitialPosition) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the initial position of the subscription for the consumer.
- subscriptionMode(SubscriptionMode) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the subscription mode to be used when subscribing to the topic.
- subscriptionName(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the subscription name for this consumer.
- subscriptionName(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the subscription name.
- subscriptionProperties(Map<String, String>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the subscription properties for this subscription.
- subscriptionProperty(String, String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Adds a subscription property for this subscription.
- subscriptionType(SubscriptionType) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the subscription type to be used when subscribing to the topic.
T
- toImmutableSpec() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Converts this builder to an immutable reactive consumer spec.
- toImmutableSpec() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Gets an immutable spec from the underlying spec of this builder.
- toImmutableSpec() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Converts this builder to an immutable reactive sender spec with the same settings.
- topic(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Adds a topic this consumer will subscribe on.
- topic(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Adds a topic this reader will read from.
- topic(String) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageSenderBuilder
-
Sets the topic this sender will be publishing on.
- topic(String...) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Adds topics this consumer will subscribe on.
- topic(String...) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Adds topics this reader will read from.
- topics(List<String>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the topics this consumer will subscribe on.
- topics(List<String>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageReaderBuilder
-
Sets the topics this reader will read from.
- topicsPattern(Pattern) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets a pattern for topics that this consumer will subscribe on.
- topicsPatternAutoDiscoveryPeriod(Duration) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets the topics auto discovery period when using a pattern for topics consumer.
- topicsPatternSubscriptionMode(RegexSubscriptionMode) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessageConsumerBuilder
-
Sets to which topics this consumer should be subscribed to - Persistent, Mon-Persistent, or both.
- toString() - Method in class org.apache.pulsar.reactive.client.api.InstantStartAtSpec
- toString() - Method in class org.apache.pulsar.reactive.client.api.MessageIdStartAtSpec
- transform(Publisher<T>) - Method in class org.apache.pulsar.reactive.client.internal.api.InflightLimiter
- transform(Publisher<T>) - Method in interface org.apache.pulsar.reactive.client.internal.api.PublisherTransformer
-
Transforms a
Publisher
to anotherPublisher
. - transformPipeline(Function<Mono<Void>, Publisher<Void>>) - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder
-
Sets a transform function that can be used to customize the pipeline.
U
- useKeyOrderedProcessing() - Method in interface org.apache.pulsar.reactive.client.api.ReactiveMessagePipelineBuilder.ConcurrentOneByOneMessagePipelineBuilder
-
Sets whether messages with the same key should be sent in order to the same message handler.
V
- value(T) - Method in interface org.apache.pulsar.reactive.client.api.MessageSpecBuilder
-
Set a domain object on the message.
- valueOf(String) - Static method in enum org.apache.pulsar.reactive.client.api.EndOfStreamAction
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.pulsar.reactive.client.api.EndOfStreamAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
All Classes All Packages