You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2020/10/22 11:41:24 UTC

[camel] branch camel-3.4.x updated: CAMEL-15710: Initial support for Open Tracing integration with third-party tracing (#4490)

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

davsclaus pushed a commit to branch camel-3.4.x
in repository https://gitbox.apache.org/repos/asf/camel.git


The following commit(s) were added to refs/heads/camel-3.4.x by this push:
     new 232835b  CAMEL-15710: Initial support for Open Tracing integration with third-party tracing (#4490)
232835b is described below

commit 232835b621e5c8661562af6fb5717198f74d2c1f
Author: Bogdan Ilchyshyn <or...@users.noreply.github.com>
AuthorDate: Thu Oct 22 22:41:02 2020 +1100

    CAMEL-15710: Initial support for Open Tracing integration with third-party tracing (#4490)
    
    Co-authored-by: Bogdan <il...@crxmarkets.com>
---
 .../camel/opentracing/OpenTracingTracer.java       |   7 ++
 .../ThirdPartyInstrumentationIntegrationTest.java  | 138 +++++++++++++++++++++
 2 files changed, 145 insertions(+)

diff --git a/components/camel-opentracing/src/main/java/org/apache/camel/opentracing/OpenTracingTracer.java b/components/camel-opentracing/src/main/java/org/apache/camel/opentracing/OpenTracingTracer.java
index 822b654..4f170fa 100644
--- a/components/camel-opentracing/src/main/java/org/apache/camel/opentracing/OpenTracingTracer.java
+++ b/components/camel-opentracing/src/main/java/org/apache/camel/opentracing/OpenTracingTracer.java
@@ -16,6 +16,7 @@
  */
 package org.apache.camel.opentracing;
 
+import io.opentracing.Scope;
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Map;
@@ -270,6 +271,9 @@ public class OpenTracingTracer extends ServiceSupport implements RoutePolicyFact
                     sd.pre(span, ese.getExchange(), ese.getEndpoint());
                     tracer.inject(span.context(), Format.Builtin.TEXT_MAP, sd.getInjectAdapter(ese.getExchange().getIn().getHeaders(), encoding));
                     ActiveSpanManager.activate(ese.getExchange(), span);
+                    Scope scope = tracer.activateSpan(span);
+                    // TODO: this seems to be better encapsulated in ActiveSpanManager, but how to pass tracer without breaking public API?
+                    ese.getExchange().setProperty("OpenTracing.activeScope", scope);
 
                     if (LOG.isTraceEnabled()) {
                         LOG.trace("OpenTracing: start client span={}", span);
@@ -288,6 +292,9 @@ public class OpenTracingTracer extends ServiceSupport implements RoutePolicyFact
                         sd.post(span, ese.getExchange(), ese.getEndpoint());
                         span.finish();
                         ActiveSpanManager.deactivate(ese.getExchange());
+                        // TODO: this seems to be better encapsulated in ActiveSpanManager, but how to pass tracer without breaking public API?
+                        Scope scope = ese.getExchange().getProperty("OpenTracing.activeScope", Scope.class);
+                        scope.close();
                     } else {
                         LOG.warn("OpenTracing: could not find managed span for exchange={}", ese.getExchange());
                     }
diff --git a/components/camel-opentracing/src/test/java/org/apache/camel/opentracing/ThirdPartyInstrumentationIntegrationTest.java b/components/camel-opentracing/src/test/java/org/apache/camel/opentracing/ThirdPartyInstrumentationIntegrationTest.java
new file mode 100644
index 0000000..c170525
--- /dev/null
+++ b/components/camel-opentracing/src/test/java/org/apache/camel/opentracing/ThirdPartyInstrumentationIntegrationTest.java
@@ -0,0 +1,138 @@
+/*
+ * 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.camel.opentracing;
+
+import io.opentracing.Scope;
+import io.opentracing.Span;
+import io.opentracing.Tracer;
+import io.opentracing.mock.MockSpan;
+import io.opentracing.mock.MockTracer;
+import io.opentracing.tag.Tags;
+import java.util.List;
+import java.util.Set;
+import java.util.stream.Collectors;
+import org.apache.camel.CamelContext;
+import org.apache.camel.Exchange;
+import org.apache.camel.RoutesBuilder;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.apache.camel.util.function.ThrowingRunnable;
+import org.junit.Test;
+
+/**
+ * Validates that {@link OpenTracingTracer} is compatible with third-party tracing solutions, i.e. integrates
+ * into active traces and allows others to integrate into Camel-initialized traces.
+ */
+public class ThirdPartyInstrumentationIntegrationTest extends CamelTestSupport {
+
+    private MockTracer tracer;
+
+    @Override
+    protected void doPostSetup() {
+        tracer.reset();
+    }
+
+    @Override
+    protected CamelContext createCamelContext() throws Exception {
+        CamelContext context = super.createCamelContext();
+
+        tracer = new MockTracer(MockTracer.Propagator.TEXT_MAP);
+
+        OpenTracingTracer openTracingTracer = new OpenTracingTracer();
+        openTracingTracer.setTracer(tracer);
+        openTracingTracer.init(context);
+
+        return context;
+    }
+
+    @Test
+    public void testBasicIntegrationUseCase() {
+        template.requestBody("direct:DirectProcessor", "");
+
+        List<MockSpan> actualSpans = tracer.finishedSpans();
+        assertEquals("Unexpected spans registered", 3, actualSpans.size());
+
+        Set<Long> traceIds = getTraceIds(actualSpans);
+        assertEquals("Expected all spans belonging to the same trace, but got: " + traceIds,
+                1, traceIds.size());
+    }
+
+    @Test
+    public void testTracingContextIsCleanedUp() {
+        // execute the route multiple times on the same thread to ensure active trace is reset upon route completion
+        template.requestBody("direct:DirectProcessor", "");
+        template.requestBody("direct:DirectProcessor", "");
+
+        List<MockSpan> actualSpans = tracer.finishedSpans();
+        assertEquals("Unexpected spans registered", 6, actualSpans.size());
+
+        Set<Long> traceIds = getTraceIds(actualSpans);
+        assertEquals("Expected all spans belonging to two traces, but got: " + traceIds,
+                2, traceIds.size());
+    }
+
+    @Test
+    public void testCamelIntegratesIntoActiveTrace() {
+        executeInThirdPartySpan(() -> template.requestBody("direct:DirectProcessor", ""));
+
+        List<MockSpan> actualSpans = tracer.finishedSpans();
+        assertEquals("Unexpected spans registered", 4, actualSpans.size());
+
+        Set<Long> traceIds = getTraceIds(actualSpans);
+        assertEquals("Expected all spans belonging to the same trace, but got: " + traceIds,
+                1, traceIds.size());
+    }
+
+    private Set<Long> getTraceIds(List<MockSpan> actualSpans) {
+        return actualSpans.stream()
+                .map(span -> span.context().traceId())
+                .collect(Collectors.toSet());
+    }
+
+    /**
+     * Simulates third-party instrumentation
+     */
+    private void tracingProcessor(Exchange exchange) {
+        executeInThirdPartySpan(() -> Thread.sleep(1000));
+    }
+
+    private void executeInThirdPartySpan(ThrowingRunnable<Exception> closure) {
+        Tracer.SpanBuilder spanBuilder = tracer.buildSpan("third-party-span")
+                .withTag(Tags.SPAN_KIND.getKey(), Tags.SPAN_KIND_SERVER);
+        Span span = spanBuilder.start();
+        try (Scope ignored = tracer.activateSpan(span)) {
+            closure.run();
+        }
+        catch (Exception e) {
+            Tags.ERROR.set(span, Boolean.TRUE);
+        }
+        finally {
+            span.finish();
+        }
+    }
+
+    @Override
+    protected RoutesBuilder createRouteBuilder() {
+        return new RouteBuilder() {
+            @Override
+            public void configure() {
+                from("direct:DirectProcessor")
+                        .process(ThirdPartyInstrumentationIntegrationTest.this::tracingProcessor);
+            }
+        };
+    }
+}