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 2019/01/20 13:45:48 UTC

[camel] branch master updated: Remove @deprecated from EIP models

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 66250f4  Remove @deprecated from EIP models
66250f4 is described below

commit 66250f4096e1a5f186d6659c988164c2cf0d2c41
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Jan 20 14:45:30 2019 +0100

    Remove @deprecated from EIP models
---
 .../org/apache/camel/model/RethrowDefinition.java  |  54 -----------
 .../java/org/apache/camel/model/TryDefinition.java |  10 --
 .../org/apache/camel/reifier/ProcessorReifier.java |   2 -
 .../org/apache/camel/reifier/RethrowReifier.java   |  41 --------
 .../TryCatchWithSplitNotHandledIssueTest.java      |  82 ----------------
 .../camel/processor/TryProcessorHandledTest.java   | 105 ---------------------
 .../apache/camel/component/cxf/CxfTimeoutTest.java |   3 -
 .../component/cxf/cxfConduitTimeOutContext.xml     |  13 +--
 .../src/main/docs/linkedin-component.adoc          |   2 +-
 ...SpringTryCatchWithSplitNotHandledIssueTest.java |  30 ------
 .../SpringRouteTopLevelMisconfiguredTest.java      |   2 +-
 .../processor/SpringTryCatchMisconfiguredTest.java |   2 +-
 ...ingTryCatchMustHaveExceptionConfiguredTest.java |   2 +-
 .../processor/SpringTryProcessorHandledTest.java   |  30 ------
 .../SpringTryCatchWithSplitNotHandledIssueTest.xml |  46 ---------
 .../processor/SpringTryProcessorHandledTest.xml    |  56 -----------
 16 files changed, 5 insertions(+), 475 deletions(-)

diff --git a/camel-core/src/main/java/org/apache/camel/model/RethrowDefinition.java b/camel-core/src/main/java/org/apache/camel/model/RethrowDefinition.java
deleted file mode 100644
index 96a32e1..0000000
--- a/camel-core/src/main/java/org/apache/camel/model/RethrowDefinition.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/**
- * 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.model;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.spi.Metadata;
-import org.apache.camel.spi.RouteContext;
-
-/**
- * Rethrow an exception inside a catch block
- */
-@Metadata(label = "error")
-@XmlRootElement(name = "rethrow")
-@XmlAccessorType(XmlAccessType.FIELD)
-public class RethrowDefinition extends NoOutputDefinition<RethrowDefinition> {
-
-    public RethrowDefinition() {
-    }
-
-    @Override
-    public String toString() {
-        return "Rethrow[]";
-    }
-
-    @Override
-    public String getShortName() {
-        return "rethrow";
-    }
-
-    @Override
-    public String getLabel() {
-        return "rethrow[]";
-    }
-
-}
diff --git a/camel-core/src/main/java/org/apache/camel/model/TryDefinition.java b/camel-core/src/main/java/org/apache/camel/model/TryDefinition.java
index 9a85bc1..7ca43af 100644
--- a/camel-core/src/main/java/org/apache/camel/model/TryDefinition.java
+++ b/camel-core/src/main/java/org/apache/camel/model/TryDefinition.java
@@ -130,16 +130,6 @@ public class TryDefinition extends OutputDefinition<TryDefinition> {
         return this;
     }
 
-    /**
-     * Rethrow the exception that has been caught by Camel.
-     *
-     * @return the builder
-     */
-    public TryDefinition rethrow() {
-        addOutput(new RethrowDefinition());
-        return this;
-    }
-
     // Properties
     // -------------------------------------------------------------------------
 
diff --git a/camel-core/src/main/java/org/apache/camel/reifier/ProcessorReifier.java b/camel-core/src/main/java/org/apache/camel/reifier/ProcessorReifier.java
index 93bc47b..efdc1cf 100644
--- a/camel-core/src/main/java/org/apache/camel/reifier/ProcessorReifier.java
+++ b/camel-core/src/main/java/org/apache/camel/reifier/ProcessorReifier.java
@@ -68,7 +68,6 @@ import org.apache.camel.model.RemoveHeadersDefinition;
 import org.apache.camel.model.RemovePropertiesDefinition;
 import org.apache.camel.model.RemovePropertyDefinition;
 import org.apache.camel.model.ResequenceDefinition;
-import org.apache.camel.model.RethrowDefinition;
 import org.apache.camel.model.RollbackDefinition;
 import org.apache.camel.model.RouteDefinition;
 import org.apache.camel.model.RoutingSlipDefinition;
@@ -151,7 +150,6 @@ public abstract class ProcessorReifier<T extends ProcessorDefinition<?>> {
         map.put(RemovePropertiesDefinition.class, RemovePropertiesReifier::new);
         map.put(RemovePropertyDefinition.class, RemovePropertyReifier::new);
         map.put(ResequenceDefinition.class, ResequenceReifier::new);
-        map.put(RethrowDefinition.class, RethrowReifier::new);
         map.put(RollbackDefinition.class, RollbackReifier::new);
         map.put(RouteDefinition.class, RouteReifier::new);
         map.put(RoutingSlipDefinition.class, RoutingSlipReifier::new);
diff --git a/camel-core/src/main/java/org/apache/camel/reifier/RethrowReifier.java b/camel-core/src/main/java/org/apache/camel/reifier/RethrowReifier.java
deleted file mode 100644
index e833388..0000000
--- a/camel-core/src/main/java/org/apache/camel/reifier/RethrowReifier.java
+++ /dev/null
@@ -1,41 +0,0 @@
-/**
- * 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.reifier;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.model.ProcessorDefinition;
-import org.apache.camel.model.RethrowDefinition;
-import org.apache.camel.spi.RouteContext;
-
-class RethrowReifier extends ProcessorReifier<RethrowDefinition> {
-
-    RethrowReifier(ProcessorDefinition<?> definition) {
-        super((RethrowDefinition) definition);
-    }
-
-    @Override
-    public Processor createProcessor(RouteContext routeContext) throws Exception {
-        return exchange -> {
-            Exception e = exchange.getProperty(Exchange.EXCEPTION_CAUGHT, Exception.class);
-            if (e != null) {
-                throw e;
-            }
-        };
-    }
-
-}
diff --git a/camel-core/src/test/java/org/apache/camel/issues/TryCatchWithSplitNotHandledIssueTest.java b/camel-core/src/test/java/org/apache/camel/issues/TryCatchWithSplitNotHandledIssueTest.java
deleted file mode 100644
index 06c5fa3..0000000
--- a/camel-core/src/test/java/org/apache/camel/issues/TryCatchWithSplitNotHandledIssueTest.java
+++ /dev/null
@@ -1,82 +0,0 @@
-/**
- * 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.issues;
-
-import org.apache.camel.ContextTestSupport;
-import org.apache.camel.Exchange;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.impl.JndiRegistry;
-import org.junit.Test;
-
-public class TryCatchWithSplitNotHandledIssueTest extends ContextTestSupport {
-
-    @Test
-    public void testSplitWithErrorIsNotHandled() throws Exception {
-        MockEndpoint error = getMockEndpoint("mock:error");
-        error.expectedBodiesReceived("James");
-        error.message(0).exchangeProperty(Exchange.EXCEPTION_CAUGHT).isNotNull();
-
-        MockEndpoint result = getMockEndpoint("mock:result");
-        result.expectedBodiesReceived("Hi Claus", "Hi Willem");
-
-        try {
-            template.sendBody("direct:start", "Claus@James@Willem");
-            fail("Should have thrown an exception");
-        } catch (Exception e) {
-            assertEquals("This is a dummy error James!", e.getCause().getMessage());
-        }
-
-        assertMockEndpointsSatisfied();
-    }
-
-
-    protected JndiRegistry createRegistry() throws Exception {
-        JndiRegistry jndi = super.createRegistry();
-        jndi.bind("error", new GenerateError());
-        return jndi;
-    }
-
-    protected RouteBuilder createRouteBuilder() {
-        return new RouteBuilder() {
-            public void configure() {
-                from("direct:start")
-                    .split(body().tokenize("@"))
-                    .doTry()
-                        .to("bean:error")
-                        .to("mock:result")
-                    .doCatch(Exception.class)
-                        .to("mock:error")
-                        .rethrow()
-                    .end();
-            }
-
-        };
-    }
-
-    public static class GenerateError {
-
-        public String dummyException(String payload) throws Exception {
-            if (payload.equals("James")) {
-                throw new Exception("This is a dummy error James!");
-            }
-            return "Hi " + payload;
-        }
-
-    }
-
-}
\ No newline at end of file
diff --git a/camel-core/src/test/java/org/apache/camel/processor/TryProcessorHandledTest.java b/camel-core/src/test/java/org/apache/camel/processor/TryProcessorHandledTest.java
deleted file mode 100644
index c83f914..0000000
--- a/camel-core/src/test/java/org/apache/camel/processor/TryProcessorHandledTest.java
+++ /dev/null
@@ -1,105 +0,0 @@
-/**
- * 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.processor;
-
-import java.io.IOException;
-
-import org.apache.camel.ContextTestSupport;
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.builder.RouteBuilder;
-import org.junit.Test;
-
-/**
- * Unit test for try .. catch with handled false.
- */
-public class TryProcessorHandledTest extends ContextTestSupport {
-
-    @Test
-    public void testOk() throws Exception {
-        getMockEndpoint("mock:result").expectedMessageCount(1);
-        getMockEndpoint("mock:error").expectedMessageCount(0);
-
-        sendBody("direct:start", "Hello World");
-
-        assertMockEndpointsSatisfied();
-    }
-
-    @Test
-    public void testIllegalStateException() throws Exception {
-        getMockEndpoint("mock:result").expectedMessageCount(0);
-        getMockEndpoint("mock:error").expectedMessageCount(1);
-
-        template.sendBody("direct:start", "Damn State");
-
-        assertMockEndpointsSatisfied();
-    }
-
-    @Test
-    public void testIOException() throws Exception {
-        getMockEndpoint("mock:result").expectedMessageCount(0);
-        getMockEndpoint("mock:io").expectedMessageCount(1);
-
-        try {
-            template.sendBody("direct:start", "Damn IO");
-            fail("Should have thrown a RuntimeCamelException");
-        } catch (RuntimeCamelException e) {
-            assertIsInstanceOf(IOException.class, e.getCause());
-            assertEquals("Damn IO", e.getCause().getMessage());
-        }
-
-        assertMockEndpointsSatisfied();
-    }
-
-    protected RouteBuilder createRouteBuilder() {
-        return new RouteBuilder() {
-            public void configure() {
-                // START SNIPPET: e1
-                from("direct:start")
-                    // here is our try where we try processing the exchange in the route below if it fails
-                    // we can catch it below, just like regular try .. catch .. finally in Java
-                    .doTry()
-                        .process(new ProcessorFail())
-                        .to("mock:result")
-                    // catch IOException that we do not want to handle, eg the caller should get the error back
-                    .doCatch(IOException.class)
-                        .to("mock:io")
-                        .rethrow()
-                    .doCatch(Exception.class)
-                        // and catch all other exceptions
-                        // they are handled by default (ie handled = true)
-                        .to("mock:error")
-                    // here the try block ends
-                    .end();
-                // END SNIPPET: e1
-            }
-        };
-    }
-
-    public static class ProcessorFail implements Processor {
-        public void process(Exchange exchange) throws Exception {
-            String body = exchange.getIn().getBody(String.class);
-            if ("Damn IO".equals(body)) {
-                throw new IOException("Damn IO");
-            } else if ("Damn State".equals(body)) {
-                throw new IllegalStateException("Damn State");
-            }
-        }
-    }
-
-}
\ No newline at end of file
diff --git a/components/camel-cxf/src/test/java/org/apache/camel/component/cxf/CxfTimeoutTest.java b/components/camel-cxf/src/test/java/org/apache/camel/component/cxf/CxfTimeoutTest.java
index 20c509a..088c3fd 100644
--- a/components/camel-cxf/src/test/java/org/apache/camel/component/cxf/CxfTimeoutTest.java
+++ b/components/camel-cxf/src/test/java/org/apache/camel/component/cxf/CxfTimeoutTest.java
@@ -85,10 +85,7 @@ public class CxfTimeoutTest extends CamelSpringTestSupport {
     
     @Test
     public void testDoCatchWithTimeOutException() throws Exception {
-        MockEndpoint error = context.getEndpoint("mock:error", MockEndpoint.class);
-        error.expectedMessageCount(1);
         sendTimeOutMessage("direct:doCatch");
-        error.assertIsSatisfied();
     }
     
     protected void sendTimeOutMessage(String endpointUri) throws Exception {
diff --git a/components/camel-cxf/src/test/resources/org/apache/camel/component/cxf/cxfConduitTimeOutContext.xml b/components/camel-cxf/src/test/resources/org/apache/camel/component/cxf/cxfConduitTimeOutContext.xml
index 3608148..d41ae82 100644
--- a/components/camel-cxf/src/test/resources/org/apache/camel/component/cxf/cxfConduitTimeOutContext.xml
+++ b/components/camel-cxf/src/test/resources/org/apache/camel/component/cxf/cxfConduitTimeOutContext.xml
@@ -63,18 +63,7 @@
 
         <route>
             <from uri="direct:doCatch"/>
-            <doTry>
-                <to uri="cxf:bean:springEndpoint"/>
-                <doCatch>
-                    <!-- and catch all other exceptions they are handled by default (ie handled
-                        = true) -->
-                    <exception>java.lang.Exception</exception>
-                    <handled>
-                        <constant>false</constant>
-                    </handled>
-                    <to uri="mock:error"/>
-                </doCatch>
-            </doTry>
+            <to uri="cxf:bean:springEndpoint"/>
         </route>
     </camelContext>
 
diff --git a/components/camel-linkedin/camel-linkedin-component/src/main/docs/linkedin-component.adoc b/components/camel-linkedin/camel-linkedin-component/src/main/docs/linkedin-component.adoc
index e1dc028..6e6b3e5 100644
--- a/components/camel-linkedin/camel-linkedin-component/src/main/docs/linkedin-component.adoc
+++ b/components/camel-linkedin/camel-linkedin-component/src/main/docs/linkedin-component.adoc
@@ -124,7 +124,7 @@ The component supports 15 options, which are listed below.
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Type
-| *camel.component.linkedin.configuration.access-token* | LinkedIn access token to avoid username and password login. |  | String
+| *camel.component.linkedin.configuration.access-token* | LinkedIn access token to avoid username and password login procedure. LinkedIn responds to login forms by using a CAPTCHA. This makes it impossible for a standalone, headless process to log in to LinkedIn by specifying a username and password. To work around this, obtain a LinkedIn access token and provide the token as the setting of the accessToken parameter. Obtaining a LinkedIn access token is a multi-step procedure. You must c [...]
 | *camel.component.linkedin.configuration.api-name* | What kind of operation to perform |  | LinkedInApiName
 | *camel.component.linkedin.configuration.client-id* | LinkedIn application client ID |  | String
 | *camel.component.linkedin.configuration.client-secret* | LinkedIn application client secret |  | String
diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.java
deleted file mode 100644
index 9f79601..0000000
--- a/components/camel-spring/src/test/java/org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * 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.issues;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.issues.TryCatchWithSplitNotHandledIssueTest;
-
-import static org.apache.camel.spring.processor.SpringTestHelper.createSpringCamelContext;
-
-public class SpringTryCatchWithSplitNotHandledIssueTest extends TryCatchWithSplitNotHandledIssueTest {
-
-    protected CamelContext createCamelContext() throws Exception {
-        return createSpringCamelContext(this, "org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.xml");
-    }
-
-}
\ No newline at end of file
diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringRouteTopLevelMisconfiguredTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringRouteTopLevelMisconfiguredTest.java
index 3cd31af..65f9d8d 100644
--- a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringRouteTopLevelMisconfiguredTest.java
+++ b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringRouteTopLevelMisconfiguredTest.java
@@ -53,7 +53,7 @@ public class SpringRouteTopLevelMisconfiguredTest extends ContextTestSupport {
 
 
         // return a working context instead, to let this test pass
-        return createSpringCamelContext(this, "org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml");
+        return createSpringCamelContext(this, "org/apache/camel/spring/processor/convertBody.xml");
     }
 
     @Test
diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMisconfiguredTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMisconfiguredTest.java
index f10b14c..660de9c 100644
--- a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMisconfiguredTest.java
+++ b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMisconfiguredTest.java
@@ -47,7 +47,7 @@ public class SpringTryCatchMisconfiguredTest extends ContextTestSupport {
         }
 
         // return a working context instead, to let this test pass
-        return createSpringCamelContext(this, "org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml");
+        return createSpringCamelContext(this, "org/apache/camel/spring/processor/convertBody.xml");
     }
 
     @Test
diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMustHaveExceptionConfiguredTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMustHaveExceptionConfiguredTest.java
index efbd16b..cf5639f 100644
--- a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMustHaveExceptionConfiguredTest.java
+++ b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryCatchMustHaveExceptionConfiguredTest.java
@@ -37,7 +37,7 @@ public class SpringTryCatchMustHaveExceptionConfiguredTest extends ContextTestSu
         }
 
         // return a working context instead, to let this test pass
-        return createSpringCamelContext(this, "org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml");
+        return createSpringCamelContext(this, "org/apache/camel/spring/processor/convertBody.xml");
     }
 
     @Test
diff --git a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryProcessorHandledTest.java b/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryProcessorHandledTest.java
deleted file mode 100644
index 065d67c..0000000
--- a/components/camel-spring/src/test/java/org/apache/camel/spring/processor/SpringTryProcessorHandledTest.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * 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.processor;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.processor.TryProcessorHandledTest;
-
-import static org.apache.camel.spring.processor.SpringTestHelper.createSpringCamelContext;
-
-public class SpringTryProcessorHandledTest extends TryProcessorHandledTest {
-
-    protected CamelContext createCamelContext() throws Exception {
-        return createSpringCamelContext(this, "org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml");
-    }
-
-}
\ No newline at end of file
diff --git a/components/camel-spring/src/test/resources/org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.xml b/components/camel-spring/src/test/resources/org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.xml
deleted file mode 100644
index f50802c..0000000
--- a/components/camel-spring/src/test/resources/org/apache/camel/spring/issues/SpringTryCatchWithSplitNotHandledIssueTest.xml
+++ /dev/null
@@ -1,46 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    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.
-
--->
-<beans xmlns="http://www.springframework.org/schema/beans"
-       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-       xsi:schemaLocation="
-       http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
-    ">
-
-    <bean id="error" class="org.apache.camel.issues.TryCatchWithSplitNotHandledIssueTest$GenerateError"/>
-
-    <camelContext xmlns="http://camel.apache.org/schema/spring">
-        <route>
-            <from uri="direct:start"/>
-            <split><tokenize token="@"/>
-                <doTry>
-                    <to uri="bean:error"/>
-                    <to uri="mock:result"/>
-                    <doCatch>
-                        <exception>java.lang.Exception</exception>
-                        <handled><constant>false</constant></handled>
-                        <to uri="mock:error"/>
-                    </doCatch>
-                </doTry>
-            </split>
-        </route>
-    </camelContext>
-
-</beans>
diff --git a/components/camel-spring/src/test/resources/org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml b/components/camel-spring/src/test/resources/org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml
deleted file mode 100644
index 5b103a9..0000000
--- a/components/camel-spring/src/test/resources/org/apache/camel/spring/processor/SpringTryProcessorHandledTest.xml
+++ /dev/null
@@ -1,56 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    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.
-
--->
-<beans xmlns="http://www.springframework.org/schema/beans"
-       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-       xsi:schemaLocation="
-       http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
-    ">
-
-    <camelContext xmlns="http://camel.apache.org/schema/spring">
-        <!-- START SNIPPET: e1 -->
-        <route>
-            <from uri="direct:start"/>
-            <!-- here the try starts. its a try .. catch .. finally just as regular java code -->
-            <doTry>
-                <process ref="processorFail"/>
-                <to uri="mock:result"/>
-                <doCatch>
-                    <!-- catch IOExcption that we do not want to handle, eg the caller should get the error back -->
-                    <exception>java.io.IOException</exception>
-                    <!-- mark this as NOT handled, eg the caller will also get the exception -->
-                    <handled>
-                        <constant>false</constant>
-                    </handled>
-                    <to uri="mock:io"/>
-                </doCatch>
-                <doCatch>
-                    <!-- and catch all other exceptions they are handled by default (ie handled = true) -->
-                    <exception>java.lang.Exception</exception>
-                    <to uri="mock:error"/>
-                </doCatch>
-            </doTry>
-        </route>
-        <!-- END SNIPPET: e1 -->
-    </camelContext>
-
-    <bean id="processorFail" class="org.apache.camel.processor.TryProcessorHandledTest$ProcessorFail"/>
-
-</beans>