You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by da...@apache.org on 2024/04/01 10:50:23 UTC

(pulsar-site) branch main updated: [fix] Fix storageSize*/ offloadedStorageSize* stats descriptions. (#870)

This is an automated email from the ASF dual-hosted git repository.

daojun pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/pulsar-site.git


The following commit(s) were added to refs/heads/main by this push:
     new 34e9c5fd5138 [fix] Fix storageSize*/ offloadedStorageSize* stats descriptions. (#870)
34e9c5fd5138 is described below

commit 34e9c5fd5138a1dd8218cd57da40f89515d2f68a
Author: 道君 <da...@apache.org>
AuthorDate: Mon Apr 1 18:50:17 2024 +0800

    [fix] Fix storageSize*/ offloadedStorageSize* stats descriptions. (#870)
    
    * Fix storageSize*/ offloadedStorageSize* stats descriptions.
    
    * Address comment
---
 docs/administration-stats.md                       |  4 +-
 .../version-2.10.x/administration-stats.md         | 56 +++++++++++-----------
 .../version-2.11.x/administration-stats.md         | 54 ++++++++++-----------
 .../version-3.0.x/administration-stats.md          | 54 ++++++++++-----------
 .../version-3.1.x/administration-stats.md          | 54 ++++++++++-----------
 .../version-3.2.x/administration-stats.md          |  4 +-
 6 files changed, 113 insertions(+), 113 deletions(-)

diff --git a/docs/administration-stats.md b/docs/administration-stats.md
index 27aa699ef1ba..ab701f6bd31a 100644
--- a/docs/administration-stats.md
+++ b/docs/administration-stats.md
@@ -22,8 +22,8 @@ All stats below are **reset** to 0 upon broker restart or topic unloading, **exc
 | msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                                                                                                                                            |
 | msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                                                                                                                                               |
 | averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                                                                                                                                        |
-| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** for a topic (in bytes). <br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.                                                                |
-| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.                                                                      |
+| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** and **in tiered storage** for a topic (in bytes).                                                                                                                                        |
+| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize`, includes `offloadedStorageSize`.                                                              |
 | earliestMsgPublishTimeInBacklogs*                | The publish time of the earliest message in the backlog (in milliseconds).                                                                                                                                                                      |
 | bytesInCounter                                   | The total bytes published to the topic.                                                                                                                                                                                                         |
 | msgInCounter                                     | The total messages published to the topic.                                                                                                                                                                                                      |
diff --git a/versioned_docs/version-2.10.x/administration-stats.md b/versioned_docs/version-2.10.x/administration-stats.md
index d39f05917b0e..c27991b16597 100644
--- a/versioned_docs/version-2.10.x/administration-stats.md
+++ b/versioned_docs/version-2.10.x/administration-stats.md
@@ -13,34 +13,34 @@ All stats below are **reset** to 0 upon broker restart or topic unloading, **exc
 
 ## Partitioned topics
 
-|Stat|Description|
-|---|---|
-|msgRateIn| The sum of publish rates of all local and replication publishers in messages per second.|
-|msgThroughputIn| Same as msgRateIn but in bytes per second instead of messages per second.|
-|msgRateOut| The sum of dispatch rates of all local and replication consumers in messages per second.|
-|msgThroughputOut| Same as msgRateOut but in bytes per second instead of messages per second.|
-|averageMsgSize| Average message size, in bytes, from this publisher within the last interval.|
-| storageSize*                                      | The sum of the ledgers' storage size **in BookKeeper** for a topic (in bytes). <br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.  |
-| offloadedStorageSize*                             | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`. 
-|publishers| The list of all local publishers into the topic. Publishers can be anywhere from zero to thousands.|
-|producerId| Internal identifier for this producer on this topic.|
-|producerName|  Internal identifier for this producer, generated by the client library.|
-|address| IP address and source port for the connection of this producer.|
-|connectedSince| Timestamp this producer is created or last reconnected.|
-|subscriptions| The list of all local subscriptions to the topic.|
-|my-subscription| The name of this subscription (client defined).|
-|msgBacklog| The count of messages in backlog for this subscription.|
-|type| This subscription type.|
-|msgRateExpired| The rate at which messages are discarded instead of dispatched from this subscription due to TTL.|
-|consumers| The list of connected consumers for this subscription.|
-|consumerName| Internal identifier for this consumer, generated by the client library.|
-|availablePermits| The number of messages this consumer has space for in the listen queue of client library. A value of 0 means the queue of client library is full and receive() is not being called. A nonzero value means this consumer is ready to be dispatched messages.|
-|replication| This section gives the stats for cross-colo replication of this topic.|
-|replicationBacklog| The outbound replication backlog in messages.|
-|connected| Whether the outbound replicator is connected.|
-|replicationDelayInSeconds| How long the oldest message has been waiting to be sent through the connection, if connected is true.|
-|inboundConnection| The IP and port of the broker in the publisher connection of remote cluster to this broker. |
-|inboundConnectedSince| The TCP connection being used to publish messages to the remote cluster. If no local publishers are connected, this connection is automatically closed after a minute.|
+| Stat                      | Description                                                                                                                                                                                                                                                 |
+|---------------------------|-------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------|
+| msgRateIn                 | The sum of publish rates of all local and replication publishers in messages per second.                                                                                                                                                                    |
+| msgThroughputIn           | Same as msgRateIn but in bytes per second instead of messages per second.                                                                                                                                                                                   |
+| msgRateOut                | The sum of dispatch rates of all local and replication consumers in messages per second.                                                                                                                                                                    |
+| msgThroughputOut          | Same as msgRateOut but in bytes per second instead of messages per second.                                                                                                                                                                                  |
+| averageMsgSize            | Average message size, in bytes, from this publisher within the last interval.                                                                                                                                                                               |
+| storageSize*              | The sum of the ledgers' storage size **in BookKeeper** and **in tiered storage** for a topic (in bytes).                                                                                                                                                    |
+| offloadedStorageSize*     | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize`, includes `offloadedStorageSize`.                                                                          |
+| publishers                | The list of all local publishers into the topic. Publishers can be anywhere from zero to thousands.                                                                                                                                                         |
+| producerId                | Internal identifier for this producer on this topic.                                                                                                                                                                                                        |
+| producerName              | Internal identifier for this producer, generated by the client library.                                                                                                                                                                                     |
+| address                   | IP address and source port for the connection of this producer.                                                                                                                                                                                             |
+| connectedSince            | Timestamp this producer is created or last reconnected.                                                                                                                                                                                                     |
+| subscriptions             | The list of all local subscriptions to the topic.                                                                                                                                                                                                           |
+| my-subscription           | The name of this subscription (client defined).                                                                                                                                                                                                             |
+| msgBacklog                | The count of messages in backlog for this subscription.                                                                                                                                                                                                     |
+| type                      | This subscription type.                                                                                                                                                                                                                                     |
+| msgRateExpired            | The rate at which messages are discarded instead of dispatched from this subscription due to TTL.                                                                                                                                                           |
+| consumers                 | The list of connected consumers for this subscription.                                                                                                                                                                                                      |
+| consumerName              | Internal identifier for this consumer, generated by the client library.                                                                                                                                                                                     |
+| availablePermits          | The number of messages this consumer has space for in the listen queue of client library. A value of 0 means the queue of client library is full and receive() is not being called. A nonzero value means this consumer is ready to be dispatched messages. |
+| replication               | This section gives the stats for cross-colo replication of this topic.                                                                                                                                                                                      |
+| replicationBacklog        | The outbound replication backlog in messages.                                                                                                                                                                                                               |
+| connected                 | Whether the outbound replicator is connected.                                                                                                                                                                                                               |
+| replicationDelayInSeconds | How long the oldest message has been waiting to be sent through the connection, if connected is true.                                                                                                                                                       |
+| inboundConnection         | The IP and port of the broker in the publisher connection of remote cluster to this broker.                                                                                                                                                                 |
+| inboundConnectedSince     | The TCP connection being used to publish messages to the remote cluster. If no local publishers are connected, this connection is automatically closed after a minute.                                                                                      |
 
 
 ## Topics
diff --git a/versioned_docs/version-2.11.x/administration-stats.md b/versioned_docs/version-2.11.x/administration-stats.md
index 2d756f8fa939..a83dbdae5f49 100644
--- a/versioned_docs/version-2.11.x/administration-stats.md
+++ b/versioned_docs/version-2.11.x/administration-stats.md
@@ -14,32 +14,32 @@ All stats below are **reset** to 0 upon broker restart or topic unloading, **exc
 
 :::
 
-| Stat                                             | Description                                                                                                                     |
-|--------------------------------------------------|---------------------------------------------------------------------------------------------------------------------------------|
-| msgRateIn                                        | The sum of all local and replication publishers' publish rates (message per second).                                            |
-| msgThroughputIn                                  | The sum of all local and replication publishers' publish rates (byte per second).                                               |
-| msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                            |
-| msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                               |
-| averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                        |
-| storageSize*                                      | The sum of the ledgers' storage size **in BookKeeper** for a topic (in bytes). <br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.  |
-| offloadedStorageSize*                             | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`. 
-| earliestMsgPublishTimeInBacklogs*                 | The publish time of the earliest message in the backlog (in milliseconds).                               |
-| bytesInCounter                                   | The total bytes published to the topic.                                                                                         |
-| msgInCounter                                     | The total messages published to the topic.                                                                                      |
-| bytesOutCounter                                  | The total bytes delivered to consumers.                                                                                         |
-| msgOutCounter                                    | The total messages delivered to consumers.                                                                                      |
-| msgChunkPublished                                | The topics that have chunked messages published on it.                                                                          |
-| backlogSize*                                      | The estimated total unconsumed or backlog size (in bytes).                                              |
-| waitingPublishers                                | The number of publishers waiting in a queue in exclusive access mode.                                                           |
-| deduplicationStatus                              | The status of message deduplication for the topic.                                                                              |
-| topicEpoch                                       | The topic epoch or empty if not set.                                                                                            |
-| filteredEntriesCount                             | The count of skipped entries for the topic.                                                                                     |
-| nonContiguousDeletedMessagesRanges               | The number of non-contiguous deleted messages ranges.                                                                           |
-| nonContiguousDeletedMessagesRangesSerializedSize | The serialized size of non-contiguous deleted messages ranges.                                                                  |
-| ownerBroker                                      | The broker that owns this topic.                                                                                                |
-| [publishers](#producer-stats)                    | The list of all local publishers on the topic, ranging from zero to thousands.                                                  |
-| [subscriptions](#subscription-stats)             | The list of all local subscriptions to the topic.                                                                               |
-| [replication](#replication-stats)                | This section gives the stats for cross-colo replication of this topic.                                                          |
+| Stat                                             | Description                                                                                                                                                                        |
+|--------------------------------------------------|------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------|
+| msgRateIn                                        | The sum of all local and replication publishers' publish rates (message per second).                                                                                               |
+| msgThroughputIn                                  | The sum of all local and replication publishers' publish rates (byte per second).                                                                                                  |
+| msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                                                                               |
+| msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                                                                                  |
+| averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                                                                           |
+| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** and **in tiered storage** for a topic (in bytes).                                                                           |
+| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize`, includes `offloadedStorageSize`. |
+| earliestMsgPublishTimeInBacklogs*                | The publish time of the earliest message in the backlog (in milliseconds).                                                                                                         |
+| bytesInCounter                                   | The total bytes published to the topic.                                                                                                                                            |
+| msgInCounter                                     | The total messages published to the topic.                                                                                                                                         |
+| bytesOutCounter                                  | The total bytes delivered to consumers.                                                                                                                                            |
+| msgOutCounter                                    | The total messages delivered to consumers.                                                                                                                                         |
+| msgChunkPublished                                | The topics that have chunked messages published on it.                                                                                                                             |
+| backlogSize*                                     | The estimated total unconsumed or backlog size (in bytes).                                                                                                                         |
+| waitingPublishers                                | The number of publishers waiting in a queue in exclusive access mode.                                                                                                              |
+| deduplicationStatus                              | The status of message deduplication for the topic.                                                                                                                                 |
+| topicEpoch                                       | The topic epoch or empty if not set.                                                                                                                                               |
+| filteredEntriesCount                             | The count of skipped entries for the topic.                                                                                                                                        |
+| nonContiguousDeletedMessagesRanges               | The number of non-contiguous deleted messages ranges.                                                                                                                              |
+| nonContiguousDeletedMessagesRangesSerializedSize | The serialized size of non-contiguous deleted messages ranges.                                                                                                                     |
+| ownerBroker                                      | The broker that owns this topic.                                                                                                                                                   |
+| [publishers](#producer-stats)                    | The list of all local publishers on the topic, ranging from zero to thousands.                                                                                                     |
+| [subscriptions](#subscription-stats)             | The list of all local subscriptions to the topic.                                                                                                                                  |
+| [replication](#replication-stats)                | This section gives the stats for cross-colo replication of this topic.                                                                                                             |
 
 ### Producer stats
 
@@ -175,4 +175,4 @@ The following table outlines the internal stats inside a topic. For more details
 | entries                            | The total number of entries that belong to this ledger.                                                                                                                             |
 | size                               | The size of messages written to this ledger (in bytes).                                                                                                                             |
 | offloaded                          | Whether this ledger is offloaded. The value is `false` for the compacted topic ledger.                                                                                              |
-| metadata                           | The ledger metadata.                                                                                                                                                                |
\ No newline at end of file
+| metadata                           | The ledger metadata.                                                                                                                                                                |
diff --git a/versioned_docs/version-3.0.x/administration-stats.md b/versioned_docs/version-3.0.x/administration-stats.md
index 073f3be00f95..fb2515cb0289 100644
--- a/versioned_docs/version-3.0.x/administration-stats.md
+++ b/versioned_docs/version-3.0.x/administration-stats.md
@@ -15,32 +15,32 @@ All stats below are **reset** to 0 upon broker restart or topic unloading, **exc
 :::
 
 
-| Stat                                             | Description                                                                                                                     |
-|--------------------------------------------------|---------------------------------------------------------------------------------------------------------------------------------|
-| msgRateIn                                        | The sum of all local and replication publishers' publish rates (message per second).                                            |
-| msgThroughputIn                                  | The sum of all local and replication publishers' publish rates (byte per second).                                               |
-| msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                            |
-| msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                               |
-| averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                        |
-| storageSize*                                      | The sum of the ledgers' storage size **in BookKeeper** for a topic (in bytes). <br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.  |
-| offloadedStorageSize*                             | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`. 
-| earliestMsgPublishTimeInBacklogs*                 | The publish time of the earliest message in the backlog (in milliseconds).                        |
-| bytesInCounter                                   | The total bytes published to the topic.                                                                                         |
-| msgInCounter                                     | The total messages published to the topic.                                                                                      |
-| bytesOutCounter                                  | The total bytes delivered to consumers.                                                                                         |
-| msgOutCounter                                    | The total messages delivered to consumers.                                                                                      |
-| msgChunkPublished                                | The topics that have chunked messages published on it.                                                                          |
-| backlogSize*                                      | The estimated total unconsumed or backlog size (in bytes).                            |
-| waitingPublishers                                | The number of publishers waiting in a queue in exclusive access mode.                                                           |
-| deduplicationStatus                              | The status of message deduplication for the topic.                                                                              |
-| topicEpoch                                       | The topic epoch or empty if not set.                                                                                            |
-| filteredEntriesCount                             | The count of skipped entries for the topic.                                                                                     |
-| nonContiguousDeletedMessagesRanges               | The number of non-contiguous deleted messages ranges.                                                                           |
-| nonContiguousDeletedMessagesRangesSerializedSize | The serialized size of non-contiguous deleted messages ranges.                                                                  |
-| ownerBroker                                      | The broker that owns this topic.                                                                                                |
-| [publishers](#producer-stats)                    | The list of all local publishers on the topic, ranging from zero to thousands.                                                  |
-| [subscriptions](#subscription-stats)             | The list of all local subscriptions to the topic.                                                                               |
-| [replication](#replication-stats)                | This section gives the stats for cross-colo replication of this topic.                                                          |
+| Stat                                             | Description                                                                                                                                                                        |
+|--------------------------------------------------|------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------|
+| msgRateIn                                        | The sum of all local and replication publishers' publish rates (message per second).                                                                                               |
+| msgThroughputIn                                  | The sum of all local and replication publishers' publish rates (byte per second).                                                                                                  |
+| msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                                                                               |
+| msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                                                                                  |
+| averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                                                                           |
+| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** and **in tiered storage** for a topic (in bytes).                                                                           |
+| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize`, includes `offloadedStorageSize`. |
+| earliestMsgPublishTimeInBacklogs*                | The publish time of the earliest message in the backlog (in milliseconds).                                                                                                         |
+| bytesInCounter                                   | The total bytes published to the topic.                                                                                                                                            |
+| msgInCounter                                     | The total messages published to the topic.                                                                                                                                         |
+| bytesOutCounter                                  | The total bytes delivered to consumers.                                                                                                                                            |
+| msgOutCounter                                    | The total messages delivered to consumers.                                                                                                                                         |
+| msgChunkPublished                                | The topics that have chunked messages published on it.                                                                                                                             |
+| backlogSize*                                     | The estimated total unconsumed or backlog size (in bytes).                                                                                                                         |
+| waitingPublishers                                | The number of publishers waiting in a queue in exclusive access mode.                                                                                                              |
+| deduplicationStatus                              | The status of message deduplication for the topic.                                                                                                                                 |
+| topicEpoch                                       | The topic epoch or empty if not set.                                                                                                                                               |
+| filteredEntriesCount                             | The count of skipped entries for the topic.                                                                                                                                        |
+| nonContiguousDeletedMessagesRanges               | The number of non-contiguous deleted messages ranges.                                                                                                                              |
+| nonContiguousDeletedMessagesRangesSerializedSize | The serialized size of non-contiguous deleted messages ranges.                                                                                                                     |
+| ownerBroker                                      | The broker that owns this topic.                                                                                                                                                   |
+| [publishers](#producer-stats)                    | The list of all local publishers on the topic, ranging from zero to thousands.                                                                                                     |
+| [subscriptions](#subscription-stats)             | The list of all local subscriptions to the topic.                                                                                                                                  |
+| [replication](#replication-stats)                | This section gives the stats for cross-colo replication of this topic.                                                                                                             |
 
 ### Producer stats
 
@@ -175,4 +175,4 @@ The following table outlines the internal stats inside a topic. For more details
 | entries                            | The total number of entries that belong to this ledger.                                                                                                                             |
 | size                               | The size of messages written to this ledger (in bytes).                                                                                                                             |
 | offloaded                          | Whether this ledger is offloaded. The value is `false` for the compacted topic ledger.                                                                                              |
-| metadata                           | The ledger metadata.                                                                                                                                                                |
\ No newline at end of file
+| metadata                           | The ledger metadata.                                                                                                                                                                |
diff --git a/versioned_docs/version-3.1.x/administration-stats.md b/versioned_docs/version-3.1.x/administration-stats.md
index 073f3be00f95..fb2515cb0289 100644
--- a/versioned_docs/version-3.1.x/administration-stats.md
+++ b/versioned_docs/version-3.1.x/administration-stats.md
@@ -15,32 +15,32 @@ All stats below are **reset** to 0 upon broker restart or topic unloading, **exc
 :::
 
 
-| Stat                                             | Description                                                                                                                     |
-|--------------------------------------------------|---------------------------------------------------------------------------------------------------------------------------------|
-| msgRateIn                                        | The sum of all local and replication publishers' publish rates (message per second).                                            |
-| msgThroughputIn                                  | The sum of all local and replication publishers' publish rates (byte per second).                                               |
-| msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                            |
-| msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                               |
-| averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                        |
-| storageSize*                                      | The sum of the ledgers' storage size **in BookKeeper** for a topic (in bytes). <br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.  |
-| offloadedStorageSize*                             | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`. 
-| earliestMsgPublishTimeInBacklogs*                 | The publish time of the earliest message in the backlog (in milliseconds).                        |
-| bytesInCounter                                   | The total bytes published to the topic.                                                                                         |
-| msgInCounter                                     | The total messages published to the topic.                                                                                      |
-| bytesOutCounter                                  | The total bytes delivered to consumers.                                                                                         |
-| msgOutCounter                                    | The total messages delivered to consumers.                                                                                      |
-| msgChunkPublished                                | The topics that have chunked messages published on it.                                                                          |
-| backlogSize*                                      | The estimated total unconsumed or backlog size (in bytes).                            |
-| waitingPublishers                                | The number of publishers waiting in a queue in exclusive access mode.                                                           |
-| deduplicationStatus                              | The status of message deduplication for the topic.                                                                              |
-| topicEpoch                                       | The topic epoch or empty if not set.                                                                                            |
-| filteredEntriesCount                             | The count of skipped entries for the topic.                                                                                     |
-| nonContiguousDeletedMessagesRanges               | The number of non-contiguous deleted messages ranges.                                                                           |
-| nonContiguousDeletedMessagesRangesSerializedSize | The serialized size of non-contiguous deleted messages ranges.                                                                  |
-| ownerBroker                                      | The broker that owns this topic.                                                                                                |
-| [publishers](#producer-stats)                    | The list of all local publishers on the topic, ranging from zero to thousands.                                                  |
-| [subscriptions](#subscription-stats)             | The list of all local subscriptions to the topic.                                                                               |
-| [replication](#replication-stats)                | This section gives the stats for cross-colo replication of this topic.                                                          |
+| Stat                                             | Description                                                                                                                                                                        |
+|--------------------------------------------------|------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------|
+| msgRateIn                                        | The sum of all local and replication publishers' publish rates (message per second).                                                                                               |
+| msgThroughputIn                                  | The sum of all local and replication publishers' publish rates (byte per second).                                                                                                  |
+| msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                                                                               |
+| msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                                                                                  |
+| averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                                                                           |
+| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** and **in tiered storage** for a topic (in bytes).                                                                           |
+| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize`, includes `offloadedStorageSize`. |
+| earliestMsgPublishTimeInBacklogs*                | The publish time of the earliest message in the backlog (in milliseconds).                                                                                                         |
+| bytesInCounter                                   | The total bytes published to the topic.                                                                                                                                            |
+| msgInCounter                                     | The total messages published to the topic.                                                                                                                                         |
+| bytesOutCounter                                  | The total bytes delivered to consumers.                                                                                                                                            |
+| msgOutCounter                                    | The total messages delivered to consumers.                                                                                                                                         |
+| msgChunkPublished                                | The topics that have chunked messages published on it.                                                                                                                             |
+| backlogSize*                                     | The estimated total unconsumed or backlog size (in bytes).                                                                                                                         |
+| waitingPublishers                                | The number of publishers waiting in a queue in exclusive access mode.                                                                                                              |
+| deduplicationStatus                              | The status of message deduplication for the topic.                                                                                                                                 |
+| topicEpoch                                       | The topic epoch or empty if not set.                                                                                                                                               |
+| filteredEntriesCount                             | The count of skipped entries for the topic.                                                                                                                                        |
+| nonContiguousDeletedMessagesRanges               | The number of non-contiguous deleted messages ranges.                                                                                                                              |
+| nonContiguousDeletedMessagesRangesSerializedSize | The serialized size of non-contiguous deleted messages ranges.                                                                                                                     |
+| ownerBroker                                      | The broker that owns this topic.                                                                                                                                                   |
+| [publishers](#producer-stats)                    | The list of all local publishers on the topic, ranging from zero to thousands.                                                                                                     |
+| [subscriptions](#subscription-stats)             | The list of all local subscriptions to the topic.                                                                                                                                  |
+| [replication](#replication-stats)                | This section gives the stats for cross-colo replication of this topic.                                                                                                             |
 
 ### Producer stats
 
@@ -175,4 +175,4 @@ The following table outlines the internal stats inside a topic. For more details
 | entries                            | The total number of entries that belong to this ledger.                                                                                                                             |
 | size                               | The size of messages written to this ledger (in bytes).                                                                                                                             |
 | offloaded                          | Whether this ledger is offloaded. The value is `false` for the compacted topic ledger.                                                                                              |
-| metadata                           | The ledger metadata.                                                                                                                                                                |
\ No newline at end of file
+| metadata                           | The ledger metadata.                                                                                                                                                                |
diff --git a/versioned_docs/version-3.2.x/administration-stats.md b/versioned_docs/version-3.2.x/administration-stats.md
index 27aa699ef1ba..ab701f6bd31a 100644
--- a/versioned_docs/version-3.2.x/administration-stats.md
+++ b/versioned_docs/version-3.2.x/administration-stats.md
@@ -22,8 +22,8 @@ All stats below are **reset** to 0 upon broker restart or topic unloading, **exc
 | msgRateOut                                       | The sum of all local and replication consumers' dispatch rates (message per second).                                                                                                                                                            |
 | msgThroughputOut                                 | The sum of all local and replication consumers' dispatch rates (byte per second).                                                                                                                                                               |
 | averageMsgSize                                   | The average size (bytes) of messages published within the last interval.                                                                                                                                                                        |
-| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** for a topic (in bytes). <br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.                                                                |
-| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize` + `offloadedStorageSize`.                                                                      |
+| storageSize*                                     | The sum of the ledgers' storage size **in BookKeeper** and **in tiered storage** for a topic (in bytes).                                                                                                                                        |
+| offloadedStorageSize*                            | The sum of the storage size **in tiered storage** for a topic (in bytes).<br/><br/>**Note**: the `total storage size of a topic` = `storageSize`, includes `offloadedStorageSize`.                                                              |
 | earliestMsgPublishTimeInBacklogs*                | The publish time of the earliest message in the backlog (in milliseconds).                                                                                                                                                                      |
 | bytesInCounter                                   | The total bytes published to the topic.                                                                                                                                                                                                         |
 | msgInCounter                                     | The total messages published to the topic.                                                                                                                                                                                                      |