Class TopicStatsImpl

java.lang.Object
org.apache.pulsar.common.policies.data.stats.TopicStatsImpl
All Implemented Interfaces:
TopicStats
Direct Known Subclasses:
NonPersistentTopicStatsImpl, PartitionedTopicStatsImpl

public class TopicStatsImpl extends Object implements TopicStats
Statistics for a Pulsar topic. This class is not thread-safe.
  • Field Details

    • 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.
    • publishRateLimitedTimes

      public long publishRateLimitedTimes
      The number of times the publishing rate limit was triggered.
    • earliestMsgPublishTimeInBacklogs

      public long earliestMsgPublishTimeInBacklogs
      Get the publish time of the earliest message over all the backlogs.
    • 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
    • ongoingTxnCount

      public long ongoingTxnCount
    • abortedTxnCount

      public long abortedTxnCount
    • committedTxnCount

      public long committedTxnCount
    • waitingPublishers

      public int waitingPublishers
    • subscriptions

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

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

      public String deduplicationStatus
    • topicEpoch

      public 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.
    • delayedMessageIndexSizeInBytes

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

      public Map<String,TopicMetricBean> bucketDelayedIndexStats
      Map of bucket delayed index statistics.
    • compaction

      public CompactionStatsImpl compaction
      The compaction stats.
    • ownerBroker

      public String ownerBroker
      The broker that owns this topic.
  • Constructor Details

    • TopicStatsImpl

      public TopicStatsImpl()
  • Method Details