You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@skywalking.apache.org by ke...@apache.org on 2021/02/20 08:12:02 UTC

[skywalking] branch master updated: Add E2E test for VM monitoring that the metrics from Promethues node-exporter via OTEL. (#6404)

This is an automated email from the ASF dual-hosted git repository.

kezhenxu94 pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/skywalking.git


The following commit(s) were added to refs/heads/master by this push:
     new 6c6a8a7  Add E2E test for VM monitoring that the metrics from Promethues node-exporter via OTEL. (#6404)
6c6a8a7 is described below

commit 6c6a8a7109c9a5a0dc173d8424ce45dec1da9f9e
Author: wankai123 <wa...@foxmail.com>
AuthorDate: Sat Feb 20 16:11:44 2021 +0800

    Add E2E test for VM monitoring that the metrics from Promethues node-exporter via OTEL. (#6404)
---
 CHANGES.md                                         |   1 +
 .../apache/skywalking/e2e/SimpleQueryClient.java   |   3 +-
 .../skywalking/e2e/metrics/MetricsQuery.java       |  18 ++++
 .../skywalking/e2e/metrics/ReadMetricsQuery.java   |   2 +
 .../e2e-data/src/main/resources/read-metrics.gql   |   2 +-
 .../docker/promOtelVM/Dockerfile.nodeExporter}     |  25 ++---
 .../e2e-test/docker/promOtelVM/docker-compose.yml  |  56 ++++++++++
 .../docker/promOtelVM/otel-collector-config.yaml}  |  45 ++++----
 .../skywalking/e2e/promOtelVM/PromOtelVME2E.java   | 115 +++++++++++++++++++++
 .../resources/expected/promOtelVM/services.yml}    |  22 +---
 10 files changed, 230 insertions(+), 59 deletions(-)

diff --git a/CHANGES.md b/CHANGES.md
index ce8c9fa..81a5479 100644
--- a/CHANGES.md
+++ b/CHANGES.md
@@ -6,6 +6,7 @@ Release Notes.
 ------------------
 #### Project
 * Update frontend-maven-plugin to 1.11.0, for Download node x64 binary on Apple Silicon.
+* Add E2E test for VM monitoring that metrics from Promethues node-exporter.
 
 #### Java Agent
 * Remove invalid mysql configuration in agent.config.
diff --git a/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/SimpleQueryClient.java b/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/SimpleQueryClient.java
index b704bb6..1de1135 100644
--- a/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/SimpleQueryClient.java
+++ b/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/SimpleQueryClient.java
@@ -329,7 +329,8 @@ public class SimpleQueryClient {
                                             .replace("{end}", query.end())
                                             .replace("{metricsName}", query.metricsName())
                                             .replace("{serviceName}", query.serviceName())
-                                            .replace("{instanceName}", query.instanceName());
+                                            .replace("{instanceName}", query.instanceName())
+                                            .replace("{scope}", query.scope());
         LOGGER.info("Query: {}", queryString);
         final ResponseEntity<GQLResponse<ReadMetricsData>> responseEntity = restTemplate.exchange(
             new RequestEntity<>(queryString, HttpMethod.POST, URI.create(endpointUrl)),
diff --git a/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/MetricsQuery.java b/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/MetricsQuery.java
index 50debe6..e50d2f6 100644
--- a/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/MetricsQuery.java
+++ b/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/MetricsQuery.java
@@ -160,4 +160,22 @@ public class MetricsQuery extends AbstractQuery<MetricsQuery> {
             .put("meter_agent_vfs_fs_size", Arrays.asList("/-total"))
             .build();
 
+    public static String[] SIMPLE_PROM_VM_METERS = {
+        "meter_vm_memory_used",
+        "meter_vm_memory_total",
+        "meter_vm_memory_available",
+        "meter_vm_disk_written",
+        "meter_vm_network_transmit",
+        "meter_vm_tcp_curr_estab",
+        "meter_vm_tcp_alloc",
+        "meter_vm_sockets_used",
+        "meter_vm_udp_inuse",
+        "meter_vm_filefd_allocated"
+    };
+
+    public static Map<String, List<String>> SIMPLE_PROM_VM_LABELED_METERS = ImmutableMap.<String, List<String>>builder()
+        .put("meter_vm_cpu_average_used", Arrays.asList("idle"))
+        .put("meter_vm_filesystem_percentage", Arrays.asList("/etc/hosts"))
+        .build();
 }
+
diff --git a/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/ReadMetricsQuery.java b/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/ReadMetricsQuery.java
index f974d4a..da24191 100644
--- a/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/ReadMetricsQuery.java
+++ b/test/e2e/e2e-data/src/main/java/org/apache/skywalking/e2e/metrics/ReadMetricsQuery.java
@@ -40,4 +40,6 @@ public class ReadMetricsQuery extends AbstractQuery<ReadMetricsQuery> {
 
     private String instanceName;
 
+    private String scope = "ServiceInstance";
+
 }
diff --git a/test/e2e/e2e-data/src/main/resources/read-metrics.gql b/test/e2e/e2e-data/src/main/resources/read-metrics.gql
index 5889e80..c54fbeb 100644
--- a/test/e2e/e2e-data/src/main/resources/read-metrics.gql
+++ b/test/e2e/e2e-data/src/main/resources/read-metrics.gql
@@ -24,7 +24,7 @@
       "condition":{
          "name":"{metricsName}",
          "entity":{
-            "scope":"ServiceInstance",
+            "scope":"{scope}",
             "serviceName":"{serviceName}",
             "serviceInstanceName":"{instanceName}",
             "normal":true
diff --git a/test/e2e/e2e-data/src/main/resources/read-metrics.gql b/test/e2e/e2e-test/docker/promOtelVM/Dockerfile.nodeExporter
similarity index 56%
copy from test/e2e/e2e-data/src/main/resources/read-metrics.gql
copy to test/e2e/e2e-test/docker/promOtelVM/Dockerfile.nodeExporter
index 5889e80..a5129a5 100644
--- a/test/e2e/e2e-data/src/main/resources/read-metrics.gql
+++ b/test/e2e/e2e-test/docker/promOtelVM/Dockerfile.nodeExporter
@@ -13,22 +13,9 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-{
-   "query":"query queryData($condition: MetricsCondition!, $duration: Duration!) {\n  readMetricsValues: readMetricsValues(condition: $condition, duration: $duration) {\n    label\n    values {\n      values {value}\n    }\n  }}",
-   "variables":{
-      "duration":{
-         "start":"{start}",
-         "end":"{end}",
-         "step":"{step}"
-      },
-      "condition":{
-         "name":"{metricsName}",
-         "entity":{
-            "scope":"ServiceInstance",
-            "serviceName":"{serviceName}",
-            "serviceInstanceName":"{instanceName}",
-            "normal":true
-         }
-      }
-   }
-}
\ No newline at end of file
+FROM ubuntu:latest
+
+ADD https://github.com/prometheus/node_exporter/releases/download/v1.0.1/node_exporter-1.0.1.linux-amd64.tar.gz ./
+RUN tar xvfz node_exporter-1.0.1.linux-amd64.tar.gz
+WORKDIR /node_exporter-1.0.1.linux-amd64
+CMD ["./node_exporter"]
\ No newline at end of file
diff --git a/test/e2e/e2e-test/docker/promOtelVM/docker-compose.yml b/test/e2e/e2e-test/docker/promOtelVM/docker-compose.yml
new file mode 100644
index 0000000..988f57a
--- /dev/null
+++ b/test/e2e/e2e-test/docker/promOtelVM/docker-compose.yml
@@ -0,0 +1,56 @@
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+version: '2.1'
+
+services:
+  oap:
+    extends:
+      file: ../base-compose.yml
+      service: oap
+    environment:
+      SW_OTEL_RECEIVER: default
+      SW_OTEL_RECEIVER_ENABLED_OC_RULES: vm
+  node-exporter:
+    build:
+      context: .
+      dockerfile: Dockerfile.nodeExporter
+    networks:
+      - e2e
+    expose:
+      - 9100
+  otel-collector:
+    image: otel/opentelemetry-collector:0.19.0
+    networks:
+      - e2e
+    command: [ "--config=/etc/otel-collector-config.yaml" ]
+    volumes:
+      - ./otel-collector-config.yaml:/etc/otel-collector-config.yaml
+    expose:
+      - 55678
+    depends_on:
+      oap:
+        condition: service_healthy
+
+  ui:
+    extends:
+      file: ../base-compose.yml
+      service: ui
+    depends_on:
+      oap:
+        condition: service_healthy
+
+networks:
+  e2e:
diff --git a/test/e2e/e2e-data/src/main/resources/read-metrics.gql b/test/e2e/e2e-test/docker/promOtelVM/otel-collector-config.yaml
similarity index 56%
copy from test/e2e/e2e-data/src/main/resources/read-metrics.gql
copy to test/e2e/e2e-test/docker/promOtelVM/otel-collector-config.yaml
index 5889e80..a9c18cc 100644
--- a/test/e2e/e2e-data/src/main/resources/read-metrics.gql
+++ b/test/e2e/e2e-test/docker/promOtelVM/otel-collector-config.yaml
@@ -13,22 +13,29 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-{
-   "query":"query queryData($condition: MetricsCondition!, $duration: Duration!) {\n  readMetricsValues: readMetricsValues(condition: $condition, duration: $duration) {\n    label\n    values {\n      values {value}\n    }\n  }}",
-   "variables":{
-      "duration":{
-         "start":"{start}",
-         "end":"{end}",
-         "step":"{step}"
-      },
-      "condition":{
-         "name":"{metricsName}",
-         "entity":{
-            "scope":"ServiceInstance",
-            "serviceName":"{serviceName}",
-            "serviceInstanceName":"{instanceName}",
-            "normal":true
-         }
-      }
-   }
-}
\ No newline at end of file
+receivers:
+  prometheus:
+    config:
+      scrape_configs:
+        - job_name: 'otel-collector'
+          scrape_interval: 10s
+          static_configs:
+            - targets: [ 'node-exporter:9100' ]
+
+processors:
+  batch:
+
+exporters:
+  opencensus:
+    endpoint: "oap:11800" # The OAP Server address
+    insecure: true
+  # Exports data to the console  
+  logging:
+    logLevel: debug
+
+service:
+  pipelines:
+    metrics:
+      receivers: [prometheus]
+      processors: [batch]
+      exporters: [opencensus,logging]
diff --git a/test/e2e/e2e-test/src/test/java/org/apache/skywalking/e2e/promOtelVM/PromOtelVME2E.java b/test/e2e/e2e-test/src/test/java/org/apache/skywalking/e2e/promOtelVM/PromOtelVME2E.java
new file mode 100644
index 0000000..62a8493
--- /dev/null
+++ b/test/e2e/e2e-test/src/test/java/org/apache/skywalking/e2e/promOtelVM/PromOtelVME2E.java
@@ -0,0 +1,115 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ *
+ */
+
+package org.apache.skywalking.e2e.promOtelVM;
+
+import java.util.List;
+import java.util.Map;
+import java.util.stream.Collectors;
+import lombok.extern.slf4j.Slf4j;
+import org.apache.skywalking.e2e.UIConfigurationManagementClient;
+import org.apache.skywalking.e2e.annotation.ContainerHostAndPort;
+import org.apache.skywalking.e2e.annotation.DockerCompose;
+import org.apache.skywalking.e2e.base.SkyWalkingE2E;
+import org.apache.skywalking.e2e.base.SkyWalkingTestAdapter;
+import org.apache.skywalking.e2e.common.HostAndPort;
+import org.apache.skywalking.e2e.metrics.AtLeastOneOfMetricsMatcher;
+import org.apache.skywalking.e2e.metrics.Metrics;
+import org.apache.skywalking.e2e.metrics.MetricsValueMatcher;
+import org.apache.skywalking.e2e.metrics.ReadLabeledMetricsQuery;
+import org.apache.skywalking.e2e.metrics.ReadMetrics;
+import org.apache.skywalking.e2e.metrics.ReadMetricsQuery;
+import org.apache.skywalking.e2e.retryable.RetryableTest;
+import org.apache.skywalking.e2e.service.Service;
+import org.apache.skywalking.e2e.service.ServicesMatcher;
+import org.apache.skywalking.e2e.service.ServicesQuery;
+import org.junit.jupiter.api.BeforeAll;
+import org.testcontainers.containers.DockerComposeContainer;
+
+import static org.apache.skywalking.e2e.metrics.MetricsQuery.SIMPLE_PROM_VM_LABELED_METERS;
+import static org.apache.skywalking.e2e.metrics.MetricsQuery.SIMPLE_PROM_VM_METERS;
+import static org.apache.skywalking.e2e.utils.Times.now;
+import static org.apache.skywalking.e2e.utils.Yamls.load;
+
+@Slf4j
+@SkyWalkingE2E
+public class PromOtelVME2E extends SkyWalkingTestAdapter {
+
+    @DockerCompose({"docker/promOtelVM/docker-compose.yml"})
+    private DockerComposeContainer<?> compose;
+
+    @ContainerHostAndPort(name = "ui", port = 8080)
+    private HostAndPort swWebappHostPort;
+
+    private UIConfigurationManagementClient graphql;
+
+    @BeforeAll
+    public void setUp() throws Exception {
+        graphql = new UIConfigurationManagementClient(swWebappHostPort.host(), swWebappHostPort.port());
+
+    }
+
+    @RetryableTest
+    void testMetrics() throws Exception {
+        List<Service> services = graphql.services(new ServicesQuery().start(startTime).end(now()));
+        services = services.stream().filter(s -> !s.getLabel().equals("oap::oap-server")).collect(Collectors.toList());
+        LOGGER.info("services: {}", services);
+        load("expected/promOtelVM/services.yml").as(ServicesMatcher.class).verify(services);
+        Service service = services.get(0);
+
+        for (String metricsName : SIMPLE_PROM_VM_METERS) {
+            LOGGER.info("verifying prom vm metrics: {}", metricsName);
+            ReadMetrics metrics = graphql.readMetrics(
+                new ReadMetricsQuery().stepByMinute()
+                                      .metricsName(metricsName)
+                                      .serviceName(service.getLabel())
+                                      .scope("Service")
+                                      .instanceName("")
+            );
+            LOGGER.info("prom vm metrics: {}", metrics);
+
+            final AtLeastOneOfMetricsMatcher instanceRespTimeMatcher = new AtLeastOneOfMetricsMatcher();
+            final MetricsValueMatcher greaterThanZero = new MetricsValueMatcher();
+            greaterThanZero.setValue("gt 0");
+            instanceRespTimeMatcher.setValue(greaterThanZero);
+            instanceRespTimeMatcher.verify(metrics.getValues());
+        }
+
+        for (Map.Entry<String, List<String>> entry : SIMPLE_PROM_VM_LABELED_METERS.entrySet()) {
+            String metricsName = entry.getKey();
+            List<String> labels = entry.getValue();
+            LOGGER.info("verifying prom vm labeledMetrics: {}", metricsName);
+            List<ReadMetrics> labeledMetrics = graphql.readLabeledMetrics(
+                new ReadLabeledMetricsQuery().stepByMinute().metricsName(metricsName)
+                                             .serviceName(service.getLabel()).scope("Service").instanceName("")
+                                             .labels(labels)
+            );
+            LOGGER.info("prom vm labeledMetrics: {}", labeledMetrics);
+
+            Metrics allValues = new Metrics();
+            for (ReadMetrics readMetrics : labeledMetrics) {
+                allValues.getValues().addAll(readMetrics.getValues().getValues());
+            }
+            final AtLeastOneOfMetricsMatcher instanceRespTimeMatcher = new AtLeastOneOfMetricsMatcher();
+            final MetricsValueMatcher greaterThanZero = new MetricsValueMatcher();
+            greaterThanZero.setValue("gt 0");
+            instanceRespTimeMatcher.setValue(greaterThanZero);
+            instanceRespTimeMatcher.verify(allValues);
+        }
+    }
+}
diff --git a/test/e2e/e2e-data/src/main/resources/read-metrics.gql b/test/e2e/e2e-test/src/test/resources/expected/promOtelVM/services.yml
similarity index 56%
copy from test/e2e/e2e-data/src/main/resources/read-metrics.gql
copy to test/e2e/e2e-test/src/test/resources/expected/promOtelVM/services.yml
index 5889e80..7e14dc8 100644
--- a/test/e2e/e2e-data/src/main/resources/read-metrics.gql
+++ b/test/e2e/e2e-test/src/test/resources/expected/promOtelVM/services.yml
@@ -13,22 +13,6 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-{
-   "query":"query queryData($condition: MetricsCondition!, $duration: Duration!) {\n  readMetricsValues: readMetricsValues(condition: $condition, duration: $duration) {\n    label\n    values {\n      values {value}\n    }\n  }}",
-   "variables":{
-      "duration":{
-         "start":"{start}",
-         "end":"{end}",
-         "step":"{step}"
-      },
-      "condition":{
-         "name":"{metricsName}",
-         "entity":{
-            "scope":"ServiceInstance",
-            "serviceName":"{serviceName}",
-            "serviceInstanceName":"{instanceName}",
-            "normal":true
-         }
-      }
-   }
-}
\ No newline at end of file
+services:
+  - key: not null
+    label: "vm::node-exporter"