Skip to technology filters Skip to main content
Dynatrace Hub

Extend the platform,
empower your team.

Popular searches:
Home hero bg
Apache KafkaApache Kafka
Apache Kafka

Apache Kafka

Automatic and intelligent observability with trace and metric insights.

Extension
Free trialDocumentation
Get an overview of your Kafka monitoring using New Dashboards, which are bundled with the extension upon activation.Easily navigate your Kafka environment and its most important metrics with the out of the box dashboard, included with the activation of the extension.Dedicated screen for your Kafka broker with all its metrics, along with a navigation card for the rest of your Kafka environment.Dedicated screens also for your Kafka producers, consumers and topics.List all your Kafka topics to get a clear overview of your generated entities, with filtering and ordering for the most relevant metrics.Lists also available for the rest of the generated entities.Producer-level metrics can be viewed in Unified-Analysis screens for your Queues.The OneAgent can monitor end-to-end traces that connect producer and consumer services, monitor the performance of topics and queues, and more.
  • Product information
  • Release notes

Overview

With Dynatrace, you can get observability for Kafka without touching any code, thanks to automatic monitoring. Seamless end-to-end traces for connected producer and consumer clients allow you to diagnose anomalies and pinpoint the root cause of the broken code before your customers are affected. Comprehensive metrics give you insight into your Kafka servers with health and performance metrics for brokers, topics, producers, and consumers. Events point you to critical anomalies, reducing the mean repair time.

Use cases

  • Capture every message across tiers without blind spots.
  • Improve the performance of your producer and consumer services end-to-end.
  • Troubleshoot asynchronous service problems across your stack proactively.
  • Prevent message processing anomalies to reduce the mean time to repair.
  • Monitor the health and performance of all your brokers and topics.
  • Understand your consumer lag.

Compatibility information

Requirements

  • OneAgent version 1.270+
  • Dynatrace version 1.270+
  • OneAgent feature Java Metric Extensions 2.0 (JMX) activated
Dynatrace
Documentation
By Dynatrace
Dynatrace support center
Subscribe to new releases
Copy to clipboard

Extension content

Content typeNumber of items included
screen message cards
8
alerts
4
screen layout
8
list screen layout
4
metric metadata
102
screen chart groups
16
document dashboard
1
screen injections
11
screen actions
8
screen metric tables
4
screen dql table
11
screen entities lists
11
generic relationship
8
dashboards
1
generic type
4
screen properties
3

Feature sets

Below is a complete list of the feature sets provided in this version. To ensure a good fit for your needs, individual feature sets can be activated and deactivated by your administrator during configuration.

Feature setsNumber of metrics included
Metric nameMetric keyDescriptionUnit
Records appended ratekafka.raft.append-records-rateThe average number of records appended per sec by the leader of the raft quorum.Count
Commit latency (avg)kafka.raft.commit-latency-avgThe average time in milliseconds to commit an entry in the raft log.MilliSecond
Commit latency (max)kafka.raft.commit-latency-maxThe maximum time in milliseconds to commit an entry in the raft log.MilliSecond
Record fetch ratekafka.raft.fetch-records-rateThe average number of records fetched from the leader of the raft quorum.Count
Log end epochkafka.raft.log-end-epochThe current raft log end epoch.Count
Log end offsetkafka.raft.log-end-offsetThe current raft log end offset.Count
Current leader IDkafka.raft.current-leaderThe current quorum leader's id; -1 indicates unknown.Count
Metric nameMetric keyDescriptionUnit
Kafka Network - Produce requests per secondkafka.network.RequestMetrics.RequestsPerSec.Produce.OneMinuteRateThe total number of requests made for produce per secondPerSecond
Kafka Network - FetchConsumer requests per secondkafka.network.RequestMetrics.RequestsPerSec.FetchConsumer.OneMinuteRateThe total number of requests made for fetch consumer per secondPerSecond
Kafka Network - FetchFollower requests per secondkafka.network.RequestMetrics.RequestsPerSec.FetchFollower.OneMinuteRateThe total number of requests made for fetch follower per secondPerSecond
Kafka Network - Total time per Produce requestkafka.network.RequestMetrics.TotalTimeMs.Produce.CountTotal time, in milliseconds, spent processing requests, for produce.MilliSecond
Kafka Network - Total time per FetchConsumer requestkafka.network.RequestMetrics.TotalTimeMs.FetchConsumer.CountTotal time, in milliseconds, spent processing requests, for fetch consumer.MilliSecond
Kafka Network - Total time per FetchFollower requestkafka.network.RequestMetrics.TotalTimeMs.FetchFollower.CountTotal time, in milliseconds, spent processing requests, for pfetch follower.MilliSecond
Kafka Network - Request queue sizekafka.network.RequestChannel.RequestQueueSize.ValueSize of the request queue.Count
Kafka Network - Response queue sizekafka.network.RequestChannel.ResponseQueueSize.ValueSize of the response queue.Count
Kafka Network - Network processor average idle percentkafka.network.SocketServer.NetworkProcessorAvgIdlePercentThe average fraction of time the network processor threads are idle.Percent
Metric nameMetric keyDescriptionUnit
Kafka Connector - Statuskafka.connector.statusEquals 1 if the status is running, 0 otherwise.Count
Kafka Connector - Task statuskafka.connector.task.statusEquals 1 if the status is running, 0 otherwise.Count
Kafka Connector - Task pause ratiokafka.connector.task.pause-ratioThe fraction of time this task has spent in the pause state.Count
Kafka Connector - Task running ratiokafka.connector.task.running-ratioThe fraction of time this task has spent in the running state.Count
Kafka Connector - Task success ratiokafka.connector.task.offset-commit-success-percentageThe average percentage of this task's offset commit attempts that succeeded.Percent
Kafka Connector - Task commit time (max)kafka.connector.task.offset-commit-max-time-msThe maximum time in milliseconds taken by this task to commit offsets.MilliSecond
Kafka Connector - Task failure ratiokafka.connector.task.offset-commit-failure-percentageThe maximum time in milliseconds taken by this task to commit offsets.Percent
Kafka Connector - Task commit time (avg)kafka.connector.task.offset-commit-avg-time-msThe average time in milliseconds taken by this task to commit offsets.MilliSecond
Kafka Connector - Task batch size (max)kafka.connector.task.batch-size-maxThe maximum size of the batches processed by the connector.Byte
Kafka Connector - Task batch size (avg)kafka.connector.task.batch-size-avgThe average size of the batches processed by the connector.Byte
Metric nameMetric keyDescriptionUnit
Kafka Server - Handler Pool Idle Percent Ratekafka.server.handler.average-idle-percent.rateThe average fraction of time the request handler threads are idle. Values are between 0 meaning all resources are used and 1 meaning all resources are available.PerSecond
Metric nameMetric keyDescriptionUnit
Kafka Producer - Incoming byte ratekafka.producer.producer-metrics.incoming-byte-rateThe average number of responses received per second for a node.BytePerSecond
Kafka Producer - Outgoing byte ratekafka.producer.producer-metrics.outgoing-byte-rateThe average number of outgoing bytes sent per second to all servers.BytePerSecond
Kafka Producer - I/O Wait timekafka.producer.producer-metrics.io-wait-time-ns-avgThe average length of time the I/O thread spent waiting for a socket ready for reads or writes in nanoseconds.NanoSecond
Kafka Producer - Response ratekafka.producer.producer-metrics.response-rateResponses received sent per second.PerSecond
Kafka Producer - Request latencykafka.producer.producer-metrics.request-latency-avgThe average request latency in ms.MilliSecond
Kafka Producer - Compression ratekafka.producer.producer-metrics.compression-rate-avgThe average compression rate of record batches, defined as the average ratio of the compressed batch size over the uncompressed size.PerSecond
Kafka Producer - Request sizekafka.producer.producer-metrics.request-size-avgThe average size of all requests in the window.Byte
Kafka Producer - Requestskafka.producer.producer-metrics.request-rateThe average number of requests sent per second.PerSecond
Kafka Producer - Byte ratekafka.producer.producer-topic-metrics.byte-rateThe average number of bytes sent per second for a topic.BytePerSecond
Kafka Producer - Compression ratekafka.producer.producer-topic-metrics.compression-rateThe average compression rate of record batches for a topic, defined as the average ratio of the compressed batch size over the uncompressed size.BytePerSecond
Kafka Producer - Failed Requests Ratekafka.producer.producer-topic-metrics.record-error-rateThe average per-second number of record sends that resulted in errors for a topic.PerSecond
Kafka Producer - Requests Sent Ratekafka.producer.producer-topic-metrics.record-send-rateThe average number of records sent per second for a topic.PerSecond
Metric nameMetric keyDescriptionUnit
Kafka Consumer - Requestskafka.consumer.consumer-metrics.request-rateThe average number of requests sent per second for a node.PerSecond
Kafka Consumer - Request sizekafka.consumer.consumer-metrics.request-size-avgThe average size of all requests in the window.Byte
Kafka Consumer - Incoming byte ratekafka.consumer.consumer-metrics.incoming-byte-rateBytes/second read off all sockets.BytePerSecond
Kafka Consumer - Outgoing byte ratekafka.consumer.consumer-metrics.outgoing-byte-rateThe average number of outgoing bytes sent per second to all servers.BytePerSecond
Kafka Consumer - Request latencykafka.consumer.consumer-metrics.request-latency-avgThe average request latency in ms for a node.MilliSecond
Kafka Consumer - Messages consumed ratekafka.consumer.consumer-metrics.records-consumed-rateThe average number of records consumed per second.PerSecond
Kafka Consumer - Bytes consumed ratekafka.consumer.consumer-metrics.bytes-consumed-rateThe average number of bytes consumed per second for a topic.PerSecond
Kafka Consumer - Fetch latencykafka.consumer.consumer-metrics.fetch-latency-avgThe average time taken for a fetch request.MilliSecond
Kafka Consumer - Consumer lagkafka.consumer.consumer-metrics.records-lagThe latest lag of the partition.Count
Kafka Consumer - Consumer lag averagekafka.consumer.consumer-metrics.records-lag-avgThe average lag of the partition.Count
Kafka Consumer - Consumer lag maximumkafka.consumer.consumer-metrics.records-lag-maxThe max lag of the partition.Count
Metric nameMetric keyDescriptionUnit
Active link countkafka.cluster-link.link-countTotal number of links in an active state.Count
Active mirror countkafka.cluster-link.mirror-topic-countTotal number of active (healthy) mirror topics.Count
Cluster link max lagkafka.cluster-link.max-lagMaximum lag in messages between the replicas on the destination cluster and the leader replica on the source cluster.Count
Fetched bytes per secondkafka.cluster-link.bytes-per-sec.countRate at which data is fetched from the source cluster. Indicates amount of throughput in bytes per second on the cluster link.BytePerSecond
Fetched throttle timekafka.cluster-link.fetch-throttle-time-avgGives throttle times for the Cluster Linking fetchers. May indicate increases in lag on the cluster link due to throttling/quotas being enforced.MilliSecond
Active task countkafka.cluster-link.link-task-countMonitor the state of link level tasks.Count
Failed reverse connection countkafka.cluster-link.reverse-connection-failed-totalTotal count of reverse connections that failed for this cluster link. Only available for outbound connections.Count
Authentication problemskafka.cluster-link.authentication-problemsUnavailable links due to authentication.Count
Unavailable link (by reason)kafka.cluster-link.unavailable-link-countUnavailable links due to authentication.Count
Controller reverse connection countkafka.cluster-link.controller-reverse-connection-countNumber of persistent reverse connections for this link between the local broker and the remote link coordinator.Count
Controller reverse connection countkafka.cluster-link.remote-admin-request-timeAdmin request processing time.MilliSecond
Background thread countkafka.cluster-link.background-thread-usageBackground thread active usage.Count
Metric nameMetric keyDescriptionUnit
Kafka Broker - Incoming byte ratekafka.server.BrokerTopicMetrics.BytesInPerSec.OneMinuteRateThe rate at which data sent from producers is consumed by the broker.BytePerSecond
Kafka Broker - Mirror topic bytes in ratekafka.server.BrokerTopicMetrics.MirrorBytesInPerSec.OneMinuteRateThe rate at which mirror bytes are received, by topic.PerSecond
Kafka Broker - Outgoing byte ratekafka.server.BrokerTopicMetrics.BytesOutPerSec.OneMinuteRateThe rate at which data sent from other brokers is consumed by the follower broker.BytePerSecond
Kafka Broker - Messages in ratekafka.server.BrokerTopicMetrics.MessagesInPerSec.OneMinuteRateThe rate at which individual messages are consumed by the broker.PerSecond
Kafka Broker - Follower fetch requests ratekafka.server.BrokerTopicMetrics.TotalFollowerFetchRequestsPerSec.OneMinuteRateThe follower fetch request rate for the broker.PerSecond
Kafka Broker - Produce message conversions ratekafka.server.BrokerTopicMetrics.ProduceMessageConversionsPerSec.OneMinuteRateThe rate at which produce messages are converted, by topic.PerSecond
Kafka Broker - Partitionskafka.server.ReplicaManager.PartitionCountThe number of partitions in the broker.Count
Kafka Broker - Under replicated partitionskafka.server.ReplicaManager.UnderReplicatedPartitionsThe number of partitions that have not been fully replicated in the follower replicas.Count
Kafka Broker - Under minimum in-sync replica partitionskafka.server.ReplicaManager.UnderMinIsrPartitionCountThe number of partitions whose in-sync replicas count is less than minIsr.Count
Kafka Broker - Produce request ratekafka.server.BrokerTopicMetrics.TotalProduceRequestsPerSec.OneMinuteRateThe produce request rate per second.PerSecond
Kafka Broker - Fetch request ratekafka.server.BrokerTopicMetrics.TotalFetchRequestsPerSec.OneMinuteRateThe fetch request rate per second.PerSecond
Kafka Broker - Failed produce requestskafka.server.BrokerTopicMetrics.FailedProduceRequestsPerSec.OneMinuteRateThe produce request rate for requests that failed.PerSecond
Kafka Broker - Failed fetch requestskafka.server.BrokerTopicMetrics.FailedFetchRequestsPerSec.OneMinuteRateThe fetch request rate for requests that failed.PerSecond
Kafka Server - Max follower lagkafka.server.ReplicaFetcherManager.MaxLag.Replica.ValueThe maximum lag between the time that messages are received by the leader replica and by the follower replicas.Count
Kafka Server - Current follower lagkafka.server.FetcherLagMetrics.ConsumerLag.ValueThe lag in number of messages per follower replica.Count
Kafka Server - Fetch Conversions Ratekafka.server.FetchConversionsRate.OneMinuteRate-Count
Kafka Server - Produce Conversions Ratekafka.server.ProduceConversionsRate.OneMinuteRate-Count
Metric nameMetric keyDescriptionUnit
Kafka Controller - Offline partitionskafka.controller.KafkaController.OfflinePartitionsCountThe number of partitions that don't have an active leader and are therefore not writable or readable.Count
Kafka Controller - Active cluster controllerskafka.controller.KafkaController.ActiveControllerCount.ValueIndicates whether the broker is the controller broker.Count
Metric nameMetric keyDescriptionUnit
Kafka Server - Disk Read Ratekafka.server.disk.read-bytesThe total number of bytes read by the broker process, including reads from all disks. The total doesn't include reads from page cache. Available only on Linux-based systems.PerSecond
Kafka Server - Disk Write Ratekafka.server.disk.write-bytesThe total number of bytes written by the broker process, including writes from all disks. Available only on Linux-based systems.PerSecond
Metric nameMetric keyDescriptionUnit
Kafka Log - Log flush 95th percentilekafka.log.LogFlushStats.LogFlushRateAndTimeMs.Percentile95thLog flush rate and time in milliseconds.MilliSecond
Kafka Log - Log flush mean timekafka.log.LogFlushStats.LogFlushRateAndTimeMs.MeanLog flush rate and time in milliseconds.MilliSecond
Metric nameMetric keyDescriptionUnit
Last applied record offsetkafka.raft.last-applied-record-offsetThe offset of the last record from the cluster metadata partition that was applied by the broker.Count
Last applied record timestampkafka.raft.last-applied-record-timestampThe timestamp of the last record from the cluster metadata partition that was applied by the broker.Count
Last applied record lagkafka.raft.last-applied-record-lag-msThe difference between now and the timestamp of the last record from the cluster metadata partition that was applied by the broker.MilliSecond
Metadata load error countkafka.raft.metadata-load-error-countThe number of errors encountered by the BrokerMetadataListener while loading the metadata log and generating a new MetadataDelta based on it.Count
Metadata apply error countkafka.raft.metadata-apply-error-countThe number of errors encountered by the BrokerMetadataPublisher while applying a new MetadataImage based on the latest MetadataDelta.Count
Metric nameMetric keyDescriptionUnit
Kafka Server - Purgatory Produce Sizekafka.server.purgatory.produce-delay-sizeRequests waiting in the produce purgatory.Count
Kafka Server - Purgatory Fetch Sizekafka.server.purgatory.fetch-delay-sizeRequests waiting in the fetch purgatory.Count
Metric nameMetric keyDescriptionUnit
Kafka Controller - Leader election ratekafka.controller.ControllerStats.LeaderElectionRateAndTimeMs.OneMinuteRateThe broker leader election rate and latency in milliseconds. This is non-zero when there are broker failures.MilliSecond
Kafka Controller - Unclean election ratekafka.controller.ControllerStats.UncleanLeaderElectionsPerSec.OneMinuteRateThe unclean broker leader election rate. Should be 0.PerSecond
Kafka Server - Leader countkafka.server.ReplicaManager.LeaderCount.ValueThe number of replicas for which this broker is the leader.Count
Metric nameMetric keyDescriptionUnit
Kafka Connect - Requestskafka.connect.connect-metrics.request-rateThe average number of requests sent per second.PerSecond
Kafka Connect - Outgoing byte ratekafka.connect.connect-metrics.outgoing-byte-rateThe average number of outgoing bytes sent per second to all servers.BytePerSecond
Kafka Connect - Request sizekafka.connect.connect-metrics.request-size-avgThe average size of all requests in the window.Byte
Kafka Connect - Incoming byte ratekafka.connect.connect-metrics.incoming-byte-rateBytes/second read off all sockets.BytePerSecond
Metric nameMetric keyDescriptionUnit
Kafka Server - ZooKeeper disconnectskafka.server.SessionExpireListener.ZooKeeperDisconnectsPerSec.OneMinuteRateA meter that provides the number of recent ZooKeeper client disconnects.PerSecond
Kafka Server - ZooKeeper expireskafka.server.SessionExpireListener.ZooKeeperExpiresPerSec.OneMinuteRateThe number of ZooKeeper sessions that have expired.PerSecond
Kafka Server - Zookeeper Active Connectionskafka.server.active-connectionsThe number of currently open connections to the broker.Count

Full version history

To have more information on how to install the downloaded package, please follow the instructions on this page.
ReleaseDate

Full version history

  • Added 3 new metrics
    • broker-metrics feature set
      • kafka.server.ReplicaManager.UnderMinIsrPartitionCount
    • network-metrics feature set
      • kafka.network.RequestChannel.ResponseQueueSize.Value
      • kafka.network.SocketServer.NetworkProcessorAvgIdlePercent

Full version history

  • Added new broker topic metric Mirror topic bytes in rate
  • Added 24 new Confluent platform only metrics:
    • 12 new cluster linking metrics
      • Active link count
      • Active mirror count
      • Cluster link max lag
      • Fetched bytes per second
      • Fetched throttle time
      • Active task count
      • Failed reverse connection count
      • Authentication problems
      • Unavailable link (by reason)
      • Controller reverse connection count
      • Controller reverse connection count
      • Background thread count
    • 12 new KRaft metrics
      • Records appended rate
      • Commit latency (avg)
      • Commit latency (max)
      • Record fetch rate
      • Log end epoch
      • Log end offset
      • Current leader ID
      • Last applied record offset
      • Last applied record timestamp
      • Last applied record lag
      • Metadata load error count
      • Metadata apply error count

Full version history

Minimum Dynatrace version now 1.313!

Changes

  • Security context attribute on entities
  • New Dashboards app dashboard
  • Platform ready screen definitions

Full version history

Minimum Dynatrace version required has been increased to 1.313

  • Connector status and connector task status metrics now show the proper value of the status dimension.
  • Producers and consumers now show the process name instead of the host name on their own name. If running an older version than 1.319 of the OneAgent, the producer/consumer will still show the host's name instead.

Full version history

  • Added gen3 dashboard

Full version history

  • Added new variable Topic name filter which can be used to filter out the topics that will be monitored.

Full version history

🚀 Improved in this version:

  • [🔴 Breaking change] Refactored entity creation for consumers and producers. The dimension client-id is no longer used to generate these entities but only the process_group_instanceand the host will be considered. This will generate new entity IDs for all your existing consumers and producers, which will break any configuration (metric events, dashboards, etc.) that use those individual IDs. The name of these entities will also change, as it was based on the client-idpreviously.
  • Charts in consumers and producers have been changed to show metrics per client-id, instead of per entity.
  • Added descriptions to all extension metrics

✨ New in this version:

  • Added 8 new metrics related to the Kafka Connector.

🐛 Fixed in this version:

  • As client-id is no longer used for generating consumer and producer entities, we no longer run into the entity dimension limitation that prevented new data from being ingested.

Full version history

  • Broker now uses the hostname instead of the host ID, when available.
  • Entity lists for broker, producer and consumer now show the host and the process they are related to, as well as allowing you to filter by those entities.
  • Removed any reference to zookeeper metrics or entities. To get insight into Zookeeper, activate the recently released standalone extension.

Full version history

  • Changed the name of the out-of-the-box alerts to include the word Kafka in the title for increased accessibility.
  • Added the following metrics under the zookeeper-metrics feature set:
    • kafka.zookeeper.server.maxRequestLatency
    • kafka.zookeeper.server.minRequestLatency
    • kafka.zookeeper.server.avgRequestLatency
    • kafka.zookeeper.server.aliveConnections
    • kafka.zookeeper.server.packetsReceived.count
    • kafka.zookeeper.server.packetsSent.count
    • kafka.zookeeper.server.outstandingRequests
  • Added custom topology for the zookeeper
  • Added UA screens for the zookeeper
  • Modified the out-of-the-box dashboard to include data about the zookeeper

Full version history

  • Added a new metric kafka.consumer.consumer-metrics.records-lag to show latest consumer lag instead of the already available consumer lag average and maximum.
  • Removed the status dimension from the kafka.connector.status and kafka.connector.task.status as the framework is not ready to report such dimensions. The metrics now report 1 when the status is running or 0 otherwise.

Full version history

  • Fixed a bug where consumer-fetch-manager-metrics where not being captured correctly.
  • Added connector task status to metrics.
  • Replace entity lists for Host and Process Group Instance with properties in broker, consumer and producer screens.

Full version history

  • Fixed a bug where metrics for kafka.consumer:type=consumer-fetch-manager-metrics where not being populated:
    • kafka.consumer.consumer-metrics.records-lag-avg
    • kafka.consumer.consumer-metrics.records-lag-max
    • kafka.consumer.consumer-metrics.records-consumed-rate
    • kafka.consumer.consumer-metrics.bytes-consumed-rate
    • kafka.consumer.consumer-metrics.fetch-latency-avg

Full version history

  • Add topic dimension to existing metrics:
    • kafka.server.BrokerTopicMetrics.BytesInPerSec.OneMinuteRate
    • kafka.server.BrokerTopicMetrics.BytesOutPerSec.OneMinuteRate
    • kafka.server.BrokerTopicMetrics.MessagesInPerSec.OneMinuteRate
    • kafka.server.BrokerTopicMetrics.TotalProduceRequestsPerSec.OneMinuteRate
  • Add new metrics:
    • kafka.server.BrokerTopicMetrics.TotalFollowerFetchRequestsPerSec.OneMinuteRate
    • kafka.server.BrokerTopicMetrics.ProduceMessageConversionsPerSec.OneMinuteRate
  • Modified UA screens to include the metrics and dimensions listed above:
    • Kafka Broker screen
    • Kafka Topic screen
    • Host injected tile
    • Process Group Instance injected tile

Full version history

  • Kafka Server - Current follower lag: Fixed typo in metric key, changed from kafka.server.FetcherLagMetrics.CosumerLag.Value to kafka.server.FetcherLagMetrics.ConsumerLag.Value
    • This is a breaking change if you're using this metric in dashboards, metric events or other configurations. You will need to reference the new key.
  • Added connector status metric
  • Added primary entity for most metrics
  • Added navigation card to all screens

Full version history

No release notes

Dynatrace Hub
Get data into DynatraceBuild your own app
All (811)Log Management and AnalyticsKubernetesAI and LLM ObservabilityInfrastructure ObservabilitySoftware DeliveryApplication ObservabilityApplication SecurityDigital ExperienceBusiness Observability
Filter
Type
Built and maintained by
Deployment model
SaaS
  • SaaS
  • Managed
Partner FinderBecome a partnerDynatrace Developer

Discover recent additions to Dynatrace

Problems logo

Problems

Analyze abnormal system behavior and performance problems detected by Davis AI.

Logs logo

Logs

Explore all your logs without writing a single query.

Security Investigator logo

Security Investigator

Fast and precise forensics for security and logs on Grail data with DQL queries.

Business Flow logo

Business Flow

Track, analyze, and optimize your critical business processes.

Cost & Carbon Optimization logo

Cost & Carbon Optimization

Track, analyze, and optimize your IT carbon footprint and public cloud costs.

Davis Anomaly Detection logo

Davis Anomaly Detection

Detect anomalies in timeseries using the Davis AI

Analyze your data

Understand your data better with deep insights and clear visualizations.

Notebooks logo

Notebooks

Create powerful, data-driven documents for custom analytics and collaboration.

Dashboards logo

Dashboards

Transform complex data into clear visualizations with custom dashboards.

Automate your processes

Turn data and answers into actions, securely, and at scale.

Workflows logo

Workflows

Automate tasks in your IT landscape, remediate problems, and visualize processes

Jira logo

Jira

Create, query, comment, transition, and resolve Jira tickets within workflows.

Slack logo

Slack

Automate Slack messaging for security incidents, attacks, remediation, and more.

Secure your cloud application

See vulnerabilities and attacks in your environment.

Security Overview logo

Security Overview

Get a comprehensive overview of the security of your applications.

Code-Level Vulnerabilities logo

Code-Level Vulnerabilities

Detect vulnerabilities in your code in real time.

Security Posture Management logo

Security Posture Management

Detect, prioritize, and remediate security and compliance findings with SPM.

Threats & Exploits logo

Threats & Exploits

Understand, triage, and investigate detection findings and alerts.

Are you looking for something different?

We have hundreds of apps, extensions, and other technologies to customize your environment

Leverage our newest innovations of Dynatrace Saas

Kick-start your app creation

Kick-start your app creation

Whether you’re a beginner or a pro, Dynatrace Developer has the tools and support you need to create incredible apps with minimal effort.
Go to Dynatrace Developer
Upgrading from Dynatrace Managed to SaaS

Upgrading from Dynatrace Managed to SaaS

Drive innovation, speed, and agility in your organization by seamlessly and securely upgrading.
Learn More
Log Management and Analytics

Log Management and Analytics

Innovate faster and more efficiently with unified log management and log analytics for actionable insights and automation.
Learn more