Interface TopicStats
- All Known Subinterfaces:
- NonPersistentPartitionedTopicStats,- NonPersistentTopicStats,- PartitionedTopicStats
public interface TopicStats
Statistics for a Pulsar topic.
- 
Method SummaryModifier and TypeMethodDescriptiondoubleAverage size of published messages (bytes).longGet estimated total unconsumed or backlog size in bytes.longTotal bytes published to the topic (bytes).longTotal bytes delivered to consumer (bytes).The compaction stats.longGet the publish time of the earliest message over all the backlogs.longTotal messages published to the topic (msg).longTotal messages delivered to consumer (msg).doubleTotal rate of messages published on the topic (msg/s).doubleTotal rate of messages dispatched for the topic (msg/s).doubleTotal throughput of messages published on the topic (byte/s).doubleTotal throughput of messages dispatched for the topic (byte/s).intThe number of non-contiguous deleted messages ranges.intThe serialized size of non-contiguous deleted messages ranges.longSpace used to store the offloaded messages for the topic/.List<? extends PublisherStats>List of connected publishers on this topic w/ their stats.Map<String,? extends ReplicatorStats> Map of replication statistics by remote cluster context.longSpace used to store the messages for the topic (bytes).Map<String,? extends SubscriptionStats> Map of subscriptions with their individual statistics.The topic epoch or empty if not set.intbooleanTopic has chunked message published on it.
- 
Method Details- 
getMsgRateIndouble getMsgRateIn()Total rate of messages published on the topic (msg/s).
- 
getMsgThroughputIndouble getMsgThroughputIn()Total throughput of messages published on the topic (byte/s).
- 
getMsgRateOutdouble getMsgRateOut()Total rate of messages dispatched for the topic (msg/s).
- 
getMsgThroughputOutdouble getMsgThroughputOut()Total throughput of messages dispatched for the topic (byte/s).
- 
getBytesInCounterlong getBytesInCounter()Total bytes published to the topic (bytes).
- 
getMsgInCounterlong getMsgInCounter()Total messages published to the topic (msg).
- 
getBytesOutCounterlong getBytesOutCounter()Total bytes delivered to consumer (bytes).
- 
getMsgOutCounterlong getMsgOutCounter()Total messages delivered to consumer (msg).
- 
getAverageMsgSizedouble getAverageMsgSize()Average size of published messages (bytes).
- 
isMsgChunkPublishedboolean isMsgChunkPublished()Topic has chunked message published on it.
- 
getStorageSizelong getStorageSize()Space used to store the messages for the topic (bytes).
- 
getBacklogSizelong getBacklogSize()Get estimated total unconsumed or backlog size in bytes.
- 
getEarliestMsgPublishTimeInBacklogslong getEarliestMsgPublishTimeInBacklogs()Get the publish time of the earliest message over all the backlogs.
- 
getOffloadedStorageSizelong getOffloadedStorageSize()Space used to store the offloaded messages for the topic/.
- 
getPublishersList<? extends PublisherStats> getPublishers()List of connected publishers on this topic w/ their stats.
- 
getWaitingPublishersint getWaitingPublishers()
- 
getSubscriptionsMap<String,? extends SubscriptionStats> getSubscriptions()Map of subscriptions with their individual statistics.
- 
getReplicationMap<String,? extends ReplicatorStats> getReplication()Map of replication statistics by remote cluster context.
- 
getDeduplicationStatusString getDeduplicationStatus()
- 
getTopicEpochLong getTopicEpoch()The topic epoch or empty if not set.
- 
getNonContiguousDeletedMessagesRangesint getNonContiguousDeletedMessagesRanges()The number of non-contiguous deleted messages ranges.
- 
getNonContiguousDeletedMessagesRangesSerializedSizeint getNonContiguousDeletedMessagesRangesSerializedSize()The serialized size of non-contiguous deleted messages ranges.
- 
getCompactionCompactionStats getCompaction()The compaction stats.
 
-