Class ConsumerStatsImpl

java.lang.Object
org.apache.pulsar.common.policies.data.stats.ConsumerStatsImpl
All Implemented Interfaces:
ConsumerStats

public class ConsumerStatsImpl extends Object implements ConsumerStats
Consumer statistics.
  • Field Details

    • msgRateOut

      public double msgRateOut
      Total rate of messages delivered to the consumer (msg/s).
    • msgThroughputOut

      public double msgThroughputOut
      Total throughput delivered to the consumer (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 by this consumer (msg/s).
    • messageAckRate

      public double messageAckRate
      Total rate of message ack (msg/s).
    • chunkedMessageRate

      public double chunkedMessageRate
      The total rate of chunked messages delivered to this consumer.
    • consumerName

      public String consumerName
      Name of the consumer.
    • availablePermits

      public int availablePermits
      Number of available message permits for the consumer.
    • unackedMessages

      public int unackedMessages
      Number of unacknowledged messages for the consumer, where an unacknowledged message is one that has been sent to the consumer but not yet acknowledged. This field is only meaningful when using a SubscriptionType that tracks individual message acknowledgement, like SubscriptionType.Shared or SubscriptionType.Key_Shared.
    • avgMessagesPerEntry

      public int avgMessagesPerEntry
      Number of average messages per entry for the consumer consumed.
    • blockedConsumerOnUnackedMsgs

      public boolean blockedConsumerOnUnackedMsgs
      Flag to verify if consumer is blocked due to reaching threshold of unacked messages.
    • readPositionWhenJoining

      public String readPositionWhenJoining
      The read position of the cursor when the consumer joining.
    • lastAckedTimestamp

      @Deprecated public long lastAckedTimestamp
      Deprecated.
    • lastConsumedTimestamp

      @Deprecated public long lastConsumedTimestamp
      Deprecated.
    • lastConsumedFlowTimestamp

      public long lastConsumedFlowTimestamp
    • keyHashRanges

      public List<String> keyHashRanges
      Hash ranges assigned to this consumer if is Key_Shared sub mode.
    • metadata

      public Map<String,String> metadata
      Metadata (key/value strings) associated with this consumer.
  • Constructor Details

    • ConsumerStatsImpl

      public ConsumerStatsImpl()
  • Method Details