You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ac...@apache.org on 2018/12/10 07:48:56 UTC

[camel] branch sandbox/camel-3.x updated (cf0186c -> 6752e17)

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

acosentino pushed a change to branch sandbox/camel-3.x
in repository https://gitbox.apache.org/repos/asf/camel.git.


    from cf0186c  Upgrade Jsch and related bundle to version 0.1.55
     new 1ecf8c5  CAMEL-12987: Ensure onContextStop is called on the OsgiServiceRegistry. (#2660)
     new 264ff91  CAMEL-12987: Fixed CS
     new 4475457  CAMEL-12987 - Fixed CS for imports
     new ee35eba  Upgrade Awaitility to version 3.1.5
     new e21f279  CAMEL-12985: TransactionErrorHandler fails if UnitOfWork is null
     new d576c09  CAMEL-12985: Added a test that fails on master
     new b323687  CAMEL-12985 - Fixed CS
     new 6752e17  CAMEL-12985 - Fixed backport from 2.x

The 8 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../camel/core/osgi/OsgiCamelContextHelper.java    | 21 ++++++++++----
 .../camel/core/osgi/OsgiDefaultCamelContext.java   | 14 ++--------
 .../apache/camel/core/osgi/OsgiTypeConverter.java  |  2 +-
 .../camel/core/osgi/utils/BundleContextUtils.java  |  2 +-
 .../camel/spring/spi/TransactionErrorHandler.java  | 12 ++++++--
 ...nterceptUsingAdviceWithSendToEndpointTest.java} | 32 ++++++++++++++++++----
 parent/pom.xml                                     |  2 +-
 .../camel-spring-boot-dependencies/pom.xml         |  2 +-
 8 files changed, 57 insertions(+), 30 deletions(-)
 copy components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/{TransactedInterceptSendToEndpointTest.java => TransactedInterceptUsingAdviceWithSendToEndpointTest.java} (69%)


[camel] 01/08: CAMEL-12987: Ensure onContextStop is called on the OsgiServiceRegistry. (#2660)

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 1ecf8c5632fecf64a27f4158c0436c0732b2b221
Author: Bob Paulin <bo...@bobpaulin.com>
AuthorDate: Sun Dec 9 03:52:27 2018 -0600

    CAMEL-12987: Ensure onContextStop is called on the OsgiServiceRegistry. (#2660)
---
 .../camel/core/osgi/OsgiCamelContextHelper.java     | 21 +++++++++++++++------
 .../camel/core/osgi/OsgiDefaultCamelContext.java    | 12 +-----------
 2 files changed, 16 insertions(+), 17 deletions(-)

diff --git a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java
index 08ff669..2b9b1fc 100644
--- a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java
+++ b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java
@@ -56,14 +56,23 @@ public final class OsgiCamelContextHelper {
     public static Registry wrapRegistry(CamelContext camelContext, Registry registry, BundleContext bundleContext) {
         ObjectHelper.notNull(bundleContext, "BundleContext");
 
-        LOG.debug("Setting up OSGi ServiceRegistry");
-        OsgiServiceRegistry osgiServiceRegistry = new OsgiServiceRegistry(bundleContext);
+        OsgiServiceRegistry osgiServiceRegistry = null;
+        Registry resultingRegistry = registry;
+        if(registry instanceof OsgiServiceRegistry) {
+            osgiServiceRegistry = (OsgiServiceRegistry)registry;
+        } else {
+            LOG.debug("Wrapping Registry in OsgiServiceRegistry");
+            osgiServiceRegistry = new OsgiServiceRegistry(bundleContext);
+            CompositeRegistry compositeRegistry = new CompositeRegistry();
+            compositeRegistry.addRegistry(osgiServiceRegistry);
+            compositeRegistry.addRegistry(registry);
+            resultingRegistry = compositeRegistry;
+        }
+        
         // Need to clean up the OSGi service when camel context is closed.
         camelContext.addLifecycleStrategy(osgiServiceRegistry);
-        CompositeRegistry compositeRegistry = new CompositeRegistry();
-        compositeRegistry.addRegistry(osgiServiceRegistry);
-        compositeRegistry.addRegistry(registry);
-        return compositeRegistry;
+        
+        return resultingRegistry;
     }
 
 }
diff --git a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java
index ccfbe49..7bc4ef0 100644
--- a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java
+++ b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java
@@ -32,7 +32,6 @@ import org.osgi.framework.BundleContext;
 public class OsgiDefaultCamelContext extends DefaultCamelContext {
 
     private final BundleContext bundleContext;
-    private final Registry registry;
 
     public OsgiDefaultCamelContext(BundleContext bundleContext) {
         this(bundleContext, new OsgiServiceRegistry(bundleContext));
@@ -41,7 +40,7 @@ public class OsgiDefaultCamelContext extends DefaultCamelContext {
     public OsgiDefaultCamelContext(BundleContext bundleContext, Registry registry) {
         super(registry);
         this.bundleContext = bundleContext;
-        this.registry = registry;
+        setRegistry(OsgiCamelContextHelper.wrapRegistry(this, registry, bundleContext));
         OsgiCamelContextHelper.osgiUpdate(this, bundleContext);
         // setup the application context classloader with the bundle classloader
         setApplicationContextClassLoader(new BundleDelegatingClassLoader(bundleContext.getBundle()));
@@ -53,15 +52,6 @@ public class OsgiDefaultCamelContext extends DefaultCamelContext {
     }
 
     @Override
-    protected Registry createRegistry() {
-        if (registry != null) {
-            return OsgiCamelContextHelper.wrapRegistry(this, registry, bundleContext);
-        } else {
-            return OsgiCamelContextHelper.wrapRegistry(this, super.createRegistry(), bundleContext);
-        }
-    }
-
-    @Override
     protected TypeConverter createTypeConverter() {
         // CAMEL-3614: make sure we use a bundle context which imports org.apache.camel.impl.converter package
         BundleContext ctx = BundleContextUtils.getBundleContext(getClass());


[camel] 02/08: CAMEL-12987: Fixed CS

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 264ff915e2cbda8fd768547fae5611256dee4664
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Dec 9 10:53:35 2018 +0100

    CAMEL-12987: Fixed CS
---
 .../main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java
index 2b9b1fc..80eb64d 100644
--- a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java
+++ b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiCamelContextHelper.java
@@ -58,7 +58,7 @@ public final class OsgiCamelContextHelper {
 
         OsgiServiceRegistry osgiServiceRegistry = null;
         Registry resultingRegistry = registry;
-        if(registry instanceof OsgiServiceRegistry) {
+        if (registry instanceof OsgiServiceRegistry) {
             osgiServiceRegistry = (OsgiServiceRegistry)registry;
         } else {
             LOG.debug("Wrapping Registry in OsgiServiceRegistry");


[camel] 03/08: CAMEL-12987 - Fixed CS for imports

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 4475457df7275d264918b60e80979b1bb1e77e3c
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Mon Dec 10 08:40:11 2018 +0100

    CAMEL-12987 - Fixed CS for imports
---
 .../main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java   | 2 +-
 .../src/main/java/org/apache/camel/core/osgi/OsgiTypeConverter.java     | 2 +-
 .../main/java/org/apache/camel/core/osgi/utils/BundleContextUtils.java  | 2 +-
 3 files changed, 3 insertions(+), 3 deletions(-)

diff --git a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java
index 7bc4ef0..231e720 100644
--- a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java
+++ b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiDefaultCamelContext.java
@@ -20,13 +20,13 @@ import java.io.IOException;
 import java.util.Map;
 import java.util.Properties;
 
+import org.apache.camel.LoadPropertiesException;
 import org.apache.camel.TypeConverter;
 import org.apache.camel.core.osgi.utils.BundleContextUtils;
 import org.apache.camel.core.osgi.utils.BundleDelegatingClassLoader;
 import org.apache.camel.impl.DefaultCamelContext;
 import org.apache.camel.spi.FactoryFinder;
 import org.apache.camel.spi.Registry;
-import org.apache.camel.LoadPropertiesException;
 import org.osgi.framework.BundleContext;
 
 public class OsgiDefaultCamelContext extends DefaultCamelContext {
diff --git a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiTypeConverter.java b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiTypeConverter.java
index 19947df..8aaacf2 100644
--- a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiTypeConverter.java
+++ b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/OsgiTypeConverter.java
@@ -36,8 +36,8 @@ import org.apache.camel.spi.FactoryFinder;
 import org.apache.camel.spi.Injector;
 import org.apache.camel.spi.TypeConverterLoader;
 import org.apache.camel.spi.TypeConverterRegistry;
-import org.apache.camel.support.ServiceSupport;
 import org.apache.camel.support.ServiceHelper;
+import org.apache.camel.support.ServiceSupport;
 import org.osgi.framework.BundleContext;
 import org.osgi.framework.ServiceReference;
 import org.osgi.util.tracker.ServiceTracker;
diff --git a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/utils/BundleContextUtils.java b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/utils/BundleContextUtils.java
index 84fd9c5..3120b69 100644
--- a/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/utils/BundleContextUtils.java
+++ b/components/camel-core-osgi/src/main/java/org/apache/camel/core/osgi/utils/BundleContextUtils.java
@@ -26,8 +26,8 @@ import java.util.SortedMap;
 import java.util.TreeMap;
 
 import org.apache.camel.CamelContext;
-import org.apache.camel.support.CamelContextHelper;
 import org.apache.camel.LoadPropertiesException;
+import org.apache.camel.support.CamelContextHelper;
 import org.osgi.framework.Bundle;
 import org.osgi.framework.BundleContext;
 


[camel] 08/08: CAMEL-12985 - Fixed backport from 2.x

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 6752e176b330aa43a2a563b966f94b8d39121783
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Mon Dec 10 08:48:18 2018 +0100

    CAMEL-12985 - Fixed backport from 2.x
---
 .../TransactedInterceptUsingAdviceWithSendToEndpointTest.java         | 4 +++-
 1 file changed, 3 insertions(+), 1 deletion(-)

diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java
index 39bbf5c..7b5dd78 100644
--- a/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java
+++ b/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java
@@ -16,8 +16,10 @@
  */
 package org.apache.camel.spring.interceptor;
 
+import org.apache.camel.builder.AdviceWithRouteBuilder;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.reifier.RouteReifier;
 import org.apache.camel.spring.SpringRouteBuilder;
 import org.junit.Test;
 
@@ -53,7 +55,7 @@ public class TransactedInterceptUsingAdviceWithSendToEndpointTest extends Transa
     }
     
     private void addInterceptor(String routeId) throws Exception {
-        context.getRouteDefinition(routeId).adviceWith(context, new SpringRouteBuilder() {
+    	RouteReifier.adviceWith(context.getRouteDefinitions().get(0), context, new AdviceWithRouteBuilder() {
             @Override
             public void configure() throws Exception {
                 interceptSendToEndpoint("direct:(foo|bar)")


[camel] 07/08: CAMEL-12985 - Fixed CS

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit b323687cd6e1ab4fd98934024e4a801400552817
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Mon Dec 10 08:24:30 2018 +0100

    CAMEL-12985 - Fixed CS
---
 .../org/apache/camel/spring/spi/TransactionErrorHandler.java   | 10 +++++++---
 1 file changed, 7 insertions(+), 3 deletions(-)

diff --git a/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java b/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java
index 4f493b5..8cc2c72 100644
--- a/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java
+++ b/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java
@@ -95,7 +95,9 @@ public class TransactionErrorHandler extends RedeliveryErrorHandler {
     public void process(Exchange exchange) {
         // we have to run this synchronously as Spring Transaction does *not* support
         // using multiple threads to span a transaction
-        if (transactionTemplate.getPropagationBehavior() != TransactionDefinition.PROPAGATION_REQUIRES_NEW && exchange.getUnitOfWork() != null && exchange.getUnitOfWork().isTransactedBy(transactionKey)) {
+        if (transactionTemplate.getPropagationBehavior() != TransactionDefinition.PROPAGATION_REQUIRES_NEW 
+            && exchange.getUnitOfWork() != null 
+            && exchange.getUnitOfWork().isTransactedBy(transactionKey)) {
             // already transacted by this transaction template
             // so lets just let the error handler process it
             processByErrorHandler(exchange);
@@ -129,8 +131,9 @@ public class TransactionErrorHandler extends RedeliveryErrorHandler {
 
         try {
             // mark the beginning of this transaction boundary
-            if (exchange.getUnitOfWork() != null)
+            if (exchange.getUnitOfWork() != null) {
                 exchange.getUnitOfWork().beginTransactedBy(transactionKey);
+            }
 
             // do in transaction
             logTransactionBegin(redelivered, ids);
@@ -145,8 +148,9 @@ public class TransactionErrorHandler extends RedeliveryErrorHandler {
             logTransactionRollback(redelivered, ids, e, false);
         } finally {
             // mark the end of this transaction boundary
-            if (exchange.getUnitOfWork() != null)
+            if (exchange.getUnitOfWork() != null) {
                 exchange.getUnitOfWork().endTransactedBy(transactionKey);
+            }
         }
 
         // if it was a local rollback only then remove its marker so outer transaction wont see the marker


[camel] 05/08: CAMEL-12985: TransactionErrorHandler fails if UnitOfWork is null

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit e21f27987b6ce7ec7ebf23a132a8c3973b5e8c0f
Author: Jess Sightler <je...@gmail.com>
AuthorDate: Fri Dec 7 13:07:43 2018 -0500

    CAMEL-12985: TransactionErrorHandler fails if UnitOfWork is null
---
 .../java/org/apache/camel/spring/spi/TransactionErrorHandler.java | 8 +++++---
 1 file changed, 5 insertions(+), 3 deletions(-)

diff --git a/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java b/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java
index 6360368..4f493b5 100644
--- a/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java
+++ b/components/camel-spring/src/main/java/org/apache/camel/spring/spi/TransactionErrorHandler.java
@@ -95,7 +95,7 @@ public class TransactionErrorHandler extends RedeliveryErrorHandler {
     public void process(Exchange exchange) {
         // we have to run this synchronously as Spring Transaction does *not* support
         // using multiple threads to span a transaction
-        if (transactionTemplate.getPropagationBehavior() != TransactionDefinition.PROPAGATION_REQUIRES_NEW && exchange.getUnitOfWork().isTransactedBy(transactionKey)) {
+        if (transactionTemplate.getPropagationBehavior() != TransactionDefinition.PROPAGATION_REQUIRES_NEW && exchange.getUnitOfWork() != null && exchange.getUnitOfWork().isTransactedBy(transactionKey)) {
             // already transacted by this transaction template
             // so lets just let the error handler process it
             processByErrorHandler(exchange);
@@ -129,7 +129,8 @@ public class TransactionErrorHandler extends RedeliveryErrorHandler {
 
         try {
             // mark the beginning of this transaction boundary
-            exchange.getUnitOfWork().beginTransactedBy(transactionKey);
+            if (exchange.getUnitOfWork() != null)
+                exchange.getUnitOfWork().beginTransactedBy(transactionKey);
 
             // do in transaction
             logTransactionBegin(redelivered, ids);
@@ -144,7 +145,8 @@ public class TransactionErrorHandler extends RedeliveryErrorHandler {
             logTransactionRollback(redelivered, ids, e, false);
         } finally {
             // mark the end of this transaction boundary
-            exchange.getUnitOfWork().endTransactedBy(transactionKey);
+            if (exchange.getUnitOfWork() != null)
+                exchange.getUnitOfWork().endTransactedBy(transactionKey);
         }
 
         // if it was a local rollback only then remove its marker so outer transaction wont see the marker


[camel] 06/08: CAMEL-12985: Added a test that fails on master

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit d576c0905fbe9611af55786b3fc355b9616ff515
Author: Jess Sightler <je...@gmail.com>
AuthorDate: Fri Dec 7 19:07:18 2018 -0500

    CAMEL-12985: Added a test that fails on master
---
 ...InterceptUsingAdviceWithSendToEndpointTest.java | 93 ++++++++++++++++++++++
 1 file changed, 93 insertions(+)

diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java
new file mode 100644
index 0000000..39bbf5c
--- /dev/null
+++ b/components/camel-spring/src/test/java/org/apache/camel/spring/interceptor/TransactedInterceptUsingAdviceWithSendToEndpointTest.java
@@ -0,0 +1,93 @@
+/**
+ * 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.spring.interceptor;
+
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.spring.SpringRouteBuilder;
+import org.junit.Test;
+
+/**
+ * Easier transaction configuration as we do not have to setup a transaction error handler
+ */
+public class TransactedInterceptUsingAdviceWithSendToEndpointTest extends TransactionalClientDataSourceTest {
+
+    @Test
+    public void testTransactionSuccess() throws Exception {
+        MockEndpoint intercepted = getMockEndpoint("mock:intercepted");
+        
+        addInterceptor("ok_route");
+        
+        intercepted.expectedBodiesReceived("Hello World");
+
+        super.testTransactionSuccess();
+
+        assertMockEndpointsSatisfied();
+    }
+
+    @Test
+    public void testTransactionRollback() throws Exception {
+        MockEndpoint intercepted = getMockEndpoint("mock:intercepted");
+        
+        addInterceptor("fail_route");
+        
+        intercepted.expectedBodiesReceived("Tiger in Action");
+
+        super.testTransactionRollback();
+
+        assertMockEndpointsSatisfied();
+    }
+    
+    private void addInterceptor(String routeId) throws Exception {
+        context.getRouteDefinition(routeId).adviceWith(context, new SpringRouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                interceptSendToEndpoint("direct:(foo|bar)")
+                    .to("mock:intercepted");
+            }
+        });
+    }
+
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new SpringRouteBuilder() {
+            public void configure() throws Exception {
+                from("direct:okay")
+                    .routeId("ok_route")
+                    .transacted()
+                    .enrich("direct:foo", (oldExchange, newExchange) -> {
+                        return newExchange;
+                    })
+                    .setBody(constant("Tiger in Action")).bean("bookService")
+                    .setBody(constant("Elephant in Action")).bean("bookService");
+
+                from("direct:fail")
+                    .routeId("fail_route")
+                    .transacted()
+                    .setBody(constant("Tiger in Action")).bean("bookService")
+                    .enrich("direct:bar", (oldExchange, newExchange) -> {
+                        return newExchange;
+                    })
+                    .setBody(constant("Donkey in Action")).bean("bookService");
+
+                from("direct:foo").to("log:okay");
+
+                from("direct:bar").to("mock:fail");
+            }
+        };
+    }
+
+}
\ No newline at end of file


[camel] 04/08: Upgrade Awaitility to version 3.1.5

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit ee35ebac0860855f41820c754ff39b591989fa38
Author: Pascal Schumacher <pa...@gmx.net>
AuthorDate: Sun Dec 9 11:40:46 2018 +0100

    Upgrade Awaitility to version 3.1.5
---
 parent/pom.xml                                                          | 2 +-
 .../spring-boot/spring-boot-dm/camel-spring-boot-dependencies/pom.xml   | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/parent/pom.xml b/parent/pom.xml
index f8077a1..5c03bfb 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -80,7 +80,7 @@
     <avro-version>1.8.2</avro-version>
     <avro-bundle-version>1.8.2_1</avro-bundle-version>
     <avro-ipc-bundle-version>1.8.2_1</avro-ipc-bundle-version>
-    <awaitility-version>3.1.3</awaitility-version>
+    <awaitility-version>3.1.5</awaitility-version>
     <aws-java-sdk-bundle-version>1.11.461_1</aws-java-sdk-bundle-version>
     <aws-java-sdk-version>1.11.461</aws-java-sdk-version>
     <aws-xray-version>2.1.0</aws-xray-version>
diff --git a/platforms/spring-boot/spring-boot-dm/camel-spring-boot-dependencies/pom.xml b/platforms/spring-boot/spring-boot-dm/camel-spring-boot-dependencies/pom.xml
index 4df6506..da5141a 100644
--- a/platforms/spring-boot/spring-boot-dm/camel-spring-boot-dependencies/pom.xml
+++ b/platforms/spring-boot/spring-boot-dm/camel-spring-boot-dependencies/pom.xml
@@ -3397,7 +3397,7 @@
       <dependency>
         <groupId>org.awaitility</groupId>
         <artifactId>awaitility</artifactId>
-        <version>3.1.3</version>
+        <version>3.1.5</version>
       </dependency>
       <dependency>
         <groupId>org.cassandraunit</groupId>