Confluent Cloud (Kafka) extension

  • Latest Dynatrace
  • Extension
  • Published Oct 27, 2025

Remotely monitor your Confluent Cloud Kafka Clusters and other resources.

1 of 5

Get started

Monitor your Confluent Cloud Kafka Clusters, Connectors, Schema Registries, and KSQL DB Applications. Every minute, ingest the data on your Confluent Resources performance via the Confluent-provided API.

Overview

Use cases

  • This extension provides monitoring of Confluent Cloud Resources via Confluent-provided API. For more information, see Details.
  • Monitor the health state and performance of their Confluent Cloud Resources.
  • Support analytics for for Ops, IT and Network Admins.
  • Monitor infrastructure with a comprehensive dashboard.
  • Detect usage anomalies and alert on them.

Requirements

  • Confluent Cloud Resource(s).
  • Cloud/Cluster API Key and Secret. See Authentication.
  • The metrics in the Kafka Lag Partition Metrics and Kafka Lag Consumer Group Metrics feature sets are not provided by the Confluent API. To obtain these metrics, you need Kafka Lag Exporter. The exporter isn't supported by Dynatrace and needs to be set up and run independently from this extension. Currently, it's the only exprter supported by this extension.

Activation and setup

  1. Find the extension in Dynatrace Hub and add it to your environment.

  2. Create a new monitoring configuration. For more information, see Manage Prometheus extensions

    In the Dynatrace monitoring configuration, the Confluent Cloud API Key and API Secret are used as the Basic Auth User (API Key) /Password (API secret) combination.

Authentication

First you will need to create either a Cloud/Cluster API Key and Secret. This can be done via the Confluent UI or via their CLI. The MetricsViewer role is required to access the Confluent API. It is suggested to use the Organization scope for this role so it can be used as clusters are created or destroyed.

Extension endpoint

The endpoint for the extension is the a URL with your resource types and IDs at the end, similar to what is shown below. This URL supports multiple resources but we recommend to have between 5 and 10 per URL.

https://api.telemetry.confluent.cloud/v2/metrics/cloud/export?resource.kafka.id=lkc-XXXXX&resource.connector.id=lcc-XXXX1&resource.connector.id=lcc-XXXX2

Base URL https://api.telemetry.confluent.cloud/v2/metrics/cloud/export?

  1. Confluent Kafka Cluster

    • resource.kafka.id=lkc-XXXXX
  2. Confluent Kafka Schema Registry

    • resource.schema_registry.id=lsrc=XXXXX
  3. Confluent Kafka Connector

    • resource.connector.id=lcc-XXXXX
  4. Confluent Kafka KSQL DB Application

    • resource.ksql.id=lksqlc-XXXXX
  5. Confluent Kafka Compute Pool

    • resource.compute_pool.id=lfcp-XXXXX

Details

This extension uses the Confluent Metric Export API to gather metrics.

This API has a fixed 5 minute offset for which the extension currently does not account for. This leads to metrics being out of sync by 5 minutes between Dynatrace and Confluent. For more information see the Timestamp offset in the Confluent Metric Export API documentation.

Feature sets

When activating your extension using monitoring configuration, you can limit monitoring to one of the feature sets. To work properly the extension has to collect at least one metric after the activation.

In highly segmented networks, feature sets can reflect the segments of your environment. Then, when you create a monitoring configuration, you can select a feature set and a corresponding ActiveGate group that can connect to this particular segment.

All metrics that aren't categorized into any feature set are considered to be the default and are always reported.

A metric inherits the feature set of a subgroup, which in turn inherits the feature set of a group. Also, the feature set defined on the metric level overrides the feature set defined on the subgroup level, which in turn overrides the feature set defined on the group level.

Metric nameMetric keyDescription
Kafka Connect Sent Recordsconfluent_kafka_connect_sent_recordsThe delta count of total number of records sent from the transformations and written to Kafka for the source connector. Each sample is the number of records sent since the previous data point.
Kafka Connect Received Recordsconfluent_kafka_connect_received_recordsThe delta count of total number of records received by the sink connector. Each sample is the number of records received since the previous data point.
Kafka Connect Sent Bytesconfluent_kafka_connect_sent_bytesThe delta count of total bytes sent from the transformations and written to Kafka for the source connector. Each sample is the number of bytes sent since the previous data point.
Kafka Connect Received Bytesconfluent_kafka_connect_received_bytesThe delta count of total bytes received by the sink connector. Each sample is the number of bytes received since the previous data point.
Kafka Connect Dead Letter Queue Recordsconfluent_kafka_connect_dead_letter_queue_recordsThe delta count of dead letter queue records written to Kafka for the sink connector.
Metric nameMetric keyDescription
Kafka Consumer Group Group Topic Sum Lagkafka_consumergroup_group_topic_sum_lagSum of group offset lag across topic partitions
Kafka Consumer Group Poll Time (ms)kafka_consumergroup_poll_time_msGroup poll time
Kafka Consumer Group Group Offsetkafka_consumergroup_group_offsetLast group consumed offset of a partition
Kafka Consumer Group Group Sum Lagkafka_consumergroup_group_sum_lagSum of group offset lag
Kafka Consumer Group Group Lagkafka_consumergroup_group_lagGroup offset lag of a partition
Kafka Consumer Group Group Lag Secondskafka_consumergroup_group_lag_secondsGroup time lag of a partition
Kafka Consumer Group Group Max Lagkafka_consumergroup_group_max_lagMax group offset lag
Kafka Consumer Group Group Max Lag Secondskafka_consumergroup_group_max_lag_secondsMax group time lag
Metric nameMetric keyDescription
Kafka Server Cluster Link Destination Response Bytesconfluent_kafka_server_cluster_link_destination_response_bytesThe delta count of cluster linking response bytes from all request types. Each sample is the number of bytes sent since the previous data point. The count is sampled every 60 seconds.
Kafka Server Cluster Link Source Response Bytesconfluent_kafka_server_cluster_link_source_response_bytesThe delta count of cluster linking source response bytes from all request types. Each sample is the number of bytes sent since the previous data point. The count is sampled every 60 seconds.
Kafka Server Cluster Link Countconfluent_kafka_server_cluster_link_count.gaugeThe current count of cluster links. The count is sampled every 60 seconds. The implicit time aggregation for this metric is MAX.
Kafka Server Cluster Link Mirror Topic Countconfluent_kafka_server_cluster_link_mirror_topic_count.gaugeThe cluster linking mirror topic count for a link. The count is sampled every 60 seconds.
Kafka Server Cluster Link Mirror Topic Offset Lagconfluent_kafka_server_cluster_link_mirror_topic_offset_lagThe cluster linking mirror topic offset lag maximum across all partitions. The lag is sampled every 60 seconds.
Kafka Server Cluster Link Mirror Topic Bytesconfluent_kafka_server_cluster_link_mirror_topic_bytesThe delta count of cluster linking mirror topic bytes. The count is sampled every 60 seconds.
Metric nameMetric keyDescription
Kafka Cluster Request Bytesconfluent_kafka_server_request_bytesThe delta count of total request bytes from the specified request types sent over the network. Each sample is the number of bytes sent since the previous data point. The count is sampled every 60 seconds.
Kafka Cluster Response Bytesconfluent_kafka_server_response_bytesThe delta count of total response bytes from the specified response types sent over the network. Each sample is the number of bytes sent since the previous data point. The count is sampled every 60 seconds.
Kafka Cluster Active Connection Countconfluent_kafka_server_active_connection_count.gaugeThe count of active authenticated connections.
Kafka Cluster Request Countconfluent_kafka_server_request_count.gaugeThe number of requests received over the network.
Kafka Cluster Successful Authentication Countconfluent_kafka_server_successful_authentication_count.gaugeThe number of successful authentications.
Metric nameMetric keyDescription
Kafka Cluster Received Bytesconfluent_kafka_server_received_bytesThe number of bytes of the customer's data received from the network.
Kafka Cluster Sent Bytesconfluent_kafka_server_sent_bytesThe number of bytes of the customer's data sent over the network.
Kafka Cluster Received Recordsconfluent_kafka_server_received_recordsThe number of records received.
Kafka Cluster Sent Recordsconfluent_kafka_server_sent_recordsThe number of records sent.
Kafka Cluster Retained Bytesconfluent_kafka_server_retained_bytesThe current number of bytes retained by the cluster.
Kafka Cluster Partition Countconfluent_kafka_server_partition_count.gaugeThe number of partitions.
Kafka Cluster Load Rawconfluent_kafka_server_cluster_load_percentA measure of the utilization of the cluster. The value is between 0.0 and 1.0.
Metric nameMetric keyDescription
Confluent Flink Num Records Inconfluent_flink_num_records_inTotal number of records this statement has received.
Confluent Flink Num Records Outconfluent_flink_num_records_outTotal number of records this task statement emitted.
Confluent Flink Pending Recordsconfluent_flink_pending_recordsTotal amount of available records after the consumer offset in a Kafka partition across all operators
Confluent Flink Current Input Watermark Millisecondsconfluent_flink_current_input_watermark_millisecondsThe last watermark this statement has received (in milliseconds) for the given table.
Confluent Flink Current Output Watermark Millisecondsconfluent_flink_current_output_watermark_millisecondsThe last watermark this statement has produced (in milliseconds) to the given table.
Metric nameMetric keyDescription
Confluent Flink Compute Pool Utilization Current CFUsconfluent_flink_compute_pool_utilization_current_cfusThe absolute number of CFUs at a given moment
Confluent Flink Compute Pool Utilization CFU Minutes Consumedconfluent_flink_compute_pool_utilization_cfu_minutes_consumedThe number of how many CFUs consumed since the last measurement
Confluent Flink Compute Pool Utilization CFU Limitconfluent_flink_compute_pool_utilization_cfu_limitThe possible max number of CFUs for the pool
Metric nameMetric keyDescription
Kafka Server Consumer Lag Offsetsconfluent_kafka_server_consumer_lag_offsetsThe lag between a group member's committed offset and the partition's high watermark
Metric nameMetric keyDescription
Confluent Flink Statement Statusconfluent_flink_statement_statusThis metric monitors the status of a statement within the system. Its value is always set to 1, signifying the statement's presence. The statement's current operational state is identified through the metric.status tag.
Metric nameMetric keyDescription
Kafka Partition Earliest Offsetkafka_partition_earliest_offsetEarliest offset of a partition
Kafka Partition Latest Offsetkafka_partition_latest_offsetLatest offset of a partition
Metric nameMetric keyDescription
Kafka Ksql Streaming Unit Countconfluent_kafka_ksql_streaming_unit_count.gaugeThe count of Confluent Streaming Units (CSUs) for this KSQL instance. The implicit time aggregation for this metric is MAX.
Kafka Ksql Query Saturationconfluent_kafka_ksql_query_saturationThe maximum saturation for a given ksqlDB query across all nodes. Returns a value between 0 and 1, a value close to 1 indicates that ksqlDB query processing is bottlenecked on available resources.
Kafka Ksql Task Stored Bytesconfluent_kafka_ksql_task_stored_bytesThe size of a given task's state stores in bytes.
Kafka Ksql Storage Utilizationconfluent_kafka_ksql_storage_utilizationThe total storage utilization for a given ksqlDB application.
Metric nameMetric keyDescription
Kafka Schema Registry Schema Countconfluent_kafka_schema_registry_schema_count.gaugeThe number of registered schemas.
Kafka Schema Registry Request Countconfluent_kafka_schema_registry_request_count.gaugeThe delta count of requests received by the schema registry server. Each sample is the number of requests received since the previous data point. The count sampled every 60 seconds.
Related tags
ApplicationPrometheusStreaming platformConfluentApplication Observability