Redpanda extension

  • Latest Dynatrace
  • Extension
  • Published Oct 27, 2025

Monitor Prometheus metrics exposed by Redpanda platform.

Get started

Overview

Monitor the health and performance of your Redpanda clusters through their exposed Prometheus endpoints.

Use cases

  • Get insights about the performance across your Redpanda architecture, from the cluster to the partition level.
  • Ensure the resources of your Redpanda infrastructure are sufficient to handle peaks in load.
  • Identify bottlenecks by measuring critical metrics such as consumer lag and latencies.

Requirements

To capture consumer group metrics, enable them in your Redpanda configuration.

Compatibility information

  • Dynatrace version: 1.310 or higher
  • ActiveGate version: 1.310 or higher
  • Prometheus enabled in your Redpanda instance

Activation and setup

Activate the extension in your environment using the in-product Hub, provide the necessary device configuration, and you're all set up. For more details, see Manage Prometheus extensions.

Details

The extension package contains:

  • Prometheus Data Source configuration
  • Overview dashboard (classic & latest)
  • Custom topology types extracted from metric dimensions:
    • Redpanda namespace
    • Redpanda topic
    • Redpanda partition

Licensing and cost

Calculations are based on the assumption that you monitor all metrics for every feature set every minute. The inclusion of histogram-type metrics may cause differences in the actual result:

DDUs: (20 + (4* Nº Storage shards) + (4 * Nº Servers) + (5 * Nº Consumer groups) + Nº Namespaces * (3 * Nº Topics/namespace) * (2 * Nº Partitions/topic)) * 525.6 DDUs/year, per Redpanda instance

DPS (Metric data points): (20 + (4* Nº Storage shards) + (4 * Nº Servers) + (5 * Nº Consumer groups) + Nº Namespaces * (3 * Nº Topics/namespace) * (2 * Nº Partitions/topic)) * 525,600 metric data points/year, per Redpanda instance

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.

REST Proxy metrics
Metric nameMetric keyDescription
Redpanda rest_proxy request errorsredpanda.rest_proxy.request_errors_total.countTotal number of rest_proxy server errors
Redpanda REST proxy request latencyredpanda.rest_proxy.request_latency_secondsInternal latency of request for REST proxy (Histogram of observed events)
Infrastructure metrics
Metric nameMetric keyDescription
Redpanda storage free bytesredpanda.storage.freeDisk storage bytes free
Redpanda storage total bytesredpanda.storage.totalTotal size of attached storage, in bytes
Redpanda storage space alertredpanda.storage.alertStatus of low storage space alert. 0-OK, 1-Low Space 2-Degraded
Redpanda total CPU busy time in secondsredpanda.cpu.busy.countTotal time (in seconds) the CPU has been actively processing tasks
Redpanda allocated memory sizeredpanda.memory.allocatedAllocated memory size in bytes
Redpanda available memory sizeredpanda.memory.availableTotal shard memory potentially available in bytes (free_memory plus reclaimable)
Redpanda RPC active connectionsredpanda.rpc.active_connectionsCount of currently active connections
Redpanda RPC latencyredpanda.rpc.request_latency_secondsLatency (in seconds) for RPC requests (Histogram of observed events)
Redpanda I/O queue read operationsredpanda.io_queue.read_ops.countCount of read operations processed by the I/O queue
Redpanda I/O queue write operationsredpanda.io_queue.write_ops.countCount of write operations processed by the I/O queue.
Consumer group metrics
Metric nameMetric keyDescription
Redpanda Kafka consumer group commited offsetredpanda.kafka_consumer_group.committed_offsetConsumer group committed offset.
Redpanda Kafka consumer group max lagredpanda.kafka_consumer_group.lag.maxMaximum lag observed among all partitions for a consumer group
Redpanda Kafka consumer group aggregated lagredpanda.kafka_consumer_group.lag.sumAggregated lag across all partitions for a consumer group
Redpanda Kafka consumer group consumersredpanda.kafka_consumer_group.consumersNumber of consumers per consumer group
Redpanda Kafka consumer group topicsredpanda.kafka_consumer_group.topicsNumber of topics per consumer group
Broker metrics
Metric nameMetric keyDescription
Redpanda Kafka request latencyredpanda.kafka_broker.request_latency_secondsLatency of produce/consume requests per broker (Histogram of observed events)
Cluster metrics
Metric nameMetric keyDescription
Redpanda cluster brokersredpanda.cluster.brokersNumber of configured brokers in the cluster (that is, the size of the cluster)
Redpanda cluster partitionsredpanda.cluster.partitionsNumber of partitions managed by the cluster. This includes partitions of the controller topic, but not replicas.
Redpanda cluster topicsredpanda.cluster.topicsNumber of topics in the cluster
Redpanda cluster unavailable partitionsredpanda.cluster.unavailable_partitionsNumber of partitions that lack quorum among replicants
Partition metrics
Metric nameMetric keyDescription
Redpanda Kafka max offsetredpanda.kafka_partition.max_offsetLatest committed offset for the partition (that is, the offset of the last message safely persisted on most replicas).
Redpanda Kafka under replicated replicasredpanda.kafka_partition.under_replicated_replicasNumber of under-replicated replicas for the partition (that is, replicas that are live but are not at the latest offset.)
Topic metrics
Metric nameMetric keyDescription
Redpanda Kafka replicasredpanda.kafka_topic.replicasNumber of configured replicas per topic
Redpanda Kafka request bytes totalredpanda.kafka_topic.request_bytes_total.countTotal number of bytes produced or consumed per topic.
Redpanda Kafka leadership transfersredpanda.kafka_topic.raft_leadership_changes.countNumber of won leader elections across all partitions in given topic
Application metrics
Metric nameMetric keyDescription
Redpanda application buildredpanda.application.buildRedpanda build information
Redpanda application uptimeredpanda.application.uptimeRedpanda uptime in seconds
Related tags
ApplicationPrometheusMessage queueRedpandaApplication ObservabilityMessage QueuesMessage Queues