Skip to main content
TeamEnterprise

Metrics glossary

Metric NameTypeScopeDescription
acl_countgaugeclusterThe number of ACLs in the Kafka cluster
broker_bytes_diskgaugeclusterThe written disk size in bytes of a broker
broker_bytes_totalgaugeclusterThe total disk size in bytes of a broker
broker_bytes_usablegaugeclusterThe usable disk size in bytes of a broker
broker_countgaugeclusterThe number of brokers in the Kafka cluster
broker_dir_bytes_diskgaugeclusterThe written disk size in bytes of a broker directory
broker_dir_bytes_totalgaugeclusterThe total disk size in bytes of a broker directory
broker_dir_bytes_usablegaugeclusterThe usable disk size in bytes of a broker directory
broker_end_deltahistogramclusterThe total delta of end offsets of a broker (produced msgs/s)
broker_offset_deltahistogramclusterThe total delta of all assignment offsets reading from a broker (consumed msgs/s)
broker_offset_laghistogramclusterThe total lag of all assignments reading from a broker
broker_start_deltahistogramclusterThe total delta of start offsets of a broker (deleted msgs/s)
broker_urpgaugeclusterThe total number of under replicated topic partitions belonging to this broker.
ccloud_active_connectionsgaugeclusterThe number of active connections as reported by the Confluent Cloud metrics API.
cluster_controllergaugeclusterThe ID of the broker that is acting as the controller
cluster_leader_preferred_percentagegaugeclusterThe percentage of topic partitions where the preferred leader (first replica in the list of replicas) is the actual leader in the Kafka cluster.
cluster_reassignments_in_progressgaugeclusterThe number of topic partition reassignments currently in-progress on the cluster.
cluster_uniform_replication_factor_percentagegaugeclusterThe percentage of topics that have a uniform replication factor.
group_assignment_countgaugeclusterThe number of topic partition assignments in the consumer group.
group_consumption_inactive_minsgaugeclusterThe number of minutes a group has seen no reads since it was first observed.
group_countgaugeclusterThe number of consumer groups in the Kafka cluster
group_host_countgaugeclusterThe number of distinct hosts in the consumer group.
group_member_countgaugeclusterThe number of member assignments in the consumer group.
group_offset_deltahistogramclusterThe total delta of offsets of a group (consumed msgs/s)
group_offset_delta_totalmeterclusterThe total group offset delta for all consumer groups in the Kafka cluster (consumed msgs/s)
group_offset_laghistogramclusterThe total lag of all assignments of a group
group_offset_lag_totalmeterclusterThe total lag of all consumer groups in the Kafka cluster
group_stategaugeclusterThe state of the consumer group, where the value is the ordinal of org.apache.kafka.common.ConsumerGroupState
group_topic_consumption_inactive_minsgaugeclusterThe number of minutes a group has seen no reads to the topic since it was first observed.
host_offset_deltahistogramclusterThe total delta of all group member offsets served by a host (consumed msgs/s)
host_offset_laghistogramclusterThe total lag of all group members served by a host
kraft_high_watermarkgaugeclusterThe high watermark of the metadata log in the KRaft cluster, indicating the highest committed offset.
kraft_leader_epochgaugeclusterThe current leader epoch in the KRaft cluster, incremented each time a new leader is elected.
kraft_leader_idgaugeclusterThe broker ID of the current leader in the KRaft cluster responsible for handling metadata operations.
kraft_observer_countgaugeclusterThe number of observer replicas in the KRaft cluster. Observers replicate the metadata log but do not participate in leader election.
kraft_replicas_countgaugeclusterThe total number of replicas (voters + observers) in the KRaft cluster responsible for maintaining the metadata log.
kraft_voter_countgaugeclusterThe number of voting replicas in the KRaft cluster. Voters participate in leader election and maintain the metadata log.
simple_broker_offset_deltahistogramclusterThe total delta of all simple consumer assignment offsets reading from a broker (consumed msgs/s)
simple_broker_offset_laghistogramclusterThe total lag of all simple consumer assignments reading from a broker
simple_group_offset_delta_totalmeterclusterThe total group offset delta for all simple consumer groups in the Kafka cluster (consumed msgs/s)
simple_group_offset_lag_totalmeterclusterThe total lag of all simple consumer groups in the Kafka cluster
simple_topic_consumption_inactive_minsgaugeclusterThe number of minutes a topic has seen no reads by a simple consumer since it was first observed.
simple_topic_offset_deltahistogramclusterThe total delta of all simple consumer assignment offsets reading from a topic (consumed msgs/s)
simple_topic_offset_laghistogramclusterThe total lag of all simple consumer assignments reading from a topic
topic_bytes_diskgaugeclusterThe disk size in bytes of a topic
topic_bytes_disk_totalmeterclusterThe total disk size in bytes of all topics in the Kafka cluster
topic_consumption_inactive_minsgaugeclusterThe number of minutes a topic has seen no reads since it was first observed.
topic_countgaugeclusterThe number of topics in the Kafka cluster
topic_end_deltahistogramclusterThe total delta of end offsets of a topic (produced msgs/s)
topic_end_delta_totalmeterclusterThe total delta of end offsets of all topics in the Kafka cluster (produced msgs/s)
topic_inactive_minsgaugeclusterThe number of minutes a topic has seen no reads or writes since it was first observed.
topic_leader_preferred_percentagegaugeclusterThe percentage of partitions where the preferred leader (first replica in the list of replicas) is the actual leader within the Kafka topic.
topic_non_preferred_leaders_totalmeterclusterThe total number of topic partitions where the leader is not preferred in the Kafka cluster.
topic_offset_deltahistogramclusterThe total delta of all assignment offsets reading from a topic (consumed msgs/s)
topic_offset_laghistogramclusterThe total lag of all assignments reading from a topic
topic_production_inactive_minsgaugeclusterThe number of minutes a topic has seen no writes since it was first observed.
topic_start_deltahistogramclusterThe total delta of start offsets of a topic (deleted msgs/s)
topic_urpgaugeclusterThe total number of under replicated partitions belonging to this topic.
topic_urp_totalmeterclusterThe total number of under replicated partitions of all topics in the Kafka cluster.
connect_connector_failed_totalgaugeconnectThe aggregate number of failed connectors
connect_connector_paused_totalgaugeconnectThe aggregate number of paused connectors
connect_connector_running_totalgaugeconnectThe aggregate number of running connectors
connect_connector_stategaugeconnectThe state of the connector
connect_connector_task_failed_totalgaugeconnectThe total number of failed tasks a connector has
connect_connector_task_paused_totalgaugeconnectThe total number of paused tasks a connector has
connect_connector_task_running_totalgaugeconnectThe total number of running tasks a connector has
connect_connector_task_stategaugeconnectThe state of the connector's task
connect_connector_task_totalgaugeconnectThe total number of tasks a connector has
connect_connector_task_unassigned_totalgaugeconnectThe total number of unassigned tasks a connector has
connect_connector_totalgaugeconnectThe total number of connectors
connect_connector_unassigned_totalgaugeconnectThe aggregate number of unassigned connectors
connect_connector_unreachable_totalgaugeconnectThe number of connectors that Kpow failed to query for
connect_task_failed_totalgaugeconnectThe aggregate number of connector tasks failed
connect_task_paused_totalgaugeconnectThe aggregate number of connector tasks paused
connect_task_running_totalgaugeconnectThe aggregate number of connector tasks running
connect_task_totalgaugeconnectThe total number of connector tasks
connect_task_unassigned_totalgaugeconnectThe aggregate number of connector tasks unassigned
msk_connect_connector_creating_totalgaugeconnectThe aggregate number of MSK connectors getting created
msk_connect_connector_deleting_totalgaugeconnectThe aggregate number of MSK connectors getting deleted
msk_connect_connector_failed_totalgaugeconnectThe aggregate number of failed MSK connectors
msk_connect_connector_running_totalgaugeconnectThe aggregate number of running MSK connectors
msk_connect_connector_stategaugeconnectThe state of the MSK connector
msk_connect_connector_totalgaugeconnectThe total number of MSK connectors
msk_connect_connector_unreachable_totalgaugeconnectThe number of MSK connectors that Kpow failed to query for
msk_connect_connector_updating_totalgaugeconnectThe aggregate number of MSK connectors getting updated
capture_ccloud_disktimerfactorhouseA timer that measures the duration of capturing Confluent Cloud disk metrics.
capture_ccloud_telemetrytimerfactorhouseA timer that measures the duration of capturing Confluent Cloud telemetry data.
capture_connect_telemetrytimerfactorhouseA timer that measures the duration of capturing Kafka Connect cluster telemetry.
capture_flink_telemetrytimerfactorhouseA timer that measures the duration of Flink telemetry collection.
capture_kafka_configurationtimerfactorhouseA timer that measures the duration of capturing Kafka broker and topic configuration.
capture_kafka_serdestimerfactorhouseA timer that measures the duration of discovering and capturing Kafka topic SerDes information.
capture_kafka_telemetrytimerfactorhouseA timer that measures the duration of capturing core Kafka cluster telemetry.
capture_ksqldb_telemetrytimerfactorhouseA timer that measures the duration of capturing ksqlDB cluster telemetry.
capture_schema_telemetrytimerfactorhouseA timer that measures the duration of capturing Schema Registry telemetry.
error_capture_kafka_configurationmeterfactorhouseA meter marked when there was an error capturing Kafka configuration telemetry
error_capture_kafka_serdesmeterfactorhouseA meter marked when there was an error capturing Kafka topic SerDes telemetry
error_capture_kafka_telemetrymeterfactorhouseA meter marked when there was an error capturing Kafka telemetry
error_compute_snapshotmeterfactorhouseA meter marked when there was an error computing internal snapshots
execute_kafka_acl-configtimerfactorhouseA timer that measures the duration of executing an ACL configuration request to the Kafka cluster.
execute_kafka_brokertimerfactorhouseA timer that measures the duration of executing a request for broker information from the Kafka cluster.
execute_kafka_broker-configtimerfactorhouseA timer that measures the duration of executing a broker configuration request to the Kafka cluster.
execute_kafka_clustertimerfactorhouseA timer that measures the duration of executing a request for general cluster information from Kafka.
execute_kafka_grouptimerfactorhouseA timer that measures the duration of executing a request for consumer group information.
execute_kafka_group-offsettimerfactorhouseA timer that measures the duration of executing a consumer group offset request to the Kafka cluster.
execute_kafka_replicatimerfactorhouseA timer that measures the duration of executing a request for replica information from the Kafka cluster.
execute_kafka_schematimerfactorhouseA timer that measures the duration of executing a request to the Schema Registry.
execute_kafka_subjecttimerfactorhouseA timer that measures the duration of executing a request for a subject from the Schema Registry.
execute_kafka_topic-configtimerfactorhouseA timer that measures the duration of executing a topic configuration request to the Kafka cluster.
execute_kafka_topic-offsettimerfactorhouseA timer that measures the duration of executing a topic offset request to the Kafka cluster.
inspect_topictimerfactorhouseA timer that measures the duration of a topic data inspection (kJQ) operation.
jetty_ws_connectionsgaugefactorhouseThe number of active WebSocket connections to Kpow.
jvm_memory_heap_committedgaugefactorhouseThe amount of heap memory in bytes that is guaranteed to be available for use by the JVM.
jvm_memory_heap_maxgaugefactorhouseThe maximum amount of heap memory in bytes that can be used for memory management.
jvm_memory_heap_usedgaugefactorhouseThe current amount of heap memory in bytes that is used.
jvm_memory_non-heap_committedgaugefactorhouseThe amount of non-heap memory in bytes that is guaranteed to be available for use by the JVM.
jvm_memory_non-heap_maxgaugefactorhouseThe maximum amount of non-heap memory in bytes that can be used for memory management.
jvm_memory_non-heap_usedgaugefactorhouseThe current amount of non-heap memory in bytes that is used.
ksqldb_pull-querytimerfactorhouseA timer that measures the duration of executing a pull query against a ksqlDB materialized table.
produce_topictimerfactorhouseA timer that measures the duration of producing a message to a Kafka topic.
prometheus_exporttimerfactorhouseA timer for the duration of exporting metrics to Prometheus.
prometheus_fetchtimerfactorhouseA timer that measures the duration of fetching data to be used in Prometheus metrics.
prometheus_generatetimerfactorhouseA timer that measures the duration of generating the complete Prometheus metrics payload.
query_metricstimerfactorhouseA timer that measures the duration of an internal query for Kpow metrics.
query_snapshotstimerfactorhouseA timer that measures the duration of an internal query for Kpow snapshots.
ksqldb_queries_countgaugeksqldbThe number of queries (persistent and push) in ksql.
ksqldb_sources_countgaugeksqldbThe number of sources (streams and tables) in the ksqldb.
ksqldb_streams_countgaugeksqldbThe number of streams in ksqldb.
ksqldb_tables_countgaugeksqldbThe number of tables in ksqldb.
group_assignment_deltagaugeoffsetThe change in the consumer group offset for this topic partition over time (measured in consumed messages per second).
group_assignment_first_observedgaugeoffsetThe timestamp of when the consumer group was first observed reading from this topic partition.
group_assignment_last_readgaugeoffsetThe timestamp of when the consumer group was last observed reading from this topic partition.
group_assignment_offsetgaugeoffsetThe latest observed offset position of the consumer group for this topic partition.
partition_endgaugeoffsetThe end offset of a topic partition
partition_startgaugeoffsetThe start offset of a topic partition
topic_end_sumgaugeoffsetThe sum of all partition end offsets of a topic
registry_subject_countgaugeschemaThe number of subjects in the schema registry
streams_client_stategaugestreamsThe state of the streams instance, where the value is the ordinal of org.apache.kafka.streams.KafkaStreams.State
streams_data_pointsgaugestreamsThe number of collected data points (metrics) Kpow has collected for this KafkaStreams application.
streams_stategaugestreamsThe aggregated streams state of the group, where the value is the ordinal of org.apache.kafka.streams.KafkaStreams.State