You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ja...@apache.org on 2020/09/02 11:56:23 UTC

[camel-quarkus] 08/13: Fix route template in camel-quarkus (#1621)

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

jamesnetherton pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit df18e9eaf990894a50d0a8d81e07ed7c9ff96fd9
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Wed Aug 26 13:37:43 2020 +0200

    Fix route template in camel-quarkus (#1621)
---
 .../camel/quarkus/core/FastCamelContext.java       |  11 +++
 .../deployment/CamelMainRouteTemplateTest.java     | 100 +++++++++++++++++++++
 2 files changed, 111 insertions(+)

diff --git a/extensions-core/core/runtime/src/main/java/org/apache/camel/quarkus/core/FastCamelContext.java b/extensions-core/core/runtime/src/main/java/org/apache/camel/quarkus/core/FastCamelContext.java
index a41d181..b212414 100644
--- a/extensions-core/core/runtime/src/main/java/org/apache/camel/quarkus/core/FastCamelContext.java
+++ b/extensions-core/core/runtime/src/main/java/org/apache/camel/quarkus/core/FastCamelContext.java
@@ -21,6 +21,7 @@ import java.io.InputStream;
 import java.util.Collection;
 import java.util.List;
 import java.util.Map;
+import java.util.Properties;
 import java.util.concurrent.ExecutorService;
 import java.util.function.Function;
 
@@ -705,6 +706,8 @@ public class FastCamelContext extends AbstractCamelContext implements CatalogCam
         if (!alreadyStartingRoutes) {
             setStartingRoutes(true);
         }
+
+        PropertiesComponent pc = getCamelContextReference().getPropertiesComponent();
         try {
             RouteDefinitionHelper.forceAssignIds(getCamelContextReference(), routeDefinitions);
             for (RouteDefinition routeDefinition : routeDefinitions) {
@@ -715,6 +718,14 @@ public class FastCamelContext extends AbstractCamelContext implements CatalogCam
                             "duplicate id detected: " + duplicate + ". Please correct ids to be unique among all your routes.");
                 }
 
+                // if the route definition was created via a route template then we need to prepare its parameters when the route is being created and started
+                if (routeDefinition.isTemplate() != null && routeDefinition.isTemplate()
+                        && routeDefinition.getTemplateParameters() != null) {
+                    Properties prop = new Properties();
+                    prop.putAll(routeDefinition.getTemplateParameters());
+                    pc.setLocalProperties(prop);
+                }
+
                 // must ensure route is prepared, before we can start it
                 if (!routeDefinition.isPrepared()) {
                     RouteDefinitionHelper.prepareRoute(getCamelContextReference(), routeDefinition);
diff --git a/extensions-core/main/deployment/src/test/java/org/apache/camel/quarkus/main/deployment/CamelMainRouteTemplateTest.java b/extensions-core/main/deployment/src/test/java/org/apache/camel/quarkus/main/deployment/CamelMainRouteTemplateTest.java
new file mode 100644
index 0000000..3925fb2
--- /dev/null
+++ b/extensions-core/main/deployment/src/test/java/org/apache/camel/quarkus/main/deployment/CamelMainRouteTemplateTest.java
@@ -0,0 +1,100 @@
+/*
+ * 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.quarkus.main.deployment;
+
+import java.io.IOException;
+import java.io.StringWriter;
+import java.io.Writer;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+
+import javax.enterprise.context.ApplicationScoped;
+import javax.inject.Inject;
+import javax.inject.Named;
+
+import io.quarkus.test.QuarkusUnitTest;
+import org.apache.camel.FluentProducerTemplate;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.quarkus.main.CamelMain;
+import org.jboss.shrinkwrap.api.ShrinkWrap;
+import org.jboss.shrinkwrap.api.asset.Asset;
+import org.jboss.shrinkwrap.api.asset.StringAsset;
+import org.jboss.shrinkwrap.api.spec.JavaArchive;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.RegisterExtension;
+
+import static org.assertj.core.api.Assertions.assertThat;
+
+public class CamelMainRouteTemplateTest {
+    @RegisterExtension
+    static final QuarkusUnitTest CONFIG = new QuarkusUnitTest()
+            .setArchiveProducer(() -> ShrinkWrap.create(JavaArchive.class)
+                    .addAsResource(applicationProperties(), "application.properties"));
+
+    @Inject
+    CamelMain main;
+
+    public static Asset applicationProperties() {
+        Writer writer = new StringWriter();
+
+        Properties props = new Properties();
+        props.setProperty("quarkus.banner.enabled", "false");
+
+        try {
+            props.store(writer, "");
+        } catch (IOException e) {
+            throw new RuntimeException(e);
+        }
+
+        return new StringAsset(writer.toString());
+    }
+
+    @Test
+    public void testRouteTemplate() throws Exception {
+        Map<String, Object> parameters = new HashMap<>();
+        parameters.put("foo", "one");
+        parameters.put("greeting", "Camel");
+        main.getCamelContext().addRouteFromTemplate("first", "myTemplate", parameters);
+
+        parameters.put("foo", "two");
+        parameters.put("greeting", "World");
+        main.getCamelContext().addRouteFromTemplate("second", "myTemplate", parameters);
+
+        assertThat(main.getCamelContext().getRoutes()).isNotEmpty();
+        assertThat(main.configure().getRoutesBuilders()).isNotEmpty();
+
+        FluentProducerTemplate p = main.getCamelContext().createFluentProducerTemplate();
+        String out1 = p.withBody("body1").to("direct:one").request(String.class);
+        String out2 = p.withBody("body2").to("direct:two").request(String.class);
+        assertThat(out1).isEqualTo("Hello Camel");
+        assertThat(out2).isEqualTo("Hello World");
+    }
+
+    @Named("my-template")
+    @ApplicationScoped
+    public static class MyTemplate extends RouteBuilder {
+        @Override
+        public void configure() throws Exception {
+            routeTemplate("myTemplate").templateParameter("foo").templateParameter("greeting")
+                    .description("Route saying {{greeting}}")
+                    .from("direct:{{foo}}")
+                    .transform(simple("Hello {{greeting}}"));
+        }
+    }
+
+}