TeamEnterprise
Metrics glossary
Metric Name | Type | Scope | Description |
---|---|---|---|
acl_count | gauge | cluster | The number of ACLs in the Kafka cluster |
broker_bytes_disk | gauge | cluster | The written disk size in bytes of a broker |
broker_bytes_total | gauge | cluster | The total disk size in bytes of a broker |
broker_bytes_usable | gauge | cluster | The usable disk size in bytes of a broker |
broker_count | gauge | cluster | The number of brokers in the Kafka cluster |
broker_dir_bytes_disk | gauge | cluster | The written disk size in bytes of a broker directory |
broker_dir_bytes_total | gauge | cluster | The total disk size in bytes of a broker directory |
broker_dir_bytes_usable | gauge | cluster | The usable disk size in bytes of a broker directory |
broker_end_delta | histogram | cluster | The total delta of end offsets of a broker (produced msgs/s) |
broker_offset_delta | histogram | cluster | The total delta of all assignment offsets reading from a broker (consumed msgs/s) |
broker_offset_lag | histogram | cluster | The total lag of all assignments reading from a broker |
broker_start_delta | histogram | cluster | The total delta of start offsets of a broker (deleted msgs/s) |
broker_urp | gauge | cluster | The total number of under replicated topic partitions belonging to this broker. |
ccloud_active_connections | gauge | cluster | The number of active connections as reported by the Confluent Cloud metrics API. |
cluster_controller | gauge | cluster | The ID of the broker that is acting as the controller |
cluster_leader_preferred_percentage | gauge | cluster | The 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_progress | gauge | cluster | The number of topic partition reassignments currently in-progress on the cluster. |
cluster_uniform_replication_factor_percentage | gauge | cluster | The percentage of topics that have a uniform replication factor. |
group_assignment_count | gauge | cluster | The number of topic partition assignments in the consumer group. |
group_consumption_inactive_mins | gauge | cluster | The number of minutes a group has seen no reads since it was first observed. |
group_count | gauge | cluster | The number of consumer groups in the Kafka cluster |
group_host_count | gauge | cluster | The number of distinct hosts in the consumer group. |
group_member_count | gauge | cluster | The number of member assignments in the consumer group. |
group_offset_delta | histogram | cluster | The total delta of offsets of a group (consumed msgs/s) |
group_offset_delta_total | meter | cluster | The total group offset delta for all consumer groups in the Kafka cluster (consumed msgs/s) |
group_offset_lag | histogram | cluster | The total lag of all assignments of a group |
group_offset_lag_total | meter | cluster | The total lag of all consumer groups in the Kafka cluster |
group_state | gauge | cluster | The state of the consumer group, where the value is the ordinal of org.apache.kafka.common.ConsumerGroupState |
group_topic_consumption_inactive_mins | gauge | cluster | The number of minutes a group has seen no reads to the topic since it was first observed. |
host_offset_delta | histogram | cluster | The total delta of all group member offsets served by a host (consumed msgs/s) |
host_offset_lag | histogram | cluster | The total lag of all group members served by a host |
kraft_high_watermark | gauge | cluster | The high watermark of the metadata log in the KRaft cluster, indicating the highest committed offset. |
kraft_leader_epoch | gauge | cluster | The current leader epoch in the KRaft cluster, incremented each time a new leader is elected. |
kraft_leader_id | gauge | cluster | The broker ID of the current leader in the KRaft cluster responsible for handling metadata operations. |
kraft_observer_count | gauge | cluster | The number of observer replicas in the KRaft cluster. Observers replicate the metadata log but do not participate in leader election. |
kraft_replicas_count | gauge | cluster | The total number of replicas (voters + observers) in the KRaft cluster responsible for maintaining the metadata log. |
kraft_voter_count | gauge | cluster | The number of voting replicas in the KRaft cluster. Voters participate in leader election and maintain the metadata log. |
simple_broker_offset_delta | histogram | cluster | The total delta of all simple consumer assignment offsets reading from a broker (consumed msgs/s) |
simple_broker_offset_lag | histogram | cluster | The total lag of all simple consumer assignments reading from a broker |
simple_group_offset_delta_total | meter | cluster | The total group offset delta for all simple consumer groups in the Kafka cluster (consumed msgs/s) |
simple_group_offset_lag_total | meter | cluster | The total lag of all simple consumer groups in the Kafka cluster |
simple_topic_consumption_inactive_mins | gauge | cluster | The number of minutes a topic has seen no reads by a simple consumer since it was first observed. |
simple_topic_offset_delta | histogram | cluster | The total delta of all simple consumer assignment offsets reading from a topic (consumed msgs/s) |
simple_topic_offset_lag | histogram | cluster | The total lag of all simple consumer assignments reading from a topic |
topic_bytes_disk | gauge | cluster | The disk size in bytes of a topic |
topic_bytes_disk_total | meter | cluster | The total disk size in bytes of all topics in the Kafka cluster |
topic_consumption_inactive_mins | gauge | cluster | The number of minutes a topic has seen no reads since it was first observed. |
topic_count | gauge | cluster | The number of topics in the Kafka cluster |
topic_end_delta | histogram | cluster | The total delta of end offsets of a topic (produced msgs/s) |
topic_end_delta_total | meter | cluster | The total delta of end offsets of all topics in the Kafka cluster (produced msgs/s) |
topic_inactive_mins | gauge | cluster | The number of minutes a topic has seen no reads or writes since it was first observed. |
topic_leader_preferred_percentage | gauge | cluster | The 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_total | meter | cluster | The total number of topic partitions where the leader is not preferred in the Kafka cluster. |
topic_offset_delta | histogram | cluster | The total delta of all assignment offsets reading from a topic (consumed msgs/s) |
topic_offset_lag | histogram | cluster | The total lag of all assignments reading from a topic |
topic_production_inactive_mins | gauge | cluster | The number of minutes a topic has seen no writes since it was first observed. |
topic_start_delta | histogram | cluster | The total delta of start offsets of a topic (deleted msgs/s) |
topic_urp | gauge | cluster | The total number of under replicated partitions belonging to this topic. |
topic_urp_total | meter | cluster | The total number of under replicated partitions of all topics in the Kafka cluster. |
connect_connector_failed_total | gauge | connect | The aggregate number of failed connectors |
connect_connector_paused_total | gauge | connect | The aggregate number of paused connectors |
connect_connector_running_total | gauge | connect | The aggregate number of running connectors |
connect_connector_state | gauge | connect | The state of the connector |
connect_connector_task_failed_total | gauge | connect | The total number of failed tasks a connector has |
connect_connector_task_paused_total | gauge | connect | The total number of paused tasks a connector has |
connect_connector_task_running_total | gauge | connect | The total number of running tasks a connector has |
connect_connector_task_state | gauge | connect | The state of the connector's task |
connect_connector_task_total | gauge | connect | The total number of tasks a connector has |
connect_connector_task_unassigned_total | gauge | connect | The total number of unassigned tasks a connector has |
connect_connector_total | gauge | connect | The total number of connectors |
connect_connector_unassigned_total | gauge | connect | The aggregate number of unassigned connectors |
connect_connector_unreachable_total | gauge | connect | The number of connectors that Kpow failed to query for |
connect_task_failed_total | gauge | connect | The aggregate number of connector tasks failed |
connect_task_paused_total | gauge | connect | The aggregate number of connector tasks paused |
connect_task_running_total | gauge | connect | The aggregate number of connector tasks running |
connect_task_total | gauge | connect | The total number of connector tasks |
connect_task_unassigned_total | gauge | connect | The aggregate number of connector tasks unassigned |
msk_connect_connector_creating_total | gauge | connect | The aggregate number of MSK connectors getting created |
msk_connect_connector_deleting_total | gauge | connect | The aggregate number of MSK connectors getting deleted |
msk_connect_connector_failed_total | gauge | connect | The aggregate number of failed MSK connectors |
msk_connect_connector_running_total | gauge | connect | The aggregate number of running MSK connectors |
msk_connect_connector_state | gauge | connect | The state of the MSK connector |
msk_connect_connector_total | gauge | connect | The total number of MSK connectors |
msk_connect_connector_unreachable_total | gauge | connect | The number of MSK connectors that Kpow failed to query for |
msk_connect_connector_updating_total | gauge | connect | The aggregate number of MSK connectors getting updated |
capture_ccloud_disk | timer | factorhouse | A timer that measures the duration of capturing Confluent Cloud disk metrics. |
capture_ccloud_telemetry | timer | factorhouse | A timer that measures the duration of capturing Confluent Cloud telemetry data. |
capture_connect_telemetry | timer | factorhouse | A timer that measures the duration of capturing Kafka Connect cluster telemetry. |
capture_flink_telemetry | timer | factorhouse | A timer that measures the duration of Flink telemetry collection. |
capture_kafka_configuration | timer | factorhouse | A timer that measures the duration of capturing Kafka broker and topic configuration. |
capture_kafka_serdes | timer | factorhouse | A timer that measures the duration of discovering and capturing Kafka topic SerDes information. |
capture_kafka_telemetry | timer | factorhouse | A timer that measures the duration of capturing core Kafka cluster telemetry. |
capture_ksqldb_telemetry | timer | factorhouse | A timer that measures the duration of capturing ksqlDB cluster telemetry. |
capture_schema_telemetry | timer | factorhouse | A timer that measures the duration of capturing Schema Registry telemetry. |
error_capture_kafka_configuration | meter | factorhouse | A meter marked when there was an error capturing Kafka configuration telemetry |
error_capture_kafka_serdes | meter | factorhouse | A meter marked when there was an error capturing Kafka topic SerDes telemetry |
error_capture_kafka_telemetry | meter | factorhouse | A meter marked when there was an error capturing Kafka telemetry |
error_compute_snapshot | meter | factorhouse | A meter marked when there was an error computing internal snapshots |
execute_kafka_acl-config | timer | factorhouse | A timer that measures the duration of executing an ACL configuration request to the Kafka cluster. |
execute_kafka_broker | timer | factorhouse | A timer that measures the duration of executing a request for broker information from the Kafka cluster. |
execute_kafka_broker-config | timer | factorhouse | A timer that measures the duration of executing a broker configuration request to the Kafka cluster. |
execute_kafka_cluster | timer | factorhouse | A timer that measures the duration of executing a request for general cluster information from Kafka. |
execute_kafka_group | timer | factorhouse | A timer that measures the duration of executing a request for consumer group information. |
execute_kafka_group-offset | timer | factorhouse | A timer that measures the duration of executing a consumer group offset request to the Kafka cluster. |
execute_kafka_replica | timer | factorhouse | A timer that measures the duration of executing a request for replica information from the Kafka cluster. |
execute_kafka_schema | timer | factorhouse | A timer that measures the duration of executing a request to the Schema Registry. |
execute_kafka_subject | timer | factorhouse | A timer that measures the duration of executing a request for a subject from the Schema Registry. |
execute_kafka_topic-config | timer | factorhouse | A timer that measures the duration of executing a topic configuration request to the Kafka cluster. |
execute_kafka_topic-offset | timer | factorhouse | A timer that measures the duration of executing a topic offset request to the Kafka cluster. |
inspect_topic | timer | factorhouse | A timer that measures the duration of a topic data inspection (kJQ) operation. |
jetty_ws_connections | gauge | factorhouse | The number of active WebSocket connections to Kpow. |
jvm_memory_heap_committed | gauge | factorhouse | The amount of heap memory in bytes that is guaranteed to be available for use by the JVM. |
jvm_memory_heap_max | gauge | factorhouse | The maximum amount of heap memory in bytes that can be used for memory management. |
jvm_memory_heap_used | gauge | factorhouse | The current amount of heap memory in bytes that is used. |
jvm_memory_non-heap_committed | gauge | factorhouse | The amount of non-heap memory in bytes that is guaranteed to be available for use by the JVM. |
jvm_memory_non-heap_max | gauge | factorhouse | The maximum amount of non-heap memory in bytes that can be used for memory management. |
jvm_memory_non-heap_used | gauge | factorhouse | The current amount of non-heap memory in bytes that is used. |
ksqldb_pull-query | timer | factorhouse | A timer that measures the duration of executing a pull query against a ksqlDB materialized table. |
produce_topic | timer | factorhouse | A timer that measures the duration of producing a message to a Kafka topic. |
prometheus_export | timer | factorhouse | A timer for the duration of exporting metrics to Prometheus. |
prometheus_fetch | timer | factorhouse | A timer that measures the duration of fetching data to be used in Prometheus metrics. |
prometheus_generate | timer | factorhouse | A timer that measures the duration of generating the complete Prometheus metrics payload. |
query_metrics | timer | factorhouse | A timer that measures the duration of an internal query for Kpow metrics. |
query_snapshots | timer | factorhouse | A timer that measures the duration of an internal query for Kpow snapshots. |
ksqldb_queries_count | gauge | ksqldb | The number of queries (persistent and push) in ksql. |
ksqldb_sources_count | gauge | ksqldb | The number of sources (streams and tables) in the ksqldb. |
ksqldb_streams_count | gauge | ksqldb | The number of streams in ksqldb. |
ksqldb_tables_count | gauge | ksqldb | The number of tables in ksqldb. |
group_assignment_delta | gauge | offset | The change in the consumer group offset for this topic partition over time (measured in consumed messages per second). |
group_assignment_first_observed | gauge | offset | The timestamp of when the consumer group was first observed reading from this topic partition. |
group_assignment_last_read | gauge | offset | The timestamp of when the consumer group was last observed reading from this topic partition. |
group_assignment_offset | gauge | offset | The latest observed offset position of the consumer group for this topic partition. |
partition_end | gauge | offset | The end offset of a topic partition |
partition_start | gauge | offset | The start offset of a topic partition |
topic_end_sum | gauge | offset | The sum of all partition end offsets of a topic |
registry_subject_count | gauge | schema | The number of subjects in the schema registry |
streams_client_state | gauge | streams | The state of the streams instance, where the value is the ordinal of org.apache.kafka.streams.KafkaStreams.State |
streams_data_points | gauge | streams | The number of collected data points (metrics) Kpow has collected for this KafkaStreams application. |
streams_state | gauge | streams | The aggregated streams state of the group, where the value is the ordinal of org.apache.kafka.streams.KafkaStreams.State |