Class SubscriptionStatsImpl

java.lang.Object
org.apache.pulsar.common.policies.data.stats.SubscriptionStatsImpl
All Implemented Interfaces:
SubscriptionStats
Direct Known Subclasses:
NonPersistentSubscriptionStatsImpl

public class SubscriptionStatsImpl extends Object implements SubscriptionStats
Statistics about subscription.
  • Field Details

    • msgRateOut

      public double msgRateOut
      Total rate of messages delivered on this subscription (msg/s).
    • msgThroughputOut

      public double msgThroughputOut
      Total throughput delivered on this subscription (bytes/s).
    • bytesOutCounter

      public long bytesOutCounter
      Total bytes delivered to consumer (bytes).
    • msgOutCounter

      public long msgOutCounter
      Total messages delivered to consumer (msg).
    • msgRateRedeliver

      public double msgRateRedeliver
      Total rate of messages redelivered on this subscription (msg/s).
    • messageAckRate

      public double messageAckRate
      Total rate of message ack(msg/s).
    • chunkedMessageRate

      public int chunkedMessageRate
      Chunked message dispatch rate.
    • msgBacklog

      public long msgBacklog
      Number of entries in the subscription backlog.
    • backlogSize

      public long backlogSize
      Size of backlog in byte, -1 means that the argument "subscriptionBacklogSize" is false when calling the API.
    • earliestMsgPublishTimeInBacklog

      public long earliestMsgPublishTimeInBacklog
      Get the publish time of the earliest message in the backlog.
    • msgBacklogNoDelayed

      public long msgBacklogNoDelayed
      Number of entries in the subscription backlog that do not contain the delay messages.
    • blockedSubscriptionOnUnackedMsgs

      public boolean blockedSubscriptionOnUnackedMsgs
      Flag to verify if subscription is blocked due to reaching threshold of unacked messages.
    • msgDelayed

      public long msgDelayed
      Number of delayed messages currently being tracked.
    • unackedMessages

      public long unackedMessages
      Number of unacknowledged messages for the subscription, where an unacknowledged message is one that has been sent to a consumer but not yet acknowledged. Calculated by summing all ConsumerStatsImpl.unackedMessages for this subscription. See ConsumerStatsImpl.unackedMessages for additional details.
    • type

      public String type
      The subscription type as defined by SubscriptionType.
    • activeConsumerName

      public String activeConsumerName
      The name of the consumer that is active for single active consumer subscriptions i.e. failover or exclusive.
    • msgRateExpired

      public double msgRateExpired
      Total rate of messages expired on this subscription (msg/s).
    • totalMsgExpired

      public long totalMsgExpired
      Total messages expired on this subscription.
    • lastExpireTimestamp

      public long lastExpireTimestamp
      Last message expire execution timestamp.
    • lastConsumedFlowTimestamp

      public long lastConsumedFlowTimestamp
      Last received consume flow command timestamp.
    • lastConsumedTimestamp

      public long lastConsumedTimestamp
      Last consume message timestamp.
    • lastAckedTimestamp

      public long lastAckedTimestamp
      Last acked message timestamp.
    • lastMarkDeleteAdvancedTimestamp

      public long lastMarkDeleteAdvancedTimestamp
      Last MarkDelete position advanced timestamp.
    • consumers

      public List<ConsumerStatsImpl> consumers
      List of connected consumers on this subscription w/ their stats.
    • isDurable

      public boolean isDurable
      Tells whether this subscription is durable or ephemeral (eg.: from a reader).
    • isReplicated

      public boolean isReplicated
      Mark that the subscription state is kept in sync across different regions.
    • allowOutOfOrderDelivery

      public boolean allowOutOfOrderDelivery
      Whether out of order delivery is allowed on the Key_Shared subscription.
    • keySharedMode

      public String keySharedMode
      Whether the Key_Shared subscription mode is AUTO_SPLIT or STICKY.
    • consumersAfterMarkDeletePosition

      public Map<String,String> consumersAfterMarkDeletePosition
      This is for Key_Shared subscription to get the recentJoinedConsumers in the Key_Shared subscription.
    • nonContiguousDeletedMessagesRanges

      public int nonContiguousDeletedMessagesRanges
      The number of non-contiguous deleted messages ranges.
    • nonContiguousDeletedMessagesRangesSerializedSize

      public int nonContiguousDeletedMessagesRangesSerializedSize
      The serialized size of non-contiguous deleted messages ranges.
    • delayedMessageIndexSizeInBytes

      public long delayedMessageIndexSizeInBytes
      The size of DelayedDeliveryTracer memory usage.
    • bucketDelayedIndexStats

      public Map<String,TopicMetricBean> bucketDelayedIndexStats
    • subscriptionProperties

      public Map<String,String> subscriptionProperties
      SubscriptionProperties (key/value strings) associated with this subscribe.
    • filterProcessedMsgCount

      public long filterProcessedMsgCount
    • filterAcceptedMsgCount

      public long filterAcceptedMsgCount
    • filterRejectedMsgCount

      public long filterRejectedMsgCount
    • filterRescheduledMsgCount

      public long filterRescheduledMsgCount
  • Constructor Details

    • SubscriptionStatsImpl

      public SubscriptionStatsImpl()
  • Method Details