Class TopicStatsImpl

  • All Implemented Interfaces:
    org.apache.pulsar.common.policies.data.TopicStats
    Direct Known Subclasses:
    NonPersistentTopicStatsImpl, PartitionedTopicStatsImpl

    public class TopicStatsImpl
    extends java.lang.Object
    implements org.apache.pulsar.common.policies.data.TopicStats
    Statistics for a Pulsar topic.
    • Constructor Summary

      Constructors 
      Constructor Description
      TopicStatsImpl()  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      TopicStatsImpl add​(org.apache.pulsar.common.policies.data.TopicStats ts)  
      java.util.List<? extends org.apache.pulsar.common.policies.data.PublisherStats> getPublishers()  
      java.util.Map<java.lang.String,​? extends org.apache.pulsar.common.policies.data.ReplicatorStats> getReplication()  
      java.util.Map<java.lang.String,​? extends org.apache.pulsar.common.policies.data.SubscriptionStats> getSubscriptions()  
      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.TopicStats

        getAverageMsgSize, getBacklogSize, getBytesInCounter, getBytesOutCounter, getCompaction, getDeduplicationStatus, getMsgInCounter, getMsgOutCounter, getMsgRateIn, getMsgRateOut, getMsgThroughputIn, getMsgThroughputOut, getNonContiguousDeletedMessagesRanges, getNonContiguousDeletedMessagesRangesSerializedSize, getOffloadedStorageSize, getStorageSize, getTopicEpoch, getWaitingPublishers, isMsgChunkPublished
    • Field Detail

      • msgRateIn

        public double msgRateIn
        Total rate of messages published on the topic (msg/s).
      • msgThroughputIn

        public double msgThroughputIn
        Total throughput of messages published on the topic (byte/s).
      • msgRateOut

        public double msgRateOut
        Total rate of messages dispatched for the topic (msg/s).
      • msgThroughputOut

        public double msgThroughputOut
        Total throughput of messages dispatched for the topic (byte/s).
      • bytesInCounter

        public long bytesInCounter
        Total bytes published to the topic (bytes).
      • msgInCounter

        public long msgInCounter
        Total messages published to the topic (msg).
      • bytesOutCounter

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

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

        public double averageMsgSize
        Average size of published messages (bytes).
      • msgChunkPublished

        public boolean msgChunkPublished
        Topic has chunked message published on it.
      • storageSize

        public long storageSize
        Space used to store the messages for the topic (bytes).
      • backlogSize

        public long backlogSize
        Get estimated total unconsumed or backlog size in bytes.
      • offloadedStorageSize

        public long offloadedStorageSize
        Space used to store the offloaded messages for the topic/.
      • lastOffloadLedgerId

        public long lastOffloadLedgerId
        record last successful offloaded ledgerId. If no offload ledger, the value should be 0
      • lastOffloadSuccessTimeStamp

        public long lastOffloadSuccessTimeStamp
        record last successful offloaded timestamp. If no successful offload, the value should be 0
      • lastOffloadFailureTimeStamp

        public long lastOffloadFailureTimeStamp
        record last failed offloaded timestamp. If no failed offload, the value should be 0
      • publishers

        public java.util.List<PublisherStatsImpl> publishers
        List of connected publishers on this topic w/ their stats.
      • waitingPublishers

        public int waitingPublishers
      • subscriptions

        public java.util.Map<java.lang.String,​SubscriptionStatsImpl> subscriptions
        Map of subscriptions with their individual statistics.
      • replication

        public java.util.Map<java.lang.String,​ReplicatorStatsImpl> replication
        Map of replication statistics by remote cluster context.
      • deduplicationStatus

        public java.lang.String deduplicationStatus
      • topicEpoch

        public java.lang.Long topicEpoch
        The topic epoch or empty if not set.
      • 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

      • TopicStatsImpl

        public TopicStatsImpl()
    • Method Detail

      • getPublishers

        public java.util.List<? extends org.apache.pulsar.common.policies.data.PublisherStats> getPublishers()
        Specified by:
        getPublishers in interface org.apache.pulsar.common.policies.data.TopicStats
      • getSubscriptions

        public java.util.Map<java.lang.String,​? extends org.apache.pulsar.common.policies.data.SubscriptionStats> getSubscriptions()
        Specified by:
        getSubscriptions in interface org.apache.pulsar.common.policies.data.TopicStats
      • getReplication

        public java.util.Map<java.lang.String,​? extends org.apache.pulsar.common.policies.data.ReplicatorStats> getReplication()
        Specified by:
        getReplication in interface org.apache.pulsar.common.policies.data.TopicStats
      • reset

        public void reset()
      • add

        public TopicStatsImpl add​(org.apache.pulsar.common.policies.data.TopicStats ts)