VMware Tanzu Application Service

Overview

Any VMware Tanzu Application Service (formerly known as Pivotal Cloud Foundry, see the VMware announcement for more information) deployment can send metrics and events to Datadog. You can track the health and availability of all nodes in the deployment, monitor the jobs they run, collect metrics from the Loggregator Firehose, and more.

For the best experience, use this page to automatically set up monitoring through Tanzu Ops Manager for your application on VMware Tanzu Application Service and your VMware Tanzu Application Service cluster. For manual setup steps, see the VMware Tanzu Application Service Manual Setup Guide.

There are three main components for the VMware Tanzu Application Service integration with Datadog. First, the buildpack is used to collect custom metrics from your applications. Second, the BOSH Release collects metrics from the platform. Third, the Loggregator Firehose Nozzle collects all other metrics from your infrastructure. Read the Datadog VMware Tanzu Application Service architecture guide for more information.

Monitor your applications

Use the VMware Tanzu installation and configuration guide to install the integration through the Tanzu Ops Manager. For manual setup steps, read the Monitor your applications section in the manual setup guide.

Configuration

Metric collection

Set an API Key in your environment to enable the buildpack:

# set the environment variable
cf set-env <YOUR_APP> DD_API_KEY <DATADOG_API_KEY>
# restage the application to make it pick up the new environment variable and use the buildpack
cf restage <YOUR_APP>

Trace and profile collection

The Datadog Trace Agent (APM) is enabled by default. Learn more about setup for your specific language in APM setup and Profiling setup.

Log collection

Log collection is not supported for this site.

Enable log collection

To start collecting logs from your application in VMware Tanzu Application Service, the Agent contained in the buildpack needs to be activated and log collection enabled.

cf set-env <YOUR_APP_NAME> DD_LOGS_ENABLED true
# Disable the Agent core checks to disable system metrics collection
cf set-env <YOUR_APP_NAME> DD_ENABLE_CHECKS false
# Redirect Container Stdout/Stderr to a local port so the Agent collects the logs
cf set-env <YOUR_APP_NAME> STD_LOG_COLLECTION_PORT <PORT>
# Configure the Agent to collect logs from the wanted port and set the value for source and service
cf set-env <YOUR_APP_NAME> LOGS_CONFIG '[{"type":"tcp","port":"<PORT>","source":"<SOURCE>","service":"<SERVICE>"}]'
# restage the application to make it pick up the new environment variable and use the buildpack
cf restage <YOUR_APP_NAME>
Configure log collection

The following table describes the parameters above, and how they can be used to configure log collection:

ParameterDescription
DD_LOGS_ENABLEDSet to true to enable Datadog Agent log collection.
DD_ENABLE_CHECKSSet to false to disable the Agent’s system metrics collection through core checks.
STD_LOG_COLLECTION_PORTMust be used when collecting logs from stdout or stderr. It redirects the stdout or stderr stream to the corresponding local port value.
LOGS_CONFIGUse this option to configure the Agent to listen to a local TCP port and set the value for the service and source parameters.

Example:

A Java application named app01 is running in VMware Tanzu Application Service. The following configuration redirects the container stdout/stderr to the local port 10514. It then configures the Agent to collect logs from that port while setting the proper value for service and source:

# Redirect Stdout/Stderr to port 10514
cf set-env app01 STD_LOG_COLLECTION_PORT 10514
# Configure the Agent to listen to port 10514
cf set-env app01 LOGS_CONFIG '[{"type":"tcp","port":"10514","source":"java","service":"app01"}]'
Notification in case of misconfigured proxy

For Agent version 6.12 or greater, when using a proxy configuration with the buildpack, a verification is made to check if the connection can be established. Log collection is started depending on the result of this test.

If the connection fails to establish and log collection does not start, an event like this appears in the Events Explorer. Set up a monitor to track these events and be notified when a misconfigured Buildpack is deployed:

An event in Datadog with the title Log endpoint cannot be reached - Log collection not started and a message stating that a TCP connection could not be established

Tags

In order to add custom tags to your application, set the DD_TAGS environment variable through the manifest.yml file or the CF CLI command:

# set the environment variable
cf set-env <YOUR_APP> DD_TAGS key1=value1,key2=value2
# restage the application to make it pick up the new environment variable and use the new tags
cf restage <YOUR_APP>

DogStatsD

You can use DogStatsD to send custom application metrics to Datadog. See Metric Submission: DogStatsD for more information. There is a list of DogStatsD libraries compatible with a wide range of applications.

Monitor your VMware Tanzu Application Service cluster

Use the VMware Tanzu installation and configuration guide to install the integration through the Tanzu Ops Manager. For manual setup steps, read the Monitor your VMware Tanzu Application Service cluster section in the manual setup guide.

Data Collected

Metrics

The following metrics are sent by the Datadog Firehose Nozzle and are prefixed with cloudfoundry.nozzle. The Datadog Agent sends metrics from any Agent checks you configure in the Director runtime configuration, and system, network, disk, and NTP metrics by default.

The Datadog Firehose Nozzle only collects CounterEvents (as metrics, not events), ValueMetrics, and ContainerMetrics; it ignores LogMessages and Errors.

Your specific list of metrics may vary based on the PCF version and the deployment. Datadog collects counter and gauge metrics emitted from the Loggregator v2 API. See Cloud Foundry Component Metrics for a list of metrics emitted by default.

cloudfoundry.nozzle.auctioneer.LockHeld.v1_locks_auctioneer_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.auctioneer.LockHeldDuration.v1_locks_auctioneer_lock
(gauge)
The time in NS that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.auctioneer.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.auctioneer.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.auctioneer.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.auctioneer.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.auctioneer.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.auctioneer.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.auctioneer.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.auctioneer.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.bbs.ConvergenceLRPDuration
(gauge)
Time the BBS took to run its LRP convergence pass.
Shown as nanosecond
cloudfoundry.nozzle.bbs.ConvergenceLRPRuns
(gauge)
Cumulative number of times BBS has run its LRP convergence pass.
Shown as job
cloudfoundry.nozzle.bbs.ConvergenceTaskDuration
(gauge)
Time the BBS took to run its Task convergence pass.
Shown as nanosecond
cloudfoundry.nozzle.bbs.ConvergenceTaskRuns
(gauge)
Cumulative number of times the BBS has run its Task convergence pass.
Shown as job
cloudfoundry.nozzle.bbs.ConvergenceTasksKicked
(gauge)
Cumulative number of times the BBS has updated a Task during its Task convergence pass.
Shown as job
cloudfoundry.nozzle.bbs.ConvergenceTasksPruned
(gauge)
Cumulative number of times the BBS has deleted a malformed Task during its Task convergence pass.
Shown as job
cloudfoundry.nozzle.bbs.CrashedActualLRPs
(gauge)
Total number of LRP instances that have crashed.
Shown as instance
cloudfoundry.nozzle.bbs.CrashingDesiredLRPs
(gauge)
Total number of DesiredLRPs that have at least one crashed instance.
Shown as instance
cloudfoundry.nozzle.bbs.Domain.cf_apps
(gauge)
Whether the domain name (Domain.) is up to date. So that instances from that domain have been synchronized with DesiredLRPs for Diego to run. 1 means the domain is up-to-date. No data means it is not.
Shown as monitor
cloudfoundry.nozzle.bbs.Domain.cf_tasks
(gauge)
Whether the domain name (Domain.) is up to date. So that instances from that domain have been synchronized with DesiredLRPs for Diego to run. 1 means the domain is up-to-date. No data means it is not.
Shown as monitor
cloudfoundry.nozzle.bbs.ETCDLeader
(gauge)
Index of the leader node in the etcd cluster.
Shown as item
cloudfoundry.nozzle.bbs.ETCDRaftTerm
(gauge)
Raft term of the etcd cluster.
Shown as unit
cloudfoundry.nozzle.bbs.ETCDReceivedBandwidthRate
(gauge)
Number of bytes per second received by the follower etcd node.
Shown as byte
cloudfoundry.nozzle.bbs.ETCDReceivedRequestRate
(gauge)
Number of requests per second received by the follower etcd node.
Shown as byte
cloudfoundry.nozzle.bbs.ETCDSentBandwidthRate
(gauge)
Number of bytes per second sent by the leader etcd node.
Shown as byte
cloudfoundry.nozzle.bbs.ETCDSentRequestRate
(gauge)
Number of requests per second sent by the leader etcd node.
Shown as byte
cloudfoundry.nozzle.bbs.ETCDWatchers
(gauge)
Number of watchers on the etcd cluster.
Shown as operation
cloudfoundry.nozzle.bbs.LockHeld.v1_locks_bbs_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.bbs.LockHeldDuration.v1_locks_bbs_lock
(gauge)
The time in NS that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.bbs.LRPsClaimed
(gauge)
Total number of LRP instances that have been claimed by some cell.
Shown as instance
cloudfoundry.nozzle.bbs.LRPsDesired
(gauge)
Total number of LRP instances desired across all LRPs.
Shown as instance
cloudfoundry.nozzle.bbs.LRPsExtra
(gauge)
Total number of LRP instances that are no longer desired but still have a BBS record.
Shown as instance
cloudfoundry.nozzle.bbs.LRPsMissing
(gauge)
Total number of LRP instances that are desired but have no record in the BBS.
Shown as instance
cloudfoundry.nozzle.bbs.LRPsRunning
(gauge)
Total number of LRP instances that are running on cells.
Shown as instance
cloudfoundry.nozzle.bbs.LRPsUnclaimed
(gauge)
Total number of LRP instances that have not yet been claimed by a cell.
Shown as instance
cloudfoundry.nozzle.bbs.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.bbs.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.bbs.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.bbs.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.bbs.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.bbs.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.bbs.MetricsReportingDuration
(gauge)
Time it took to report periodic metrics.
Shown as nanosecond
cloudfoundry.nozzle.bbs.numCPUS
(gauge)
Number of CPUs usable by the current process.
Shown as cpu
cloudfoundry.nozzle.bbs.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.bbs.RequestCount
(gauge)
Cumulative number of requests the BBS has handled through its API.
Shown as request
cloudfoundry.nozzle.bbs.RequestLatency
(gauge)
Time the BBS took to handle requests to its API endpoints.
Shown as nanosecond
cloudfoundry.nozzle.bbs.TasksCompleted
(gauge)
Total number of Tasks that have completed.
Shown as job
cloudfoundry.nozzle.bbs.TasksPending
(gauge)
Total number of Tasks that have not yet been placed on a cell.
Shown as job
cloudfoundry.nozzle.bbs.TasksResolving
(gauge)
Total number of Tasks locked for deletion.
Shown as job
cloudfoundry.nozzle.bbs.TasksRunning
(gauge)
Total number of Tasks running on cells.
Shown as job
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.healthy
(gauge)
The status—1 for up, 0 for down—of a job on a given node, tagged by job, for example, job:api_1.
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.cpu.user
(gauge)
The user space CPU usage of a node.
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.cpu.sys
(gauge)
The system CPU usage of a node.
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.cpu.wait
(gauge)
The CPU wait for a node.
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.load.1m
(gauge)
The one minute load average for a node.
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.mem.percent
(gauge)
The percentage memory usage of a node.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.mem.kb
(gauge)
The memory usage of a node in KiB.
Shown as kibibyte
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.swap.percent
(gauge)
The percentage swap usage of a node.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.swap.kb
(gauge)
The swap usage of a node in KiB.
Shown as kibibyte
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.system.percent
(gauge)
The percentage disk usage of a node's system disk.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.system.inode_percent
(gauge)
The percentage inode usage of a node's system disk.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.ephemeral.percent
(gauge)
The percentage disk usage of a node's ephemeral disk.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.ephemeral.inode_percent
(gauge)
The percentage inode usage of a node's ephemeral disk.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.persistent.percent
(gauge)
The percentage disk usage of a node's persistent disk.
Shown as percent
cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.persistent.inode_percent
(gauge)
The percentage inode usage of a node's persistent disk.
Shown as percent
cloudfoundry.nozzle.cc.failed_job_count.total
(gauge)
cloudfoundry.nozzle.cc.http_status.1xx
(gauge)
Number of HTTP response status codes of type 1xx.
Shown as response
cloudfoundry.nozzle.cc.http_status.2XX
(gauge)
Number of HTTP response status codes of type 2XX.
Shown as response
cloudfoundry.nozzle.cc.http_status.3xx
(gauge)
Number of HTTP response status codes of type 3xx.
Shown as response
cloudfoundry.nozzle.cc.http_status.4xx
(gauge)
Number of HTTP response status codes of type 4xx.
Shown as response
cloudfoundry.nozzle.cc.http_status.5xx
(gauge)
Number of HTTP response status codes of type 5xx.
Shown as response
cloudfoundry.nozzle.cc.job_queue_length.total
(gauge)
Jobs in the job queue.
Shown as item
cloudfoundry.nozzle.cc.log_count.all
(gauge)
The total number of log messages of all severity levels.
Shown as entry
cloudfoundry.nozzle.cc.log_count.debug
(gauge)
Number of log messages of severity debug.
Shown as entry
cloudfoundry.nozzle.cc.log_count.debug1
(gauge)
Number of log messages of severity debug1.
Shown as entry
cloudfoundry.nozzle.cc.log_count.debug2
(gauge)
Number of log messages of severity debug2.
Shown as entry
cloudfoundry.nozzle.cc.log_count.error
(gauge)
Number of log messages of severity error.
Shown as entry
cloudfoundry.nozzle.cc.log_count.fatal
(gauge)
Number of log messages of severity fatal.
Shown as entry
cloudfoundry.nozzle.cc.log_count.info
(gauge)
Number of log messages of severity info.
Shown as entry
cloudfoundry.nozzle.cc.log_count.off
(gauge)
Number of log messages of severity off.
Shown as entry
cloudfoundry.nozzle.cc.log_count.warn
(gauge)
Number of log messages of severity warn.
Shown as entry
cloudfoundry.nozzle.cc.requests.completed
(gauge)
Number of requests that have been processed.
Shown as request
cloudfoundry.nozzle.cc.requests.outstanding
(gauge)
Number of request that are currently being processed.
Shown as request
cloudfoundry.nozzle.cc.tasks_running.count
(gauge)
Number of currently running tasks.
Shown as job
cloudfoundry.nozzle.cc.tasks_running.memory_in_mb
(gauge)
Memory being consumed by all currently running tasks.
Shown as mebibyte
cloudfoundry.nozzle.cc.thread_info.event_machine.connection_count
(gauge)
Number of open connections to event machine.
Shown as connection
cloudfoundry.nozzle.cc.thread_info.event_machine.resultqueue.num_waiting
(gauge)
Number of scheduled tasks in the result.
Shown as job
cloudfoundry.nozzle.cc.thread_info.event_machine.resultqueue.size
(gauge)
Number of unscheduled tasks in the result.
Shown as job
cloudfoundry.nozzle.cc.thread_info.event_machine.threadqueue.num_waiting
(gauge)
Number of scheduled tasks in the threadqueue.
Shown as job
cloudfoundry.nozzle.cc.thread_info.event_machine.threadqueue.size
(gauge)
Number of unscheduled tasks in the threadqueue.
Shown as job
cloudfoundry.nozzle.cc.thread_info.thread_count
(gauge)
Total number of threads that are either runnable or stopped.
Shown as thread
cloudfoundry.nozzle.cc.total_users
(gauge)
Total number of users ever created including inactive users.
Shown as unit
cloudfoundry.nozzle.cc.vitals.cpu
(gauge)
Percentage of CPU used by the Cloud Controller process.
Shown as percent
cloudfoundry.nozzle.cc.vitals.cpu_load_avg
(gauge)
System CPU load averaged over the last 1 minute according to the OS.
cloudfoundry.nozzle.cc.vitals.mem_bytes
(gauge)
The RSS bytes (resident set size) or real memory of the Cloud Controller process.
Shown as byte
cloudfoundry.nozzle.cc.vitals.mem_free_bytes
(gauge)
Total memory available according to the OS.
Shown as byte
cloudfoundry.nozzle.cc.vitals.mem_used_bytes
(gauge)
Total memory used (active and wired) according to the OS.
Shown as byte
cloudfoundry.nozzle.cc.vitals.num_cores
(gauge)
The number of CPUs of a host machine.
Shown as cpu
cloudfoundry.nozzle.cc.vitals.uptime
(gauge)
Uptime in seconds.
Shown as second
cloudfoundry.nozzle.cc_uploader.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.cc_uploader.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.cc_uploader.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.cc_uploader.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.cc_uploader.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.cc_uploader.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.cc_uploader.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.cc_uploader.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.doppler_proxy.slow_consumer
(gauge)
Number of dropped messages by the Loggregator system because the nozzle consumes messages more slowly than they are produced.
Shown as message
cloudfoundry.nozzle.DopplerServer.dropsondeListener.receivedByteCount
(gauge)
cloudfoundry.nozzle.DopplerServer.dropsondeListener.receivedMessageCount
(gauge)
cloudfoundry.nozzle.DopplerServer.dropsondeUnmarshaller.containerMetricReceived
(gauge)
cloudfoundry.nozzle.DopplerServer.dropsondeUnmarshaller.counterEventReceived
(gauge)
cloudfoundry.nozzle.DopplerServer.dropsondeUnmarshaller.httpStartStopReceived
(gauge)
cloudfoundry.nozzle.DopplerServer.dropsondeUnmarshaller.logMessageTotal
(gauge)
cloudfoundry.nozzle.DopplerServer.dropsondeUnmarshaller.valueMetricReceived
(gauge)
cloudfoundry.nozzle.DopplerServer.httpServer.receivedMessages
(gauge)
cloudfoundry.nozzle.DopplerServer.LinuxFileDescriptor
(gauge)
cloudfoundry.nozzle.DopplerServer.listeners.receivedEnvelopes
(gauge)
cloudfoundry.nozzle.DopplerServer.listeners.totalReceivedByteCount
(gauge)
cloudfoundry.nozzle.DopplerServer.listeners.totalReceivedMessageCount
(gauge)
cloudfoundry.nozzle.DopplerServer.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.DopplerServer.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.DopplerServer.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.DopplerServer.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.DopplerServer.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.DopplerServer.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.DopplerServer.messageRouter.numberOfDumpSinks
(gauge)
cloudfoundry.nozzle.DopplerServer.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.DopplerServer.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.DopplerServer.sentEnvelopes
(gauge)
cloudfoundry.nozzle.DopplerServer.sentMessagesFirehose
(gauge)
cloudfoundry.nozzle.DopplerServer.signatureVerifier.validSignatures
(gauge)
cloudfoundry.nozzle.DopplerServer.udpListener.receivedByteCount
(gauge)
cloudfoundry.nozzle.DopplerServer.udpListener.receivedMessageCount
(gauge)
cloudfoundry.nozzle.DopplerServer.Uptime
(gauge)
Uptime in seconds.
Shown as second
cloudfoundry.nozzle.etcd.CompareAndDeleteFail
(gauge)
Count of CompareAndDeleteFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.CompareAndDeleteSuccess
(gauge)
Count of CompareAndDeleteSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.CompareAndSwapFail
(gauge)
Count of CompareAndSwapFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.CompareAndSwapSuccess
(gauge)
Count of CompareAndSwapSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.CreateFail
(gauge)
Count of CreateFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.CreateSuccess
(gauge)
Count of CreateSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.DeleteFail
(gauge)
Count of DeleteFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.DeleteSuccess
(gauge)
Count of DeleteSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.EtcdIndex
(gauge)
Etcd Index
Shown as item
cloudfoundry.nozzle.etcd.ExpireCount
(gauge)
Count of ExpireCount operations.
Shown as operation
cloudfoundry.nozzle.etcd.Followers
(gauge)
number of etcd followers
Shown as item
cloudfoundry.nozzle.etcd.GetsFail
(gauge)
Count of GetsFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.GetsSuccess
(gauge)
Count of GetsSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.IsLeader
(gauge)
1 if it is the leader, 0 if it is not.
Shown as monitor
cloudfoundry.nozzle.etcd.logSenderTotalMessagesRead
(gauge)
Cumulative number of application log messages.
Shown as message
cloudfoundry.nozzle.etcd.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.etcd.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.etcd.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.etcd.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.etcd.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.etcd.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.etcd.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.etcd.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.etcd.RaftIndex
(gauge)
Raft index of the etcd cluster.
Shown as item
cloudfoundry.nozzle.etcd.RaftTerm
(gauge)
Raft term of the etcd cluster.
Shown as item
cloudfoundry.nozzle.etcd.ReceivedAppendRequests
(gauge)
The number of append requests this node has recieved.
Shown as request
cloudfoundry.nozzle.etcd.ReceivingBandwidthRate
(gauge)
Number of bytes per second this node is receiving (follower only).
Shown as byte
cloudfoundry.nozzle.etcd.ReceivingRequestRate
(gauge)
Number of requests per second this node is receiving (follower only).
Shown as byte
cloudfoundry.nozzle.etcd.SendingBandwidthRate
(gauge)
Number of bytes per second this node is sending (leader only).
Shown as byte
cloudfoundry.nozzle.etcd.SendingRequestRate
(gauge)
Number of requests per second this node is sending (leader only).
Shown as byte
cloudfoundry.nozzle.etcd.SentAppendRequests
(gauge)
Number of requests that this node has sent.
Shown as request
cloudfoundry.nozzle.etcd.SetsFail
(gauge)
Count of SetsFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.SetsSuccess
(gauge)
Count of SetsSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.UpdateFail
(gauge)
Count of UpdateFail operations.
Shown as operation
cloudfoundry.nozzle.etcd.UpdateSuccess
(gauge)
Count of UpdateSuccess operations.
Shown as operation
cloudfoundry.nozzle.etcd.Watchers
(gauge)
Count of Watchers operations.
Shown as operation
cloudfoundry.nozzle.file_server.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.file_server.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.file_server.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.file_server.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.file_server.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.file_server.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.file_server.numCPUS
(gauge)
Number of CPUs usable by the current process.
Shown as cpu
cloudfoundry.nozzle.file_server.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.garden_linux.BackingStores
(gauge)
Number of container backing store files.
Shown as file
cloudfoundry.nozzle.garden_linux.DepotDirs
(gauge)
Number of directories in the Garden depot.
Shown as file
cloudfoundry.nozzle.garden_linux.LoopDevices
(gauge)
Number of attached loop devices.
Shown as item
cloudfoundry.nozzle.garden_linux.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.garden_linux.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.garden_linux.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.garden_linux.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.garden_linux.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.garden_linux.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.garden_linux.MetricsReporting
(gauge)
How long it took to emit the BackingStores, DepotDirs, and LoopDevices metrics.
Shown as nanosecond
cloudfoundry.nozzle.garden_linux.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.garden_linux.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.gorouter.latency
(gauge)
Time in milliseconds that the Gorouter took to handle requests to its application endpoints.
Shown as millisecond
cloudfoundry.nozzle.gorouter.latency.CloudController
(gauge)
Time in milliseconds that the Gorouter took to handle requests from a component to its endpoints.
Shown as millisecond
cloudfoundry.nozzle.gorouter.latency.route_emitter
(gauge)
Time in milliseconds that the Gorouter took to handle requests from a component to its endpoints.
Shown as millisecond
cloudfoundry.nozzle.gorouter.logSenderTotalMessagesRead
(gauge)
Cumulative number of application log messages.
Shown as message
cloudfoundry.nozzle.gorouter.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.gorouter.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.gorouter.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.gorouter.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.gorouter.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.gorouter.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.gorouter.ms_since_last_registry_update
(gauge)
Time in millisecond since the last route register has been been received.
Shown as millisecond
cloudfoundry.nozzle.gorouter.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.gorouter.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.gorouter.registry_message
(gauge)
Time in milliseconds that the Gorouter took to handle requests to its application endpoints.
Shown as millisecond
cloudfoundry.nozzle.gorouter.registry_message.
(gauge)
Cumulative number of route register messages received for a component.
Shown as message
cloudfoundry.nozzle.gorouter.registry_message.CloudController
(gauge)
Cumulative number of route register messages received for a component.
Shown as message
cloudfoundry.nozzle.gorouter.registry_message.redis_broker
(gauge)
Cumulative number of route register messages received for a component.
Shown as message
cloudfoundry.nozzle.gorouter.registry_message.route_emitter
(gauge)
Cumulative number of route register messages received for a component.
Shown as message
cloudfoundry.nozzle.gorouter.rejected_requests
(gauge)
Cumulative number of bad requests received on Gorouter.
Shown as request
cloudfoundry.nozzle.gorouter.requests.CloudController
(gauge)
Cumulative number of requests received for a component.
Shown as request
cloudfoundry.nozzle.gorouter.requests.route_emitter
(gauge)
Cumulative number of requests received for a component.
Shown as request
cloudfoundry.nozzle.gorouter.responses
(gauge)
Cumulative number of HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.responses.1xx
(gauge)
Cumulative number of 1xx HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.responses.2xx
(gauge)
Cumulative number of 2xx HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.responses.3xx
(gauge)
Cumulative number of 3xx HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.responses.4xx
(gauge)
Cumulative number of 4xx HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.responses.5xx
(gauge)
Cumulative number of 5xx HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.responses.xxx
(gauge)
Cumulative number of xxx HTTP responses.
Shown as response
cloudfoundry.nozzle.gorouter.route_lookup_time
(gauge)
Time in nanoseconds to look up a request URL in the route table.
Shown as nanosecond
cloudfoundry.nozzle.gorouter.routed_app_requests
(gauge)
The collector sums up requests for all dea-{index} components for its output metrics.
Shown as route
cloudfoundry.nozzle.gorouter.total_requests
(gauge)
Cumulative number of requests received.
Shown as request
cloudfoundry.nozzle.gorouter.total_routes
(gauge)
Current number of routes registered.
Shown as route
cloudfoundry.nozzle.gorouter.unregistry_message
(gauge)
Cumulative number of route unregister messages received for each component.
Shown as message
cloudfoundry.nozzle.gorouter.uptime
(gauge)
Uptime in seconds.
Shown as second
cloudfoundry.nozzle.gorouter.websocket_failures
(gauge)
Cumulative number of WebSocket failures.
Shown as response
cloudfoundry.nozzle.gorouter.websocket_upgrades
(gauge)
Cumulative number of WebSocket upgrades.
Shown as connection
cloudfoundry.nozzle.LoggregatorTrafficController.LinuxFileDescriptor
(gauge)
cloudfoundry.nozzle.LoggregatorTrafficController.listeners.receivedEnvelopes
(gauge)
cloudfoundry.nozzle.LoggregatorTrafficController.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.LoggregatorTrafficController.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.LoggregatorTrafficController.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.LoggregatorTrafficController.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.LoggregatorTrafficController.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.LoggregatorTrafficController.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.LoggregatorTrafficController.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.LoggregatorTrafficController.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.LoggregatorTrafficController.Uptime
(gauge)
Uptime in seconds.
Shown as second
cloudfoundry.nozzle.MetronAgent.DopplerForwarder.sentMessages
(gauge)
Cumulative number of messages sent to Doppler regardless of protocol.
Shown as message
cloudfoundry.nozzle.MetronAgent.dropsondeAgentListener.receivedByteCount
(gauge)
Cumulative number of bytes of Dropsonde messages read by UDP socket.
Shown as byte
cloudfoundry.nozzle.MetronAgent.dropsondeAgentListener.receivedMessageCount
(gauge)
Cumulative number of Dropsonde messages read by UDP socket.
Shown as message
cloudfoundry.nozzle.MetronAgent.dropsondeMarshaller.sentEnvelopes
(gauge)
Cumulative number of sent envelopes.
Shown as payload
cloudfoundry.nozzle.MetronAgent.dropsondeUnmarshaller.containerMetricReceived
(gauge)
Cumulative number of ContainerMetric messages unmarshalled.
Shown as message
cloudfoundry.nozzle.MetronAgent.dropsondeUnmarshaller.counterEventReceived
(gauge)
Cumulative number of CounterEvent messages unmarshalled.
Shown as event
cloudfoundry.nozzle.MetronAgent.dropsondeUnmarshaller.httpStartStopReceived
(gauge)
Cumulative number of HttpStartStop messages unmarshalled.
Shown as event
cloudfoundry.nozzle.MetronAgent.dropsondeUnmarshaller.logMessageTotal
(gauge)
Cumulative number of LogMessage messages unmarshalled.
Shown as message
cloudfoundry.nozzle.MetronAgent.dropsondeUnmarshaller.receivedEnvelopes
(gauge)
Cumulative number of received envelopes.
Shown as payload
cloudfoundry.nozzle.MetronAgent.dropsondeUnmarshaller.valueMetricReceived
(gauge)
Cumulative number of ValueMetric messages unmarshalled.
Shown as message
cloudfoundry.nozzle.MetronAgent.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.MetronAgent.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.MetronAgent.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.MetronAgent.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.MetronAgent.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.MetronAgent.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.MetronAgent.MessageAggregator.counterEventReceived
(gauge)
Cumulative number of CounterEvents aggregated in Metron.
Shown as event
cloudfoundry.nozzle.MetronAgent.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.MetronAgent.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.MetronAgent.udp.sentByteCount
(gauge)
Cumulative number of sent bytes to Doppler over UDP.
Shown as byte
cloudfoundry.nozzle.MetronAgent.udp.sentMessageCount
(gauge)
Cumulative number of sent messages to Doppler over UDP.
Shown as message
cloudfoundry.nozzle.nsync_bulker.DesiredLRPSyncDuration
(gauge)
Time in nanoseconds that the nsync-bulker took to synchronize CF apps and Diego DesiredLRPs.
Shown as nanosecond
cloudfoundry.nozzle.nsync_bulker.LockHeld.v1_locks_nsync_bulker_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.nsync_bulker.LockHeldDuration.v1_locks_nsync_bulker_lock
(gauge)
The time in nanoseconds that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.nsync_bulker.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.nsync_bulker.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.nsync_bulker.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.nsync_bulker.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.nsync_bulker.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.nsync_bulker.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.nsync_bulker.NsyncInvalidDesiredLRPsFound
(gauge)
cloudfoundry.nozzle.nsync_bulker.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.nsync_bulker.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.nsync_listener.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.nsync_listener.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.nsync_listener.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.nsync_listener.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.nsync_listener.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.nsync_listener.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.nsync_listener.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.nsync_listener.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.rep.CapacityRemainingContainers
(gauge)
Remaining number of containers this cell can host.
Shown as container
cloudfoundry.nozzle.rep.CapacityRemainingDisk
(gauge)
Remaining amount in MiB of disk available for this cell to allocate to containers.
Shown as mebibyte
cloudfoundry.nozzle.rep.CapacityRemainingMemory
(gauge)
Remaining amount in MiB of memory available for this cell to allocate to containers.
Shown as mebibyte
cloudfoundry.nozzle.rep.CapacityTotalContainers
(gauge)
Total number of containers this cell can host.
Shown as container
cloudfoundry.nozzle.rep.CapacityTotalDisk
(gauge)
Time in nanoseconds that the nsync-bulker took to synchronize CF apps and Diego DesiredLRPs.
Shown as mebibyte
cloudfoundry.nozzle.rep.CapacityTotalMemory
(gauge)
Total amount in MiB of disk available for this cell to allocate to containers.
Shown as mebibyte
cloudfoundry.nozzle.rep.ContainerCount
(gauge)
Number of containers hosted on the cell.
Shown as container
cloudfoundry.nozzle.rep.logSenderTotalMessagesRead
(gauge)
Cumulative number of application log messages.
Shown as message
cloudfoundry.nozzle.rep.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.rep.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.rep.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.rep.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.rep.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.rep.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.rep.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.rep.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.rep.RepBulkSyncDuration
(gauge)
Time in nanoseconds that the cell rep took to synchronize the ActualLRPs it has claimed with its actual garden containers.
Shown as nanosecond
cloudfoundry.nozzle.rep.UnhealthyCell
(gauge)
Whether the cell has failed to pass its healthcheck against the garden backend. 0 signifies healthy and 1 signifies unhealthy.
Shown as monitor
cloudfoundry.nozzle.route_emitter.ConsulDownMode
(gauge)
cloudfoundry.nozzle.route_emitter.LockHeld.v1_locks_route_emitter_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.route_emitter.LockHeldDuration.v1_locks_route_emitter_lock
(gauge)
The time in nanoseconds that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.route_emitter.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.route_emitter.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.route_emitter.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.route_emitter.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.route_emitter.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.route_emitter.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.route_emitter.MessagesEmitted
(gauge)
The cumulative number of registration messages that this process has sent.
Shown as message
cloudfoundry.nozzle.route_emitter.numCPUS
(gauge)
Number of CPUs usable by the current process.
Shown as cpu
cloudfoundry.nozzle.route_emitter.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.route_emitter.RouteEmitterSyncDuration
(gauge)
Time in nanoseconds that the active route-emitter took to perform its synchronization pass.
Shown as nanosecond
cloudfoundry.nozzle.route_emitter.RoutesRegistered
(gauge)
Cumulative number of route registrations emitted from the route-emitter as it reacts to changes to LRPs.
Shown as route
cloudfoundry.nozzle.route_emitter.RoutesSynced
(gauge)
Cumulative number of route registrations emitted from the route-emitter during its periodic route-table synchronization.
Shown as route
cloudfoundry.nozzle.route_emitter.RoutesTotal
(gauge)
Number of routes in the route-emitter's routing table.
Shown as route
cloudfoundry.nozzle.route_emitter.RoutesUnregistered
(gauge)
Cumulative number of route unregistrations emitted from the route-emitter as it reacts to changes to LRPs.
Shown as route
cloudfoundry.nozzle.routing_api.key_refresh_events
(gauge)
Total number of events when a fresh token was fetched from UAA.
Shown as event
cloudfoundry.nozzle.routing_api.LockHeld.v1_locks_routing_api_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.routing_api.LockHeldDuration.v1_locks_routing_api_lock
(gauge)
The time in nanoseconds that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.routing_api.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.routing_api.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.routing_api.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.routing_api.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.routing_api.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.routing_api.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.routing_api.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.routing_api.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.routing_api.total_http_routes
(gauge)
cloudfoundry.nozzle.routing_api.total_http_subscriptions
(gauge)
cloudfoundry.nozzle.routing_api.total_tcp_routes
(gauge)
cloudfoundry.nozzle.routing_api.total_tcp_subscriptions
(gauge)
cloudfoundry.nozzle.routing_api.total_token_errors
(gauge)
cloudfoundry.nozzle.slowConsumerAlert
(gauge)
1 If the nozzle is processing metrics too slowly, otherwise 0.
Shown as monitor
cloudfoundry.nozzle.ssh_proxy.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.ssh_proxy.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.ssh_proxy.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.ssh_proxy.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.ssh_proxy.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.ssh_proxy.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.ssh_proxy.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.ssh_proxy.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.stager.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.stager.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.stager.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.stager.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.stager.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.stager.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.stager.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.stager.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.syslog_drain_binder.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.syslog_drain_binder.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.syslog_drain_binder.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.syslog_drain_binder.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.syslog_drain_binder.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.syslog_drain_binder.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.syslog_drain_binder.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.syslog_drain_binder.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.syslog_drain_binder.pollCount
(gauge)
Number of times the syslog drain binder has polled the cloud controller for syslog drain bindings.
Shown as event
cloudfoundry.nozzle.syslog_drain_binder.totalDrains
(gauge)
Number of syslog drains returned by cloud controller.
Shown as resource
cloudfoundry.nozzle.tcp_emitter.LockHeld.v1_locks_tcp_emitter_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.tcp_emitter.LockHeldDuration.v1_locks_tcp_emitter_lock
(gauge)
The time in nanoseconds that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.tcp_emitter.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.tcp_emitter.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tcp_emitter.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tcp_emitter.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.tcp_emitter.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.tcp_emitter.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.tcp_emitter.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.tcp_emitter.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.tcp_router.AverageConnectTimeMs
(gauge)
Average backend response time (in milliseconds).
Shown as millisecond
cloudfoundry.nozzle.tcp_router.AverageQueueTimeMs
(gauge)
Average time spent in queue (in milliseconds).
Shown as millisecond
cloudfoundry.nozzle.tcp_router.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.tcp_router.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tcp_router.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tcp_router.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.tcp_router.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.tcp_router.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.tcp_router.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.tcp_router.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.tcp_router.TotalBackendConnectionErrors
(gauge)
Total number of backend connection errors.
Shown as error
cloudfoundry.nozzle.tcp_router.TotalCurrentQueuedRequests
(gauge)
otal number of requests unassigned in queue.
Shown as request
cloudfoundry.nozzle.totalMessagesReceived
(gauge)
Total number of messages received by the nozzle.
Shown as message
cloudfoundry.nozzle.totalMetricsSent
(gauge)
Total number of metrics sent to Datadog by the nozzle.
Shown as message
cloudfoundry.nozzle.tps_listener.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.tps_listener.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tps_listener.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tps_listener.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.tps_listener.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.tps_listener.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.tps_listener.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.tps_listener.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.tps_watcher.LockHeld.v1_locks_tps_watcher_lock
(gauge)
0 means the lock is not held, 1 means it is.
Shown as monitor
cloudfoundry.nozzle.tps_watcher.LockHeldDuration.v1_locks_tps_watcher_lock
(gauge)
The time in nanoseconds that the lock has been held.
Shown as nanosecond
cloudfoundry.nozzle.tps_watcher.memoryStats.lastGCPauseTimeNS
(gauge)
Last GC pause in nanoseconds.
Shown as nanosecond
cloudfoundry.nozzle.tps_watcher.memoryStats.numBytesAllocated
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tps_watcher.memoryStats.numBytesAllocatedHeap
(gauge)
Bytes allocated and not yet freed.
Shown as byte
cloudfoundry.nozzle.tps_watcher.memoryStats.numBytesAllocatedStack
(gauge)
Number of bytes in the stack.
Shown as byte
cloudfoundry.nozzle.tps_watcher.memoryStats.numFrees
(gauge)
Number of frees.
Shown as item
cloudfoundry.nozzle.tps_watcher.memoryStats.numMallocs
(gauge)
Number of mallocs.
Shown as item
cloudfoundry.nozzle.tps_watcher.numCPUS
(gauge)
Number of CPUs usable by current process.
Shown as cpu
cloudfoundry.nozzle.tps_watcher.numGoRoutines
(gauge)
Number of existing goroutines.
Shown as item
cloudfoundry.nozzle.uaa.audit_service.client_authentication_count
(gauge)
Number of successful client authentication attempts since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.client_authentication_failure_count
(gauge)
Number of failed client authentication attempts since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.principal_authentication_failure_count
(gauge)
Number of failed non-user authentication attempts since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.principal_not_found_count
(gauge)
Number of times non-user was not found since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.user_authentication_count
(gauge)
Number of successful authentications by the user since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.user_authentication_failure_count
(gauge)
Number of failed user authentication attempts since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.user_not_found_count
(gauge)
Number of times the user was not found since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.user_password_changes
(gauge)
Number of successful password changes by the user since the last startup.
Shown as event
cloudfoundry.nozzle.uaa.audit_service.user_password_failures
(gauge)
Number of failed password changes by the user since the last startup.
Shown as event
bosh.healthmonitor.system.healthy
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.healthy instead. The status—1 for up, 0 for down—of a job on a given node, tagged by job, e.g. 'job:api_1'.
bosh.healthmonitor.system.cpu.user
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.cpu.user instead. The user space CPU usage of a node.
bosh.healthmonitor.system.cpu.sys
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.cpu.sys instead. The system CPU usage of a node.
bosh.healthmonitor.system.cpu.wait
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.cpu.wait instead. The CPU wait for a node.
bosh.healthmonitor.system.load.1m
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.load.1m instead. The one-minute load average for a node.
bosh.healthmonitor.system.mem.percent
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.mem.percent instead. The percentage memory usage of a node.
Shown as percent
bosh.healthmonitor.system.mem.kb
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.mem.kb instead. The memory usage of a node in KiB.
Shown as kibibyte
bosh.healthmonitor.system.swap.percent
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.swap.percent instead. The percentage swap usage of a node.
Shown as percent
bosh.healthmonitor.system.swap.kb
(gauge)
Deprecated. As per PCF version 2.0, use cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.swap.kb instead. The swap usage of a node in KiB.
Shown as kibibyte
bosh.healthmonitor.system.disk.system.percent
(gauge)
Deprecated. As per PCF version 2.0, use 'cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.system.percent' instead. The percentage disk usage of a node's system disk.
Shown as percent
bosh.healthmonitor.system.disk.system.inode_percent
(gauge)
Deprecated. As per PCF version 2.0, use 'cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.system.inode_percent' instead. The percentage inode usage of a node's system disk.
Shown as percent
bosh.healthmonitor.system.disk.ephemeral.percent
(gauge)
Deprecated. As per PCF version 2.0, use 'cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.ephemeral.percent' instead. The percentage disk usage of a node's ephemeral disk.
Shown as percent
bosh.healthmonitor.system.disk.ephemeral.inode_percent
(gauge)
Deprecated. As per PCF version 2.0, use 'cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.ephemeral.inode_percent' instead. The percentage inode usage of a node's ephemeral disk.
Shown as percent
bosh.healthmonitor.system.disk.persistent.percent
(gauge)
Deprecated. As per PCF version 2.0, use 'cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.persistent.percent' instead. The percentage disk usage of a node's persistent disk.
Shown as percent
bosh.healthmonitor.system.disk.persistent.inode_percent
(gauge)
Deprecated. As per PCF version 2.0, use 'cloudfoundry.nozzle.bosh_system_metrics_forwarder.system.disk.persistent.inode_percent' instead. The percentage inode usage of a node's persistent disk.
Shown as percent

Further reading