Filtering with Dynamic Focus

Dynamic Focus Query (DFQ) is a robust search and filter function that can search through all the data contexts simultaneously. Microservice architecture uses a complex variety of data contexts that are all clustered together. By using Dynamic Focus, you can filter across the data contexts to have a strong system-wide understanding.

The Instana Dynamic Focus search bar is displayed on the Infrastructure Map page, and it is used for specifying the scope for events and alerts.

Dynamic Focus enables the following kinds of queries, for example:

  • Filter infrastructure
    • with open issues
    • of a specific technology
    • for a specific service and change event
  • Filter events
    • for a specific service and infrastructure combination
    • on a specific container and technology
    • on specific infrastructure

Dynamic Focus takes advantage of the following capabilities:

  • Dynamic Graph – A cohesive model that Instana uses, which contains physical and logical components with all historical attributes and metrics. The Dynamic Graph also includes distributed traces and events. All nodes in the graph are connected based on their dependencies. The various views in Instana visualize the data of the graph, and Dynamic Focus filters the graph to provide specific subviews and focus.

  • Automatic Discovery – The Instana agent automatically discovers all components and their dependencies that are held in the graph in real-time. Any saved filter adapts to the current situation of your systems and applications without any manual change or configuration.

  • Incidents – Instana incidents are based on KPIs and machine learning and provide condensed information about an incident. The information includes the dependencies to services, traces, and physical components. Dynamic Focus uses the information to filter only the components that are part of a particular incident.

Focusing on application components

The following example helps you to understand the concept of Dynamic Focus.

Consider the graph representation of a zoned application that is running on two hosts with four containers each. A Java virtual machine (JVM) runs in every container, and each of the two hosts runs two Tomcats and two Elasticsearch instances, which provide a service per host. A simplified version of the Dynamic Graph model looks like the following diagram:

The filtering capability reduces the nodes in the graph based on a search query.

A query for entity.type:tomcat matches all the Tomcat instances in the graph. This means that containers with Elasticsearch entities and the corresponding services no longer are visible when you view your infrastructure, application, and traces in the standard views.

Any chart, change, issue, or incident in Instana can be seen only in the context of the reduced graph.

Another example query is to search for all JVMs 1.8, such as entity.jvm.version:1.8.*

In this case, the graph looks as shown:

Dynamic Focus is a powerful tool to find and focus user attention on single entities, or groups of entities, within the graph that match certain criteria.

Focusing on management attributes

Instana also has structures that are outside the Dynamic Graph, but refer to the Dynamic Graph, such as events (like a change), issues, or incidents. An incident might contain services where Instana found KPI outliers and might contain entities with issues like high CPU load.

By using the search capability of Dynamic Focus, you can query and filter for incidents like event.state:open event.type:incident. The search filters all the active incidents in the currently selected time frame. In this example, it is assumed that only one active incident is available when a degradation of an Elasticsearch service causes subsequent degradation of a Tomcat service.

Because the incident that matches has references to the two services, the query filters only the relevant entities.

If you search for a service, then only the incidents that contain this service are shown.

Lucene query syntax

Instana uses Lucene query syntax to build complex queries from the terms that are mapped to the application components and Boolean operators. A robust variety of query types are supported, like free text searches, tag filtering, CPU count queries, and more. The search bar aides the user in building queries by automatically highlighting valid individual terms from the rest of the string. In addition, you can avoid common string syntax pitfalls, such as confusing the free text query and with the Boolean operator AND.

The form that Lucene queries take varies depending on the implementation. In Instana, all queries proceed from a field to a field modifier and then to a quantifier. Both field values are separated by a period, while the quantifier is set off by a colon. For example, if you want to filter all the Tomcat instances in your application, then use the query entity.type: tomcat in the search bar. Instana removes everything from view except for all entities of the type labeled "tomcat."

The entity.type:tomcat query is just one query phrase. To build flexible and complex filters that show you exactly what you need, string different query phrases together with Boolean operators, such as AND, OR, and NOT. See the following example:

Default operator

The AND operator is the default conjunction operator. So, if no Boolean operator is used between two terms, the AND operator is used.

For example, entity.type:tomcat event.state:open is equivalent to entity.type:tomcat AND event.state:open. Using of the AND operator when no Boolean operator is used, diverges from the Lucene standard, which uses OR by default.

Complex subqueries

Lucene query syntax and Dynamic Focus queries do not support complex Boolean terms.

Especially, the negation of subqueries doesn't work as expected in the Dynamic Focus query. The following query does not yield the expected results:

entity.kubernetes.namespace:my-namespace AND NOT (entity.kubernetes.pod.name:my-name AND event.text:"ContainersNotReady")
 

The query is processed in a way that the terms in the subquery inside the parentheses are not associated to each other when Boolean logic is applied. The following query is processed:

entity.kubernetes.namespace:my-namespace AND NOT entity.kubernetes.pod.name:my-name AND NOT event.text:"ContainersNotReady"
 

Auto-complete

The Dynamic Focus search bar supports autocompletion for search fields and highlights the Lucene query terms while you type. When typing the query terms, the search bar proposes search fields that match the current input. If you do not have a command of Lucene syntax, then you can get automatic help. All query proposals that appear in a drop-down list as follows the search bar. If the needed proposal is in view, click or go to it by using the arrow keys.

Instana's search function is zero-time, which means that the results appear when you enter your search criteria. You can also save, edit, and delete filters to speed up your workflow.

Search keyword reference

Use the following tables to see an overview of the available keywords, data types and descriptions of each search context.

Infrastructure and platform monitoring

Table 1. Search keyword references
Keyword Data type Description Remark
entity.ace.integrationNode.name string ACE integration node name.
entity.ace.integrationServer.name string ACE integration server name.
entity.ace.integrationServer.state string ACE integration server state.
entity.ace.integrationServer.type string ACE integration server type.
entity.ace.messageFlow.name string ACE message flow name.
entity.ace.messageFlow.state string ACE message flow state.
entity.ace.messageFlow.type string ACE message flow type.
entity.agent.bootVersion string Agent boot version.
entity.agent.capability string Agent capability.
entity.agent.gitops.commitHash string Agent GitOps commit hash.
entity.agent.gitops.commitMessage string Agent GitOps commit message.
entity.agent.gitops.remoteBranch string Agent GitOps remote branch.
entity.agent.gitops.remoteName string Agent GitOps remote name.
entity.agent.gitops.remoteUri string Agent GitOps remote URI.
entity.agent.logLevel string Agent log level.
entity.agent.mode string Agent mode (disabled, infrastructure or apm).
entity.agent.origin string Agent origin.
entity.agent.startType string Agent start type.
entity.agent.updateMode string Agent update mode.
entity.agent.version string Agent version.
entity.agent.vm.name string Agent VM name.
entity.agent.vm.version string Agent VM version.
entity.alicloud.oss string AliCloud OSS.
entity.alicloud.oss.bucket string AliCloud OSS bucket.
entity.alicloud.oss.instanceId string AliCloud OSS instance ID.
entity.alicloud.oss.userid string AliCloud OSS user instance.
entity.alicloud.rds.mysql string Apsara RDS MySQL.
entity.alicloud.rds.mysql.instanceName string Apsara RDS MySQL instance name.
entity.alicloud.rocketmq string AliCloud RocketMq.
entity.alicloud.rocketmq.group string AliCloud RocketMq group.
entity.alicloud.rocketmq.groupId string AliCloud RocketMq group ID.
entity.alicloud.rocketmq.instanceName string AliCloud RocketMq instance name.
entity.alicloud.rocketmq.topic string AliCloud RocketMq topic.
entity.argocd.application.name string Argo CD application name.
entity.aws.accountId string Amazon account ID.
entity.aws.apigateway.apiName string ApiGateway name.
entity.aws.apigateway.protocol string ApiGateway protocol.
entity.aws.appsync.apiName string AppSync API name.
entity.aws.arn string Amazon resource name.
entity.aws.autoscaling.groupName string Auto Scaling group name.
entity.aws.beanstalk.application string Beanstalk application name.
entity.aws.beanstalk.environment string Beanstalk environment name.
entity.aws.beanstalk.health string Beanstalk health status.
entity.aws.beanstalk.solution string Beanstalk solution stack.
entity.aws.beanstalk.version string Beanstalk version label.
entity.aws.cloudfront.domainName string CloudFront distribution domain name.
entity.aws.cloudfront.id string CloudFront distribution ID.
entity.aws.documentdb.cluster.name string AWS DocumentDb cluster name.
entity.aws.documentdb.clusterName string Amazon DocumentDB cluster name.
entity.aws.documentdb.elastic.cluster.name string AWS DocumentDb elastic cluster name.
entity.aws.documentdb.instance.identifier string AWS Redshift node ID.
entity.aws.ebs.encrypted string Volume encrypted.
entity.aws.ebs.mountedInstanceId string Mounted instance ID.
entity.aws.ebs.state string Volume state.
entity.aws.ebs.type string Volume type.
entity.aws.ebs.volumeId string Volume ID.
entity.aws.ecs.clusterArn string AWS ECS cluster ARN.
entity.aws.ecs.containerId string ID of the ECS container.
entity.aws.ecs.containerName string Names of the ECS container.
entity.aws.ecs.image string Name of the ECS Docker image.
entity.aws.ecs.taskDefinitionArn string AWS ECS task definition ARN.
entity.aws.ecs.taskDefinitionName string AWS ECS task definition name.
entity.aws.ecs.taskDefinitionVersion string AWS ECS task definition version.
entity.aws.ecs.taskDefinitionVersionArn string AWS ECS task definition version ARN.
entity.aws.elb.type string Elb type.
entity.aws.emr.clusterId string EMR cluster ID.
entity.aws.iotcore.endpoint string IoT core endpoint.
entity.aws.lambda.functionname string AWS Lambda Function Name.
entity.aws.lambda.runtime string AWS Lambda runtime.
entity.aws.lambda.version string AWS Lambda version.
entity.aws.metricstreams.exporterArn string The ARN of CloudWatch metric stream which exported the metrics.
entity.aws.metricstreams.namespace string AWS namespace.
entity.aws.mq.brokerName string Amazon MQ broker name.
entity.aws.mq.deploymentMode string Amazon MQ deployment mode.
entity.aws.mq.engineVersion string Amazon MQ engine version.
entity.aws.mq.instanceType string Amazon MQ instance type.
entity.aws.msk.broker.id string AWS MSK broker ID.
entity.aws.msk.cluster.name string AWS MSK cluster name.
entity.aws.msk.clusterName string Amazon MSK cluster name.
entity.aws.msk.instanceType string Amazon MSK Broker instance type.
entity.aws.rds.id string Database instance identifier.
entity.aws.rds.name string Database name.
entity.aws.redshift.cluster.name string Amazon Redshift cluster name.
entity.aws.redshift.node.id string AWS Redshift node ID.
entity.aws.redshift.nodeType string Amazon Redshift node type.
entity.aws.s3.bucketName string Amazon resource name.
entity.aws.timestream.databaseName string Timestream database name.
entity.azure.eventhub.cluster.name string Azure event hub cluster name.
entity.azure.id string Resource ID.
entity.azure.kind string The kind of the resource.
entity.azure.location string Resource location.
entity.azure.name string Instance or resource name.
entity.azure.resourcegroup string The resource group of the resource.
entity.azure.service.apim.api.name string The API name.
entity.azure.service.apim.name string The name of the API management service.
entity.azure.service.applicationgateway.name string The name of the application gateway service.
entity.azure.service.appservice.name string The name of the app service.
entity.azure.service.cosmosdb.kind string The kind of the Cosmos DB service.
entity.azure.service.cosmosdb.name string The name of the Cosmos DB service.
entity.azure.service.databricks.name string The name of the Databricks service.
entity.azure.service.datafactory.name string The name of the DataFactory service.
entity.azure.service.eventhub.cluster.namespace.name string Azure event hub clustered namespace name.
entity.azure.service.eventhub.namespace.name string Azure event hub namespace name.
entity.azure.service.function.name string Azure function name.
entity.azure.service.functionapp.name string The name of the Function APP.
entity.azure.service.keyvault.name string The name of the Keyvault service.
entity.azure.service.loadbalancer.name string The name of the LoadBalancer service.
entity.azure.service.machinelearning.name string The name of the machine learning service.
entity.azure.service.managedHSM.name string The name of the managed HSM service.
entity.azure.service.mysql.name string The name of the MySQL server.
entity.azure.service.postgresql.name string The name of the PostgreSQL service.
entity.azure.service.purview.name string The name of the Purview service.
entity.azure.service.rediscache.name string The name of the Redis Cache service.
entity.azure.service.servicebus.name string Azure service bus namespace name.
entity.azure.service.signalr.name string The name of the SignalR service.
entity.azure.service.sqldb.name string The name of the SQL database service.
entity.azure.service.sqlelasticpool.name string The name of the SQL elastic pool.
entity.azure.service.sqlserver.name string The name of the SQL database server.
entity.azure.service.storage.blob.name string Azure Blob name.
entity.azure.service.storage.blobCapabilities string Blob storage or ADLS Gen2.
entity.azure.service.storage.kind string The kind of the storage service.
entity.azure.service.storage.name string The name of the storage service.
entity.azure.service.storage.queue.name string Azure Queue name.
entity.azure.servicebus.queue.name string Azure service bus queue name.
entity.azure.servicebus.topic.name string Azure ServiceBus topic name.
entity.azure.subscription string The subscription ID of the resource.
entity.azure.type string Instance or resource type.
entity.biztalk.application string BizTalk application.
entity.biztalk.group string BizTalk server group.
entity.cassandra.cluster.name string Cassandra cluster name.
entity.ceph.cluster.name string Ceph cluster name.
entity.clickhouse.cluster.name string Clickhouse cluster name.
entity.cloudfoundry.application.id string Cloud Foundry application ID.
entity.cloudfoundry.application.name string Cloud Foundry application name.
entity.cloudfoundry.organization.id string Cloud Foundry organization ID.
entity.cloudfoundry.organization.name string Cloud Foundry organization name.
entity.cloudfoundry.space.id string Cloud Foundry space ID.
entity.cloudfoundry.space.name string Cloud Foundry space name.
entity.clr.app.name string CLR app name.
entity.clr.dependency string Application dependencies and versions in the form module@version.
entity.clr.target string .Net Framework target version.
entity.clr.version string CLR runtime version.
entity.cockroach.cluster.name string CockroachDB cluster name.
entity.consul.cluster.name string Consul cluster name.
entity.containerd.containerId string ID of the containerd container.
entity.containerd.image string Name of the containerd image.
entity.containerd.label key_value Labels of the containerd container.
entity.containerd.name string Name of the containerd container.
entity.couchbase.bucket string Available buckets.
entity.couchbase.cluster.name string Couchbase cluster name.
entity.crio.containerId string ID of the CRI-O container.
entity.crio.image string Name of the CRI-O image.
entity.crio.label key_value Labels of the CRI-O container.
entity.crio.name string Name of the CRI-O container.
entity.crowdstrike.falcon.aid string The agent identifier.
entity.crowdstrike.falcon.rmfState string Whether the agent currently in a reduced functionality mode.
entity.crowdstrike.falcon.version string The current version of the agent.
entity.crystal.app.dependency string Application dependencies and versions in the form gem@version.
entity.crystal.app.name string Crystal app name.
entity.crystal.args string Crystal execution arguments.
entity.crystal.version string Crystal version.
entity.customentity.identifier key_value Identifiers of the custom entity.
entity.customentity.model.name string Model name.
entity.db2.name string db2 database name.
entity.docker.containerId string ID of the docker container.
entity.docker.containerName string Names of the docker container.
entity.docker.image string Name of the docker image.
entity.docker.label key_value Labels of the Docker container.
entity.drbd.connection.name string DRBD connection.
entity.drbd.device.name string DRBD device name.
entity.drbd.name string DRBD name.
entity.drbd.peerdevice.name string DRBD peer device name.
entity.drbd.resource.name string DRBD resource name.
entity.dropwizard.counter string Available Dropwizard counters. Deprecated
entity.dropwizard.gauge string Available Dropwizard gauges. Deprecated
entity.dropwizard.histogram string Available Dropwizard histograms. Deprecated
entity.dropwizard.meter string Available Dropwizard meters. Deprecated
entity.dropwizard.name string Dropwizard app name.
entity.dropwizard.timer string Available Dropwizard timers. Deprecated
entity.ec2.amiId string AMI ID.
entity.ec2.instanceId string Instance ID.
entity.ec2.ipv4 string IP V4.
entity.ec2.publicName string Public hostname.
entity.ec2.securityGroups string Security groups.
entity.ec2.type string EC2 instance type.
entity.elasticsearch.cluster.name string Elasticsearch cluster name.
entity.elasticsearch.id string Elasticsearch node id.
entity.elasticsearch.index string Available indices.
entity.elasticsearch.name string Elasticsearch node name.
entity.elasticsearch.type string Elasticsearch node type.
entity.elasticsearch.version string Version.
entity.fileMonitoring.condition.name string fileMonitoring condition name.
entity.finagle.counters string Finagle counters. Deprecated
entity.finagle.gauges string Finagle gauges. Deprecated
entity.finagle.histograms string Finagle histograms. Deprecated
entity.garden.containerId string ID of the garden container.
entity.garden.ip string IP of the garden container.
entity.gce.instanceId string Instance ID.
entity.gce.type string Instance type.
entity.gcp.cloudrun.service.name string GCP cloud run service.
entity.gcp.cloudrun.service.revision string GCP cloud run revision.
entity.gcp.datastore.projectId string Google Cloud Datastore project ID.
entity.gcp.datastore.projectNumber string Google Cloud Datastore project number.
entity.gcp.pubsub.projectId string Google Cloud PubSub project ID.
entity.gcp.pubsub.projectNumber string Google Cloud PubSub project Number.
entity.gcp.pubsub.subscription.name string Google Cloud PubSub subscription name.
entity.gcp.pubsub.topic.name string Google Cloud PubSub topic name.
entity.gcp.sql.name string Cloud SQL instance name.
entity.gcp.sql.tier string Cloud SQL instance tier.
entity.gcp.sql.version string Cloud SQL database version.
entity.gcp.storage.id string Cloud storage instance ID.
entity.gcp.storage.location string Cloud storage location.
entity.gcp.storage.name string Cloud storage instance name.
entity.gcp.storage.projectNumber string Cloud storage project number.
entity.go.app.name string Go app name.
entity.go.version string Go runtime version.
entity.haskell.programName string Program name.
entity.host.cpu.count long Number of CPUs.
entity.host.cpu.model string CPU model.
entity.host.fqdn string Fully qualified domain name.
entity.host.gpu.count long Number of GPUs.
entity.host.gpu.model string GPU model.
entity.host.ip string IP address, either IPv4 or IPv6.
entity.host.mac string MAC addresses. Deprecated
entity.host.memory long Available memory. Deprecated
entity.host.name string Host name.
entity.host.os.arch string Architecture.
entity.host.os.name string OS name.
entity.host.os.version string OS version.
entity.host.osVendorName string Os vendor name.
entity.host.service.displayname string Display name.
entity.host.service.servicename string Service name.
entity.ibm.openstack.name string IBM openstack name.
entity.ibm.openstack.region.name string IBM Openstack region name.
entity.ibmApiConnect.catalog.name string ibmApiConnect catalog name.
entity.ibmApiConnect.org.name string ibmApiConnect organisation name.
entity.ibmInfosphereCdc.name string IbmInfosphere CDC name.
entity.ibmInfosphereCdc.subscription.name string ibm Infosphere CDC subscription name.
entity.ibmdatapower.appliance.name string IBM DataPower appliance name.
entity.ibmdatapower.appliance.status string IBM DataPower appliance status.
entity.ibmdatapower.cluster.name string IBM DataPower cluster name.
entity.ibmdatapower.domain.name string IBM DataPower domain name.
entity.ibmdatapower.domain.quiesceState string IBM DataPower domain quiesce state.
entity.ibmdatapower.service.name string IBM DataPower service name.
entity.ibmdatapower.service.status string IBM DataPower service status.
entity.ibmi.activeJobs.hostname string Hostname of your IBM i instance.
entity.ibmi.activeJobs.partitionId string Partition ID of your IBM i instance.
entity.ibmi.auditJournal.hostname string Hostname of your IBM i instance.
entity.ibmi.auditJournal.partitionId string Partition ID of your IBM i instance.
entity.ibmi.db2.collectionServicesLibraryName string The library name which is used for Collection Services.
entity.ibmi.db2.hostname string Hostname of your IBM i Series instance where Db2 is running.
entity.ibmi.diskInfo.hostname string Hostname of your IBM i instance.
entity.ibmi.diskInfo.partitionId string Partition ID of your IBM i instance.
entity.ibmi.individualPtf.hostname string Hostname of your IBM i instance.
entity.ibmi.individualPtf.partitionId string Partition ID of your IBM i instance.
entity.ibmi.licensedProgram.hostname string Hostname of your IBM i instance.
entity.ibmi.licensedProgram.partitionId string Partition ID of your IBM i instance.
entity.ibmi.messageQueue.hostname string Hostname of your IBM i instance.
entity.ibmi.messageQueue.partitionId string Partition ID of your IBM i instance.
entity.ibmi.networkInfo.hostname string Hostname of your IBM i instance.
entity.ibmi.networkInfo.partitionId string Partition ID of your IBM i instance.
entity.ibmi.os.hostname string Hostname of your IBM i instance.
entity.ibmi.os.partitionId string Partition ID of your IBM i instance.
entity.ibmmq.channel.name string IBM MQ channel name.
entity.ibmmq.channel.type string IBM MQ channel type.
entity.ibmmq.cluster.name string IBM MQ cluster name.
entity.ibmmq.listener.name string IBM MQ listener name.
entity.ibmmq.mqttchannel.name string IBM MQ MQTT channel name.
entity.ibmmq.mqttchannel.type string IBM MQ MQTT channel type.
entity.ibmmq.qm.activeNode string The hostname of the IBM MQ queue manager running node.
entity.ibmmq.qm.name string IBM MQ queue manager name.
entity.ibmmq.qm.platform string IBM MQ queue manager platform.
entity.ibmmq.qm.status string IBM MQ queue manager status.
entity.ibmmq.qm.version string IBM MQ queue manager version.
entity.ibmmq.queue.baseQueueName string IBM MQ Alias Base queue name.
entity.ibmmq.queue.description string IBM MQ queue description.
entity.ibmmq.queue.name string IBM MQ queue name.
entity.ibmmq.queue.triggerControl string IBM MQ trigger control.
entity.ibmmq.queue.triggerType string IBM MQ trigger type.
entity.ibmmq.queue.type string IBM MQ queue type.
entity.ibmmq.queue.usage string IBM MQ queue usage.
entity.ibmmqmft.agent.name string IBM MQ managed file transfer agent name.
entity.ibmmqmft.monitor.name string IBM MQ managed file transfer monitor name.
entity.ibmmqmft.queuemanager.name string IBM MQ managed file transfer coordination queue manager name.
entity.ibmmqmft.zone.name string IBM MQ managed file transfer zone name.
entity.ibmopenstack.computeinstance.name string IbmOpenstack compute instance name.
entity.ibmopenstack.hypervisor.name string IbmOpenstack hypervisor name.
entity.ibmz.cics.region string Region of CICS for z/OS.
entity.ibmz.cics.systemid string System id of CICS for z/OS.
entity.ibmz.ctg.origin_node string origin_node of CTG for z/OS.
entity.ibmz.ctg.system_id string system_id of CTG for z/OS.
entity.ibmz.db2.mvssystem string Multiple virtual storage system name of Db2 for z/OS.
entity.ibmz.ims.imsid string IMS id of IMS for z/OS.
entity.ibmz.ims.imsplexname string IMSplexName of IMS for z/OS.
entity.ibmz.os.smfid string System management facilities id of z/OS.
entity.id id ID of the entity.
entity.jboss.connector string Connectors.
entity.jboss.deployment string Deployments.
entity.jboss.nodeName string JBoss node name.
entity.jboss.serverName string JBoss server name.
entity.jboss.servlet string Servlets.
entity.jvm.app.name string Application name as defined in the MANIFEST file or inferred from the command line.
entity.jvm.app.version string Application version as defined in the MANIFEST file.
entity.jvm.args string JVM arguments. For example, -Xmx512m.
entity.jvm.build string JVM build. For example, 25.102-b14.
entity.jvm.classpath string Classpath.
entity.jvm.dropwizard.counter string Available Dropwizard counters. Deprecated
entity.jvm.dropwizard.gauge string Available Dropwizard gauges. Deprecated
entity.jvm.dropwizard.histogram string Available Dropwizard histograms. Deprecated
entity.jvm.dropwizard.meter string Available Dropwizard meters. Deprecated
entity.jvm.dropwizard.timer string Available Dropwizard timers. Deprecated
entity.jvm.micrometer.counter string Available Micrometer counters. Deprecated
entity.jvm.micrometer.distributionSummary string Available Micrometer distribution summaries. Deprecated
entity.jvm.micrometer.functionCounter string Available Micrometer function counters. Deprecated
entity.jvm.micrometer.functionTimer string Available Micrometer function timers. Deprecated
entity.jvm.micrometer.gauge string Available Micrometer gauges. Deprecated
entity.jvm.micrometer.longTaskTimer string Available Micrometer long task timers. Deprecated
entity.jvm.micrometer.timeGauge string Available Micrometer time gauges. Deprecated
entity.jvm.micrometer.timer string Available Micrometer timers. Deprecated
entity.jvm.prometheus.counter string Available Prometheus counter metrics. Deprecated
entity.jvm.prometheus.gauge string Available Prometheus gauge metrics. Deprecated
entity.jvm.prometheus.gaugehistogram string Available Prometheus gauge histogram metrics. Deprecated
entity.jvm.prometheus.histogram string Available Prometheus histogram metrics. Deprecated
entity.jvm.prometheus.info string Available Prometheus info metrics. Deprecated
entity.jvm.prometheus.stateset string Available Prometheus state set metrics. Deprecated
entity.jvm.prometheus.summary string Available Prometheus summary metrics. Deprecated
entity.jvm.prometheus.unknown string Available Prometheus metrics with unknown type. Deprecated
entity.jvm.version string JVM version. For example, 1.8.0_102.
entity.kafka.cluster.name string Kafka cluster name.
entity.kafka.version string Version.
entity.kafkaconnect.cluster.name string Kafka Connect cluster name.
entity.kafkaconnect.connector.name string Kafka Connect worker connector name.
entity.kafkaconnect.task.name string Kafka Connect task name.
entity.kafkaconnect.version string Version.
entity.kubernetes.apiserver.counter string Available API server metrics counters.
entity.kubernetes.apiserver.gauge string Available API server metrics gauges.
entity.kubernetes.apiserver.histogram string Available API server metrics histograms.
entity.kubernetes.cluster.distribution string Kubernetes cluster distribution.
entity.kubernetes.cluster.label string Kubernetes cluster name.
entity.kubernetes.cluster.managedBy string Kubernetes cluster ManagedBy.
entity.kubernetes.cluster.uuid string Kubernetes cluster UUID.
entity.kubernetes.cluster.version string Kubernetes cluster Version.
entity.kubernetes.container.name string Kubernetes container name.
entity.kubernetes.container.restartCount long Kubernetes container restart count. Deprecated
entity.kubernetes.controllermanager.counter string Available Controller Manager metrics counters.
entity.kubernetes.controllermanager.gauge string Available Controller Manager metrics gauges.
entity.kubernetes.controllermanager.histogram string Available Controller Manager metrics histograms.
entity.kubernetes.cronjob.label key_value Labels of Cronjob.
entity.kubernetes.cronjob.name string Kubernetes CronJob name.
entity.kubernetes.cronjob.uid string Kubernetes CronJob UID.
entity.kubernetes.customresource.annotation key_value Annotations of Custom Resource.
entity.kubernetes.customresource.label key_value Labels of Custom Resource.
entity.kubernetes.customresource.name string Kubernetes Custom Resource name.
entity.kubernetes.customresource.uid string Uid of Custom Resource.
entity.kubernetes.customresourcedefinition.annotation key_value Annotations of Custom Resource Definition.
entity.kubernetes.customresourcedefinition.label key_value Labels of Custom Resource Definition.
entity.kubernetes.customresourcedefinition.name string Kubernetes Custom Resource Definition name.
entity.kubernetes.customresourcedefinition.uid string Uid of Custom Resource Definition.
entity.kubernetes.daemonset.annotations key_value Annotations of Daemonset.
entity.kubernetes.daemonset.label key_value Labels of Daemonset.
entity.kubernetes.daemonset.name string Kubernetes DaemonSet Name.
entity.kubernetes.daemonset.uid string Kubernetes DaemonSet UID.
entity.kubernetes.deployment.annotation key_value Annotations of Deployment.
entity.kubernetes.deployment.label key_value Labels of Deployment.
entity.kubernetes.deployment.name string Kubernetes Deployment name.
entity.kubernetes.deployment.uid string Kubernetes Deployment UID.
entity.kubernetes.etcd.counter string Available Etcd metrics counters.
entity.kubernetes.etcd.gauge string Available Etcd metrics gauges.
entity.kubernetes.etcd.histogram string Available Etcd metrics histograms.
entity.kubernetes.etcd.summary string Available Etcd metrics summaries.
entity.kubernetes.horizontalpodautoscaler.annotation key_value Annotations of HorizontalPodAutoscaler.
entity.kubernetes.horizontalpodautoscaler.label key_value Labels of HorizontalPodAutoscaler.
entity.kubernetes.horizontalpodautoscaler.name string Kubernetes HorizontalPodAutoscaler Name.
entity.kubernetes.horizontalpodautoscaler.uid string Kubernetes HorizontalPodAutoscaler UID.
entity.kubernetes.job.label key_value Labels of Job.
entity.kubernetes.job.name string Kubernetes Job Name.
entity.kubernetes.job.uid string Kubernetes Job UID.
entity.kubernetes.namespace string Kubernetes namespace name.
entity.kubernetes.namespace.annotation key_value Annotations of Namespace.
entity.kubernetes.namespace.labels key_value Labels of Namespace.
entity.kubernetes.namespace.uid string Kubernetes Namespace UID.
entity.kubernetes.node.annotation key_value Annotations of Node.
entity.kubernetes.node.externalIp string Kubernetes Node External IP.
entity.kubernetes.node.hostname string Kubernetes Node Hostname.
entity.kubernetes.node.internalIp string Kubernetes Node Internal IP.
entity.kubernetes.node.label key_value Labels of Node.
entity.kubernetes.node.name string Kubernetes Node name.
entity.kubernetes.node.uid string Kubernetes Node UID.
entity.kubernetes.persistentVolume.label key_value Labels of PersistentVolume.
entity.kubernetes.persistentVolume.storageClassName string Kubernetes PersistentVolume StorageClass name.
entity.kubernetes.persistentVolumeClaim.label key_value Labels of PersistentVolumeClaim.
entity.kubernetes.persistentVolumeClaim.name string Kubernetes PersistentVolumeClaim name.
entity.kubernetes.persistentVolumeClaim.storageClassName string Kubernetes PersistentVolumeClaim name.
entity.kubernetes.pod.annotation key_value Annotations of Pod.
entity.kubernetes.pod.label key_value Labels of Pod.
entity.kubernetes.pod.name string Kubernetes Pod name.
entity.kubernetes.pod.phase string Kubernetes Pod status.
entity.kubernetes.pod.uid string Kubernetes Pod UID.
entity.kubernetes.pod.volumeName string Volumes attached to the Pod.
entity.kubernetes.replicaSet.name string Kubernetes Replica Set name.
entity.kubernetes.replicationcontroller.name string Kubernetes Replication Controller name.
entity.kubernetes.scheduler.counter string Available scheduler metrics counters.
entity.kubernetes.scheduler.gauge string Available scheduler metrics gauges.
entity.kubernetes.scheduler.histogram string Available scheduler metrics histograms.
entity.kubernetes.service.uid string Kubernetes Service UID.
entity.kubernetes.statefulset.annotation key_value Annotations of StatefulSet.
entity.kubernetes.statefulset.label key_value Labels of StatefulSet.
entity.kubernetes.statefulset.name string Kubernetes StatefulSet name.
entity.kubernetes.statefulset.uid string Kubernetes StatefulSet UID.
entity.label string Label or name of the entity. Deprecated
entity.linuxkvmhypervisor.host.name string Linux KVM Hypervisor host.
entity.linuxkvmhypervisor.vm.name string Linux KVM Hypervisor virtual machine.
entity.lxc.ip string LXC container IP.
entity.lxc.name string LXC container name.
entity.lxc.networkInterface string LXC container network interface.
entity.lxc.privileged string LXC container is privileged.
entity.lxc.state string LXC container state.
entity.mapr.cluster.name string MapR cluster name.
entity.mapr.node.name string MapR node name.
entity.marathon.appId string Marathon application ID.
entity.mongodb.atlas.cluster.name string MongoDB Atlas cluster name.
entity.netcore.app.dependency string Application dependencies and versions in the form module@version.
entity.netcore.app.name string .Net Core app name.
entity.netcore.app.target string .Net Core target version.
entity.netcore.runtime.version string .Net Core runtime version.
entity.nginx.version string Nginx version.
entity.nodejs.app.dependency string Application dependencies and versions in the form module@version.
entity.nodejs.app.name string Application name.
entity.nodejs.app.version string Application version.
entity.nodejs.keyword string Keywords.
entity.nodejs.version string Version.
entity.nomad.allocName string Name of the nomad allocation.
entity.nomad.jobName string Name of the nomad job.
entity.nomad.taskName string Name of the nomad task.
entity.nutanix.datacenter.name string Nutanix datacenter.
entity.opc.name string Instance name.
entity.opc.type string Instance type.
entity.openshift.deploymentconfig.label key_value Labels of DeploymentConfig.
entity.openshift.deploymentconfig.name string Openshift DeploymentConfig name.
entity.openshift.deploymentconfig.namespace string Openshift DeploymentConfig Namespace. Deprecated
entity.openshift.deploymentconfig.uid string Openshift Deployment Config UID.
entity.otel.attribute key_value OpenTelemetry Resource Attribute.
entity.otel.gauge string OpenTelemetry Gauges. Deprecated
entity.otel.histogram string OpenTelemetry Histograms. Deprecated
entity.otel.sum string OpenTelemetry Sums. Deprecated
entity.otelhost.name string Name of the OpenTelemetry host.
entity.otelprocess.id string Process ID.
entity.phmc.console.name string pHMC console name.
entity.phmc.lpar.name string pHMC LPAR name.
entity.phmc.spp.name string pHMC SPPool name.
entity.phmc.system.name string pHMC system name.
entity.phmc.vios.name string pHMC system name.
entity.php.version string PHP version.
entity.physical.reference.id id Physical reference ID of the entity.
entity.ping.target string Ping target.
entity.ping.type string

Ping type.

Values: "http", and "icmp"

entity.pingdirectory.master string Server is master.
entity.pingdirectory.state string State of the server.
entity.pingdirectory.unsynchronized string Server is out of sync.
entity.pluginId id Plugin ID of the entity.
entity.podman.containerId string ID of the Podman container.
entity.podman.image string ID of the Podman image.
entity.podman.image_name string Name of the Podman image.
entity.podman.label key_value Labels of the Podman container.
entity.podman.name string Name of the Podman container.
entity.podman.restartCount long Container Restart Count. Deprecated
entity.podman.version string Version of the Podman container.
entity.powervc.computeinstance.name string PowerVC compute instance name.
entity.powervc.hypervisor.name string PowerVC hypervisor name.
entity.powervc.name string PowerVC name.
entity.powervc.region.name string PowerVC region name.
entity.process.args string Process arguments.
entity.process.exec string Process executable.
entity.process.id string Process ID.
entity.process.runsIn string

Whether a process is running in a Docker container.

Values: "docker"

entity.prometheus.counter string Available Prometheus counters. Deprecated
entity.prometheus.gauge string Available Prometheus gauges. Deprecated
entity.prometheus.histogram string Available Prometheus histograms. Deprecated
entity.prometheus.summary string Available Prometheus summaries. Deprecated
entity.prometheus.untyped string Available Prometheus untyped metrics. Deprecated
entity.python.app.name string Python app name.
entity.python.version string Python runtime version.
entity.rabbitmq.cluster.name string RabbitMQ cluster name.
entity.redis.cluster.name string Redis cluster name.
entity.redisenterprise.cluster.name string Redis Enterprise cluster name.
entity.redisenterprise.version string Redis Enterprise version.
entity.remote.host.cpu.count long Number of CPUs.
entity.remote.host.cpu.model string CPU model.
entity.remote.host.fqdn string Fully qualified domain name.
entity.remote.host.ip string IP address, either IPv4 or IPv6.
entity.remote.host.mac string MAC addresses. Deprecated
entity.remote.host.memory long Available memory. Deprecated
entity.remote.host.name string Host name.
entity.remote.host.os.arch string Architecture.
entity.remote.host.os.name string OS name.
entity.remote.host.os.version string OS version.
entity.remote.host.source string Source.
entity.rocketmq.broker.name string RocketMQ broker name.
entity.rocketmq.cluster.name string RocketMQ cluster name.
entity.rocketmq.topic.name string RocketMQ topic name.
entity.ruby.app.dependency string Application dependencies and versions in the form gem@version.
entity.ruby.app.name string Ruby app name.
entity.ruby.execArgs string Ruby execution arguments.
entity.ruby.version string Ruby version.
entity.selfType string

Type of the entity.

Values: "aws.s3", "containerd", "docker", "elasticsearch", "host", "ibmmq.cluster", "jvm", "kafka", "kubernetesCluster", "kubernetesPod", "nginx", "postgresql", "process", "rabbitmq", "redisCluster", and "springboot"

entity.snowflake.account string Snowflake account name.
entity.snowflake.organization.name string Snowflake organization name.
entity.springboot.name string SpringBoot application name.
entity.syntheticpop.locationDisplayName string Synthetic PoP location display name.
entity.syntheticpop.locationName string Synthetic PoP location name.
entity.syntheticpop.tenantType string Synthetic PoP tenant type, single or multi.
entity.syntheticpop.version string

Synthetic PoP chart version.

For example, 1.0.16.

entity.tag key_value Tags.
entity.tanzu.foundation.name string Tanzu foundation name.
entity.tibcoas.grid.name string Tibco ActiveSpaces data grid name.
entity.tibcoas.node.name string Tibco ActiveSpaces node name.
entity.tibcoas.proxy.name string Tibco ActiveSpaces proxy name.
entity.tibcobw.appinst.name string Application name.
entity.tibcobw.appnode.appnodename string The name of AppNode.
entity.tibcobw.appnode.appspace string The name of AppSpace.
entity.tibcobw.appnode.domainname string Tibco BW domain name.
entity.tibcobw.process.appname string Application name.
entity.tibcobw.process.modulename string Module name.
entity.tibcobw.process.name string Process name.
entity.tibcoems.queue.name string Name of the queue.
entity.tibcoems.serverName string Name of TIBCO EMS Server.
entity.tibcoems.topic.name string Name of the topic.
entity.tomcat.servlet string Servlets.
entity.tomcat.webapp string Web applications.
entity.tuxedo.domain.id string Oracle Tuxedo domain ID.
entity.tuxedo.domain.tuxconfig string Tuxedo Domain TUXCONFIG.
entity.tuxedo.ipcqueue.queueId string IPC queue id.
entity.tuxedo.ipcqueue.receiverPID string Process identifier of the last process that read from the queue.
entity.tuxedo.ipcqueue.receiverSrv string Receiver server name.
entity.tuxedo.ipcqueue.senderPID string Process identifier of the last process that wrote to the queue.
entity.tuxedo.ipcqueue.senderSrv string Sender server name.
entity.tuxedo.machine.lmid string Tuxedo machine logical identifier.
entity.tuxedo.machine.pmid string Tuxedo machine physical identifier.
entity.tuxedo.machine.role string The role of Tuxedo machine.
entity.tuxedo.machine.state string The state of Tuxedo machine.
entity.tuxedo.server.groupName string The group number of the Tuxedo server.
entity.tuxedo.server.groupNo string The group number of the Tuxedo server.
entity.tuxedo.server.id string Tuxedo server ID.
entity.tuxedo.server.lmid string The logical machine identifier of the Tuxedo server.
entity.tuxedo.server.name string Tuxedo server name.
entity.tuxedo.server.state string The state of Tuxedo server.
entity.tuxedoapp.application.name string Tuxedo application name.
entity.tuxedoapp.name string Tuxedo application name.
entity.tuxedoapp.serviceBrokerProject.name string Service Broker Project name.
entity.tuxedoapp.tuxedoService.name string Tuxedo service name.
entity.type string

Type of entity or type of an entity directly related to it.

Values: "aws.s3", "containerd", "docker", "elasticsearch", "host", "ibmmq.cluster", "jvm", "kafka", "kubernetesCluster", "kubernetesPod", "nginx", "postgresql", "process", "rabbitmq", "redisCluster", and "springboot"

entity.vsphere.datacenter.name string vSphere datacenter name.
entity.vsphere.datacenter.version string vSphere datacenter version.
entity.vsphere.esxihost.name string vSphere ESXi host name.
entity.vsphere.vm.name string vSphere virtual machine name.
entity.weblogic.port string Port.
entity.websphere.cellName string Websphere cell name.
entity.websphere.ejbModules string Deployed EJB modules.
entity.websphere.nodeName string WebSphere node name.
entity.websphere.serverName string WebSphere server name.
entity.websphere.version string WebSphere version.
entity.websphere.webModules string Deployed web modules.
entity.webspheredmgr.dmgr.cellName string Websphere deployment manager cell name.
entity.webspheredmgr.dmgr.serverName string WebSphere deployment manager server name.
entity.webspheredmgr.dmgr.version string WebSphere deployment manager version.
entity.websphereliberty.name string WebSphere liberty server name.
entity.websphereliberty.version string WebSphere liberty version.
entity.windowshypervisor.host.name string WindowsHypervisor host.
entity.windowshypervisor.vm.name string WindowsHypervisor VM.
entity.xenserver.host.name string XenServer host.
entity.xenserver.vm.name string XenServer VM.
entity.zhmc.console.name string zHMC console name.
entity.zhmc.cpc.name string zHMC Cpc name.
entity.zone string Availability or custom zone.

Application monitoring

Keyword Data type Description
entity.application.id id The ID of the application.
entity.application.name string The name of the application.
entity.endpoint.id id The ID of the endpoint.
entity.endpoint.name string The name of the endpoint.
entity.selfType string

Type of entity.

Values: "application", "service", and "endpoint"

entity.service.id id The ID of the service.
entity.service.name string The name of the service.
entity.type string

Type of entity or type of an entity directly related to it.

Values: "application", "service", and "endpoint"

Events

Keyword Data type Description
event.config_entity string Search events by its configuration (specificationID) and entity (snapshotId) combination.
event.configuration string

Search events by the type of configuration.

Values: "Application Smart Alert", "Built-In Event", "Change Event", "Custom Event", "Infrastructure Smart Alert", "Log Smart Alert", "Mobile Smart Alert", "SLO Smart Alert", "Sensor Event", "Synthetics Smart Alert", and "Website Smart Alert"

event.cve.severity string Event CVE severity.
event.entity.label string Entity label.
event.hostId string Host ID associated to problem.
event.id id Event ID.
event.isTransient bool

Transient Event Tag.

Values: "false", and "true"

event.pluginId string Plugin ID associated to problem.
event.rca.failure string

Reason for event to not have an associated RCA found.

Values: "no_calls", "no_calls_after_filter", and "not_enough_application_impact"

event.rca.found bool

Event RCA found.

Values: "false", and "true"

event.severity string

Problem severity.

Values: "critical", and "warning"

event.source string

Event source.

Values: "application", "endpoint", "infra", "log", "mobileApp", "service", "synthetic", and "website"

event.specification.id string Event specification ID.
event.state string

Event state.

Values: "closed", "manually_closed", and "open"

event.steadyId string Steady ID associated to problem.
event.text string Event description.
event.type string

Event type.

Values: "change", "changeAndPresence", "critical", "event", "incident", "issue", "monitoringIssue", "objectiveViolation", "offline", "online", and "warning"

Known limitations

Syntax constraints

  • White space is not allowed between the ! and the query to be negated. Use !<query> or NOT <query> instead.
  • When multiple of the same entity.application.name, entity.service.name, entity.endpoint.name Dynamic Focus keywords are used together, they can be joined only by the OR operator. For example, the queries entity.application.name:foo AND entity.application.name:bar and entity.application.name:foo entity.application.name:bar are not supported. The query entity.application.name:foo OR entity.application.name:bar is supported.
  • When multiple of different entity.application.name, entity.service.name, entity.endpoint.name Dynamic Focus keywords are used together, they can be joined only by the AND operator. For example, the query entity.application.name:foo OR entity.service.name:bar is not supported, whereas the query entity.application.name:foo AND entity.service.name:bar is supported.
  • The queries that contain a negation of the application, service, or endpoint name are not supported. Therefore, NOT entity.application.name:foo, !entity.service.name:bar, and NOT entity.endpoint.name:foobar are invalid. However, you can filter out events of an application, service, or endpoint by using NOT event.entity.label:foo instead.
  • The Dynamic Focus queries entity.application.name:<term>, entity.service.name:<term>, and entity.endpoint.name:<term> are evaluated by using the string contains logic. For example, the Dynamic Focus query entity.application.name:shop also matches entity.application.name:shop-frontend.
  • The Dynamic Focus query keywords entity.application.name, entity.service.name, and entity.endpoint.name are supported only in Boolean queries (see Boolean logic constraints), term queries, phrase queries, and prefix queries.

Query limitations

  • Dynamic Focus queries on event.text that contains hyphens might return unexpected results. For example, the event.text:"foo-bar-random" query returns the events that contain just foo,bar or random due to tokenization of the Lucene analyzer.
  • When you search with most Kubernetes keywords, you can't select Host or Availability Zone type entities. As an example, the entity.kubernetes.deployment.name:my-K8s-deployment AND entity.selfType:host query does not return any host. In contrast, the entity.kubernetes.deployment.name:my-K8s-deployment AND entity.selfType:docker query returns all Docker containers that are related to the deployment. However, you can use a few Kubernetes keywords entity.kubernetes.cluster.* and entity.kubernetes.node.* to select Host entities. For example, to return all the related hosts of the cluster, use the entity.kubernetes.cluster.label:my-K8s-cluster AND entity.selfType:host query.

FAQ

Using wildcard (*) inside double quotation marks ("") does not yield expected results.

No matches are returned because the * symbol is evaluated as a character and not as a wildcard in this case. According to the Lucene specification, single and multiple character wildcard searches in phrase queries are not supported. A phrase query is a group of words that are surrounded by double quotation marks, such as event.text:"something bad happened".

Using wildcard (*) in entity.service.name queries does not return expected results.

The query did not return any results because the asterisk (*) symbol is treated as a character and not as a wildcard. The entity.service.name query internally uses the contains operator to search for matching services. For example, the entity.service.name:proxy query returns all the services that contain the name proxy.

I am getting search result counts, which seem inconsistent.

Sometimes, the result counts might be confusing. For instance, when you search within the Infrastructure map, the searches within the views can match more entities than that are visible within the views, such as services, which are not visible in the Infrastructure map.

What fields are searched when I do not specify any fields in the search query?

When you don't specify any fields in a search query, Dynamic Focus targets the current context to provide meaningful results. This means that it searches the entity fields when you are on the infrastructure map view and searches event data when you are on the event view.

What is the difference between entity.selfType and entity.type?

Searching with entity.selfType limits the search results to the entity that is searched for. Searching with entity.type includes all the children of the entity that is searched for. For example, when you search with entity.selfType:host, the Infrastructure map shows only the host entities and all parent entities, like the zone. But when you search with entity.type:host, the search results include what is running on the host, such as webservers and databases. However, both entity.type and entity.selfType yield the same results for entity types of the application perspectives. For example, when you use the entity.type:endpoint query in the events view, the list contains only the events that are detected on endpoint entities.