Class SubscriptionStatsImpl

  • All Implemented Interfaces:
    org.apache.pulsar.common.policies.data.SubscriptionStats
    Direct Known Subclasses:
    NonPersistentSubscriptionStatsImpl

    public class SubscriptionStatsImpl
    extends java.lang.Object
    implements org.apache.pulsar.common.policies.data.SubscriptionStats
    Statistics about subscription.
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      SubscriptionStatsImpl add​(SubscriptionStatsImpl stats)  
      void reset()  
      • Methods inherited from class java.lang.Object

        clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
      • Methods inherited from interface org.apache.pulsar.common.policies.data.SubscriptionStats

        getActiveConsumerName, getBacklogSize, getBytesOutCounter, getChunkedMessageRate, getConsumers, getConsumersAfterMarkDeletePosition, getKeySharedMode, getLastAckedTimestamp, getLastConsumedFlowTimestamp, getLastConsumedTimestamp, getLastExpireTimestamp, getLastMarkDeleteAdvancedTimestamp, getMsgBacklog, getMsgBacklogNoDelayed, getMsgDelayed, getMsgOutCounter, getMsgRateExpired, getMsgRateOut, getMsgRateRedeliver, getMsgThroughputOut, getNonContiguousDeletedMessagesRanges, getNonContiguousDeletedMessagesRangesSerializedSize, getTotalMsgExpired, getType, getUnackedMessages, isAllowOutOfOrderDelivery, isBlockedSubscriptionOnUnackedMsgs, isDurable, isReplicated
    • Field Detail

      • 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).
      • chunkedMessageRate

        public int chunkedMessageRate
        Chunked message dispatch rate.
      • msgBacklog

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

        public long backlogSize
        Size of backlog in byte.
      • msgBacklogNoDelayed

        public long msgBacklogNoDelayed
        Number of messages 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.
      • type

        public java.lang.String type
        Whether this subscription is Exclusive or Shared or Failover.
      • activeConsumerName

        public java.lang.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 timesetamp.
      • consumers

        public java.util.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 java.lang.String keySharedMode
        Whether the Key_Shared subscription mode is AUTO_SPLIT or STICKY.
      • consumersAfterMarkDeletePosition

        public java.util.Map<java.lang.String,​java.lang.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.
    • Constructor Detail

      • SubscriptionStatsImpl

        public SubscriptionStatsImpl()