Interface ReactiveMessageConsumerSpec

    • Method Summary

      All Methods Instance Methods Abstract Methods 
      Modifier and Type Method Description
      java.lang.Boolean getAcknowledgeAsynchronously()
      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.
      java.time.Duration getAcknowledgementsGroupTime()
      Gets the duration used to group acknowledgements.
      reactor.core.scheduler.Scheduler getAcknowledgeScheduler()
      Gets the scheduler to use to handle acknowledgements.
      java.time.Duration getAckTimeout()
      Gets the timeout duration for unacknowledged messages.
      java.time.Duration getAckTimeoutTickTime()
      Gets the tick time of the ack-timeout redelivery.
      java.lang.Boolean getAutoAckOldestChunkedMessageOnQueueFull()
      Gets whether to automatically acknowledge pending chunked messages when maxPendingChunkedMessage is reached.
      java.lang.Boolean getAutoUpdatePartitions()
      Gets whether the consumer shall subscribe automatically to new partitions of partitioned topics.
      java.time.Duration getAutoUpdatePartitionsInterval()
      Gets the interval of updating partitions when autoUpdatePartitions is enabled.
      java.lang.Boolean getBatchIndexAckEnabled()
      Gets whether batch index acknowledgement is enabled.
      java.lang.String getConsumerName()
      Gets the consumer name.
      org.apache.pulsar.client.api.ConsumerCryptoFailureAction getCryptoFailureAction()
      Gets the action the consumer will take in case of decryption failures.
      org.apache.pulsar.client.api.CryptoKeyReader getCryptoKeyReader()
      Gets the key reader to be used to decrypt the message payloads.
      org.apache.pulsar.client.api.DeadLetterPolicy getDeadLetterPolicy()
      Gets the dead letter policy for the consumer.
      java.time.Duration getExpireTimeOfIncompleteChunkedMessage()
      Gets the time interval to expire incomplete chunks if a consumer fails to receive all the chunks.
      org.apache.pulsar.client.api.KeySharedPolicy getKeySharedPolicy()
      Gets the policy used for SubscriptionType.Key_Shared subscriptions.
      java.lang.Integer getMaxPendingChunkedMessage()
      Gets the maximum number of messages in the queue holding pending chunked messages.
      java.lang.Integer getMaxTotalReceiverQueueSizeAcrossPartitions()
      Gets the max total receiver queue size across partitions.
      java.time.Duration getNegativeAckRedeliveryDelay()
      Gets the delay to wait before re-delivering messages that have failed to be processed.
      java.lang.Integer getPriorityLevel()
      Gets the priority level for the consumer to which a broker gives more priority while dispatching messages.
      java.util.Map<java.lang.String,​java.lang.String> getProperties()
      Gets the consumer properties.
      java.lang.Boolean getReadCompacted()
      Gets whether to read messages from the compacted topic rather than reading the full message backlog of the topic.
      java.lang.Integer getReceiverQueueSize()
      Gets the size of the consumer receive queue.
      java.lang.Boolean getReplicateSubscriptionState()
      Gets whether the subscription shall be replicated.
      java.lang.Boolean getRetryLetterTopicEnable()
      Gets whether the retries are enabled.
      org.apache.pulsar.client.api.SubscriptionInitialPosition getSubscriptionInitialPosition()
      Gets the subscription initial position.
      org.apache.pulsar.client.api.SubscriptionMode getSubscriptionMode()
      Gets the subscription mode.
      java.lang.String getSubscriptionName()
      Gets the subscription name.
      java.util.Map<java.lang.String,​java.lang.String> getSubscriptionProperties()
      Gets the properties for the subscription.
      org.apache.pulsar.client.api.SubscriptionType getSubscriptionType()
      Gets the subscription type.
      java.util.List<java.lang.String> getTopicNames()
      Gets the topics to subscribe to.
      java.util.regex.Pattern getTopicsPattern()
      Gets the topics pattern of the topics to subscribe to.
      java.time.Duration getTopicsPatternAutoDiscoveryPeriod()
      Gets the topics auto discovery period when using a topic pattern.
      org.apache.pulsar.client.api.RegexSubscriptionMode getTopicsPatternSubscriptionMode()
      Gets the type of topics to subscribe to when using a topic pattern - Persistent, Non-Persistent, or both.
    • Method Detail

      • getTopicNames

        java.util.List<java.lang.String> getTopicNames()
        Gets the topics to subscribe to.
        Returns:
        the topic names
        See Also:
        ConsumerBuilder.topics(java.util.List<java.lang.String>)
      • getTopicsPattern

        java.util.regex.Pattern getTopicsPattern()
        Gets the topics pattern of the topics to subscribe to.
        Returns:
        the topics pattern
        See Also:
        ConsumerBuilder.topicsPattern(Pattern)
      • getTopicsPatternSubscriptionMode

        org.apache.pulsar.client.api.RegexSubscriptionMode getTopicsPatternSubscriptionMode()
        Gets the type of topics to subscribe to when using a topic pattern - Persistent, Non-Persistent, or both.
        Returns:
        the pattern subscription mode
        See Also:
        ConsumerBuilder.subscriptionTopicsMode(org.apache.pulsar.client.api.RegexSubscriptionMode)
      • getTopicsPatternAutoDiscoveryPeriod

        java.time.Duration getTopicsPatternAutoDiscoveryPeriod()
        Gets the topics auto discovery period when using a topic pattern.
        Returns:
        the topics discovery period
        See Also:
        ConsumerBuilder.patternAutoDiscoveryPeriod(int)
      • getSubscriptionName

        java.lang.String getSubscriptionName()
        Gets the subscription name.
        Returns:
        the name of the subscription
        See Also:
        ConsumerBuilder.subscriptionName(java.lang.String)
      • getSubscriptionMode

        org.apache.pulsar.client.api.SubscriptionMode getSubscriptionMode()
        Gets the subscription mode.
        Returns:
        the subscription mode
        See Also:
        ConsumerBuilder.subscriptionMode(org.apache.pulsar.client.api.SubscriptionMode)
      • getSubscriptionType

        org.apache.pulsar.client.api.SubscriptionType getSubscriptionType()
        Gets the subscription type.
        Returns:
        the subscription type
        See Also:
        ConsumerBuilder.subscriptionType(org.apache.pulsar.client.api.SubscriptionType)
      • getSubscriptionInitialPosition

        org.apache.pulsar.client.api.SubscriptionInitialPosition getSubscriptionInitialPosition()
        Gets the subscription initial position.
        Returns:
        the position where to initialize a newly created subscription
        See Also:
        ConsumerBuilder.subscriptionInitialPosition(org.apache.pulsar.client.api.SubscriptionInitialPosition)
      • getKeySharedPolicy

        org.apache.pulsar.client.api.KeySharedPolicy getKeySharedPolicy()
        Gets the policy used for SubscriptionType.Key_Shared subscriptions.
        Returns:
        the key-shared policy
        See Also:
        ConsumerBuilder.keySharedPolicy(org.apache.pulsar.client.api.KeySharedPolicy)
      • getReplicateSubscriptionState

        java.lang.Boolean getReplicateSubscriptionState()
        Gets whether the subscription shall be replicated.
        Returns:
        true if the subscription is replicated
        See Also:
        ConsumerBuilder.replicateSubscriptionState(boolean)
      • getSubscriptionProperties

        java.util.Map<java.lang.String,​java.lang.String> getSubscriptionProperties()
        Gets the properties for the subscription.
        Returns:
        the subscription properties
        See Also:
        ConsumerBuilder.subscriptionProperties(java.util.Map<java.lang.String, java.lang.String>)
      • getConsumerName

        java.lang.String getConsumerName()
        Gets the consumer name.
        Returns:
        the consumer name
        See Also:
        ConsumerBuilder.consumerName(java.lang.String)
      • getProperties

        java.util.Map<java.lang.String,​java.lang.String> getProperties()
        Gets the consumer properties.
        Returns:
        the consumer properties
        See Also:
        ConsumerBuilder.properties(java.util.Map<java.lang.String, java.lang.String>)
      • getPriorityLevel

        java.lang.Integer getPriorityLevel()
        Gets the priority level for the consumer to which a broker gives more priority while dispatching messages.
        Returns:
        the priority level of the consumer
        See Also:
        ConsumerBuilder.priorityLevel(int)
      • getReadCompacted

        java.lang.Boolean getReadCompacted()
        Gets whether to read messages from the compacted topic rather than reading the full message backlog of the topic.
        Returns:
        true if messages are read from the compacted topic
        See Also:
        ConsumerBuilder.readCompacted(boolean)
      • getBatchIndexAckEnabled

        java.lang.Boolean getBatchIndexAckEnabled()
        Gets whether batch index acknowledgement is enabled.
        Returns:
        true if batch index acknowledgement is enabled
        See Also:
        ConsumerBuilder.enableBatchIndexAcknowledgment(boolean)
      • getAckTimeout

        java.time.Duration getAckTimeout()
        Gets the timeout duration for unacknowledged messages.
        Returns:
        the timeout duration for unacknowledged messages
        See Also:
        ConsumerBuilder.ackTimeout(long, java.util.concurrent.TimeUnit)
      • getAckTimeoutTickTime

        java.time.Duration getAckTimeoutTickTime()
        Gets the tick time of the ack-timeout redelivery.
        Returns:
        the tick time of the ack-timeout redelivery
        See Also:
        ConsumerBuilder.ackTimeoutTickTime(long, java.util.concurrent.TimeUnit)
      • getAcknowledgementsGroupTime

        java.time.Duration getAcknowledgementsGroupTime()
        Gets the duration used to group acknowledgements.
        Returns:
        the duration used to group acknowledgements
        See Also:
        ConsumerBuilder.acknowledgmentGroupTime(long, java.util.concurrent.TimeUnit)
      • getAcknowledgeAsynchronously

        java.lang.Boolean getAcknowledgeAsynchronously()
        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.
        Returns:
        true if the acknowledge operation completion is ignored
      • getAcknowledgeScheduler

        reactor.core.scheduler.Scheduler getAcknowledgeScheduler()
        Gets the scheduler to use to handle acknowledgements.
        Returns:
        the scheduler to use to handle acknowledgements
      • getNegativeAckRedeliveryDelay

        java.time.Duration getNegativeAckRedeliveryDelay()
        Gets the delay to wait before re-delivering messages that have failed to be processed.
        Returns:
        the redelivery delay for failed messages
        See Also:
        ConsumerBuilder.negativeAckRedeliveryDelay(long, java.util.concurrent.TimeUnit)
      • getDeadLetterPolicy

        org.apache.pulsar.client.api.DeadLetterPolicy getDeadLetterPolicy()
        Gets the dead letter policy for the consumer.
        Returns:
        the dead letter policy
        See Also:
        ConsumerBuilder.deadLetterPolicy(org.apache.pulsar.client.api.DeadLetterPolicy)
      • getRetryLetterTopicEnable

        java.lang.Boolean getRetryLetterTopicEnable()
        Gets whether the retries are enabled.
        Returns:
        true if retries are enabled
        See Also:
        ConsumerBuilder.enableRetry(boolean)
      • getReceiverQueueSize

        java.lang.Integer getReceiverQueueSize()
        Gets the size of the consumer receive queue.
        Returns:
        the size of the consumer receive queue
        See Also:
        ConsumerBuilder.receiverQueueSize(int)
      • getMaxTotalReceiverQueueSizeAcrossPartitions

        java.lang.Integer getMaxTotalReceiverQueueSizeAcrossPartitions()
        Gets the max total receiver queue size across partitions.
        Returns:
        the max total receiver queue size across partitions
        See Also:
        ConsumerBuilder.maxTotalReceiverQueueSizeAcrossPartitions(int)
      • getAutoUpdatePartitions

        java.lang.Boolean getAutoUpdatePartitions()
        Gets whether the consumer shall subscribe automatically to new partitions of partitioned topics.
        Returns:
        true if the consumer subscribes automatically to new partitions
        See Also:
        ConsumerBuilder.autoUpdatePartitions(boolean)
      • getAutoUpdatePartitionsInterval

        java.time.Duration getAutoUpdatePartitionsInterval()
        Gets the interval of updating partitions when autoUpdatePartitions is enabled.
        Returns:
        the interval between partitions updates
        See Also:
        ConsumerBuilder.autoUpdatePartitionsInterval(int, java.util.concurrent.TimeUnit), ConsumerBuilder.autoUpdatePartitions(boolean)
      • getCryptoKeyReader

        org.apache.pulsar.client.api.CryptoKeyReader getCryptoKeyReader()
        Gets the key reader to be used to decrypt the message payloads.
        Returns:
        the key reader to be used to decrypt the message payloads
        See Also:
        ConsumerBuilder.cryptoKeyReader(org.apache.pulsar.client.api.CryptoKeyReader)
      • getCryptoFailureAction

        org.apache.pulsar.client.api.ConsumerCryptoFailureAction getCryptoFailureAction()
        Gets the action the consumer will take in case of decryption failures.
        Returns:
        the action the consumer will take in case of decryption failures
        See Also:
        ConsumerBuilder.cryptoFailureAction(org.apache.pulsar.client.api.ConsumerCryptoFailureAction)
      • getMaxPendingChunkedMessage

        java.lang.Integer getMaxPendingChunkedMessage()
        Gets the maximum number of messages in the queue holding pending chunked messages.
        Returns:
        the maximum number of messages in the queue holding pending chunked
        See Also:
        messages.
      • getAutoAckOldestChunkedMessageOnQueueFull

        java.lang.Boolean getAutoAckOldestChunkedMessageOnQueueFull()
        Gets whether to automatically acknowledge pending chunked messages when maxPendingChunkedMessage is reached.
        Returns:
        true to acknowledge the messages, false to have them redelivered.
        See Also:
        ConsumerBuilder.autoAckOldestChunkedMessageOnQueueFull(boolean), ConsumerBuilder.maxPendingChunkedMessage(int)
      • getExpireTimeOfIncompleteChunkedMessage

        java.time.Duration getExpireTimeOfIncompleteChunkedMessage()
        Gets the time interval to expire incomplete chunks if a consumer fails to receive all the chunks.
        Returns:
        the time interval to expire incomplete chunks.
        See Also:
        ConsumerBuilder.expireTimeOfIncompleteChunkedMessage(long, java.util.concurrent.TimeUnit)