Repository: camel
Updated Branches:
refs/heads/master 366ad8d0b -> 873720994
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersInheritedTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersInheritedTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersInheritedTest.java
deleted file mode 100644
index 229e3c9..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersInheritedTest.java
+++ /dev/null
@@ -1,21 +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.test.spring;
-
-public class CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersInheritedTest
- extends CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersTest {
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersTest.java
deleted file mode 100644
index 20bc31a..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersTest.java
+++ /dev/null
@@ -1,33 +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.test.spring;
-
-import org.junit.Test;
-import static org.junit.Assert.assertFalse;
-
-@SuppressWarnings("deprecation")
-@LazyLoadTypeConverters(false)
-public class CamelSpringJUnit4ClassRunnerLazyLoadTypeConvertersTest
- extends CamelSpringJUnit4ClassRunnerPlainTest {
-
- @Test
- @Override
- public void testLazyLoadTypeConverters() {
- assertFalse(camelContext.isLazyLoadTypeConverters());
- assertFalse(camelContext2.isLazyLoadTypeConverters());
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsAndSkipTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsAndSkipTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsAndSkipTest.java
deleted file mode 100644
index d20e72b..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsAndSkipTest.java
+++ /dev/null
@@ -1,56 +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.test.spring;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.ServiceStatus;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.seda.SedaEndpoint;
-import org.apache.camel.impl.InterceptSendToEndpoint;
-import org.junit.Test;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
-
-@MockEndpointsAndSkip("seda:*")
-public class CamelSpringJUnit4ClassRunnerMockEndpointsAndSkipTest
- extends CamelSpringJUnit4ClassRunnerPlainTest {
-
- @EndpointInject(uri = "mock:seda:context2.seda", context = "camelContext2")
- protected MockEndpoint mock;
-
- @EndpointInject(uri = "seda:context2.seda", context = "camelContext2")
- private InterceptSendToEndpoint original;
-
- @Test
- @Override
- public void testPositive() throws Exception {
- assertEquals(ServiceStatus.Started, camelContext.getStatus());
- assertEquals(ServiceStatus.Started, camelContext2.getStatus());
-
- mockA.expectedBodiesReceived("David");
- mockB.expectedBodiesReceived("Hello David");
- mock.expectedBodiesReceived("Hello David");
-
- start.sendBody("David");
- start2.sendBody("David");
-
- MockEndpoint.assertIsSatisfied(camelContext);
- MockEndpoint.assertIsSatisfied(camelContext2);
- assertTrue("Original endpoint was invoked", ((SedaEndpoint) original.getDelegate()).getExchanges().isEmpty());
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsTest.java
deleted file mode 100644
index 73dac9f..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerMockEndpointsTest.java
+++ /dev/null
@@ -1,57 +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.test.spring;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.ServiceStatus;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.seda.SedaEndpoint;
-import org.apache.camel.impl.InterceptSendToEndpoint;
-import org.junit.Test;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
-
-@MockEndpoints("seda:context2.seda")
-public class CamelSpringJUnit4ClassRunnerMockEndpointsTest
- extends CamelSpringJUnit4ClassRunnerPlainTest {
-
- @EndpointInject(uri = "mock:seda:context2.seda", context = "camelContext2")
- protected MockEndpoint mock;
-
- @EndpointInject(uri = "seda:context2.seda", context = "camelContext2")
- private InterceptSendToEndpoint original;
-
- @Test
- @Override
- public void testPositive() throws Exception {
-
- assertEquals(ServiceStatus.Started, camelContext.getStatus());
- assertEquals(ServiceStatus.Started, camelContext2.getStatus());
-
- mockA.expectedBodiesReceived("David");
- mockB.expectedBodiesReceived("Hello David");
- mockC.expectedBodiesReceived("David");
- mock.expectedBodiesReceived("Hello David");
-
- start.sendBody("David");
- start2.sendBody("David");
-
- MockEndpoint.assertIsSatisfied(camelContext);
- MockEndpoint.assertIsSatisfied(camelContext2);
- assertTrue("Original endpoint should be invoked", ((SedaEndpoint) original.getDelegate()).getExchanges().size() == 1);
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest.java
deleted file mode 100644
index 8b1504f..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest.java
+++ /dev/null
@@ -1,127 +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.test.spring;
-
-import java.util.concurrent.TimeUnit;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.EndpointInject;
-import org.apache.camel.Produce;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.ServiceStatus;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.management.DefaultManagementStrategy;
-import org.apache.camel.util.StopWatch;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.springframework.beans.factory.annotation.Autowired;
-import org.springframework.test.annotation.DirtiesContext;
-import org.springframework.test.annotation.DirtiesContext.ClassMode;
-import org.springframework.test.context.BootstrapWith;
-import org.springframework.test.context.ContextConfiguration;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertTrue;
-
-// START SNIPPET: e1
-@RunWith(CamelSpringJUnit4ClassRunner.class)
-// must tell Spring to bootstrap with Camel
-@BootstrapWith(CamelTestContextBootstrapper.class)
-@ContextConfiguration()
-// Put here to prevent Spring context caching across tests and test methods since some tests inherit
-// from this test and therefore use the same Spring context. Also because we want to reset the
-// Camel context and mock endpoints between test methods automatically.
-@DirtiesContext(classMode = ClassMode.AFTER_EACH_TEST_METHOD)
-public class CamelSpringJUnit4ClassRunnerPlainTest {
-
- @Autowired
- protected CamelContext camelContext;
-
- @Autowired
- protected CamelContext camelContext2;
-
- @EndpointInject(uri = "mock:a", context = "camelContext")
- protected MockEndpoint mockA;
-
- @EndpointInject(uri = "mock:b", context = "camelContext")
- protected MockEndpoint mockB;
-
- @EndpointInject(uri = "mock:c", context = "camelContext2")
- protected MockEndpoint mockC;
-
- @Produce(uri = "direct:start", context = "camelContext")
- protected ProducerTemplate start;
-
- @Produce(uri = "direct:start2", context = "camelContext2")
- protected ProducerTemplate start2;
-
- @Test
- public void testPositive() throws Exception {
- assertEquals(ServiceStatus.Started, camelContext.getStatus());
- assertEquals(ServiceStatus.Started, camelContext2.getStatus());
-
- mockA.expectedBodiesReceived("David");
- mockB.expectedBodiesReceived("Hello David");
- mockC.expectedBodiesReceived("David");
-
- start.sendBody("David");
- start2.sendBody("David");
-
- MockEndpoint.assertIsSatisfied(camelContext);
- MockEndpoint.assertIsSatisfied(camelContext2);
- }
-
- @Test
- public void testJmx() throws Exception {
- assertEquals(DefaultManagementStrategy.class, camelContext.getManagementStrategy().getClass());
- }
-
- @Test
- public void testShutdownTimeout() throws Exception {
- assertEquals(10, camelContext.getShutdownStrategy().getTimeout());
- assertEquals(TimeUnit.SECONDS, camelContext.getShutdownStrategy().getTimeUnit());
- }
-
- @Test
- public void testStopwatch() {
- StopWatch stopWatch = StopWatchTestExecutionListener.getStopWatch();
-
- assertNotNull(stopWatch);
- assertTrue(stopWatch.taken() < 100);
- }
-
- @Test
- public void testExcludedRoute() {
- assertNotNull(camelContext.getRoute("excludedRoute"));
- }
-
- @Test
- public void testProvidesBreakpoint() {
- assertNull(camelContext.getDebugger());
- assertNull(camelContext2.getDebugger());
- }
-
- @SuppressWarnings("deprecation")
- @Test
- public void testLazyLoadTypeConverters() {
- assertTrue(camelContext.isLazyLoadTypeConverters());
- assertTrue(camelContext2.isLazyLoadTypeConverters());
- }
-}
-// END SNIPPET: e1
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointInherritedTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointInherritedTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointInherritedTest.java
deleted file mode 100644
index 98d47e8..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointInherritedTest.java
+++ /dev/null
@@ -1,22 +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.test.spring;
-
-public class CamelSpringJUnit4ClassRunnerProvidesBreakpointInherritedTest
- extends CamelSpringJUnit4ClassRunnerProvidesBreakpointTest {
-
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointTest.java
deleted file mode 100644
index ae2d637..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerProvidesBreakpointTest.java
+++ /dev/null
@@ -1,67 +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.test.spring;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.impl.BreakpointSupport;
-import org.apache.camel.model.ProcessorDefinition;
-import org.apache.camel.spi.Breakpoint;
-
-import org.junit.Test;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-public class CamelSpringJUnit4ClassRunnerProvidesBreakpointTest
- extends CamelSpringJUnit4ClassRunnerPlainTest {
-
- @ProvidesBreakpoint
- public static Breakpoint createBreakpoint() {
- return new TestBreakpoint();
- }
-
- @Test
- @Override
- public void testProvidesBreakpoint() {
- assertNotNull(camelContext.getDebugger());
- assertNotNull(camelContext2.getDebugger());
-
- start.sendBody("David");
-
- assertNotNull(camelContext.getDebugger());
- assertNotNull(camelContext.getDebugger().getBreakpoints());
- assertEquals(1, camelContext.getDebugger().getBreakpoints().size());
-
- assertTrue(camelContext.getDebugger().getBreakpoints().get(0) instanceof TestBreakpoint);
- assertTrue(((TestBreakpoint) camelContext.getDebugger().getBreakpoints().get(0)).isBreakpointHit());
- }
-
- private static final class TestBreakpoint extends BreakpointSupport {
-
- private boolean breakpointHit;
-
- @Override
- public void beforeProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition) {
- breakpointHit = true;
- }
-
- public boolean isBreakpointHit() {
- return breakpointHit;
- }
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedOverrideTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedOverrideTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedOverrideTest.java
deleted file mode 100644
index c011d1f..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedOverrideTest.java
+++ /dev/null
@@ -1,34 +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.test.spring;
-
-import java.util.concurrent.TimeUnit;
-
-import org.junit.Test;
-import static org.junit.Assert.assertEquals;
-
-@ShutdownTimeout
-public class CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedOverrideTest
- extends CamelSpringJUnit4ClassRunnerShutdownTimeoutTest {
-
- @Test
- @Override
- public void testShutdownTimeout() throws Exception {
- assertEquals(10, camelContext.getShutdownStrategy().getTimeout());
- assertEquals(TimeUnit.SECONDS, camelContext.getShutdownStrategy().getTimeUnit());
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedTest.java
deleted file mode 100644
index 9f66625..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedTest.java
+++ /dev/null
@@ -1,22 +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.test.spring;
-
-public class CamelSpringJUnit4ClassRunnerShutdownTimeoutInheritedTest
- extends CamelSpringJUnit4ClassRunnerShutdownTimeoutTest {
-
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutTest.java
deleted file mode 100644
index 85a80ba..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerShutdownTimeoutTest.java
+++ /dev/null
@@ -1,34 +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.test.spring;
-
-import java.util.concurrent.TimeUnit;
-
-import org.junit.Test;
-import static org.junit.Assert.assertEquals;
-
-@ShutdownTimeout(value = 11, timeUnit = TimeUnit.MILLISECONDS)
-public class CamelSpringJUnit4ClassRunnerShutdownTimeoutTest
- extends CamelSpringJUnit4ClassRunnerPlainTest {
-
- @Test
- @Override
- public void testShutdownTimeout() throws Exception {
- assertEquals(11, camelContext.getShutdownStrategy().getTimeout());
- assertEquals(TimeUnit.MILLISECONDS, camelContext.getShutdownStrategy().getTimeUnit());
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerUseAdviceWithTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerUseAdviceWithTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerUseAdviceWithTest.java
deleted file mode 100644
index 7cf5e06..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerUseAdviceWithTest.java
+++ /dev/null
@@ -1,52 +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.test.spring;
-
-import org.apache.camel.ServiceStatus;
-import org.apache.camel.util.StopWatch;
-import org.junit.Before;
-import org.junit.Test;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-@UseAdviceWith
-public class CamelSpringJUnit4ClassRunnerUseAdviceWithTest extends CamelSpringJUnit4ClassRunnerPlainTest {
-
- @Before
- public void testContextStarted() throws Exception {
-
- assertEquals(ServiceStatus.Stopped, camelContext.getStatus());
- assertEquals(ServiceStatus.Stopped, camelContext2.getStatus());
- camelContext.start();
- camelContext2.start();
-
- // just sleep a little to simulate testing take a bit time
- Thread.sleep(1000);
- }
-
- @Test
- public void testStopwatch() {
- StopWatch stopWatch = StopWatchTestExecutionListener.getStopWatch();
-
- assertNotNull(stopWatch);
- long taken = stopWatch.taken();
- assertTrue(taken + " > 0, but was: " + taken, taken > 0);
- assertTrue(taken + " < 3000, but was: " + taken, taken < 3000);
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringTestSupportActiveProfileTest.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringTestSupportActiveProfileTest.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringTestSupportActiveProfileTest.java
deleted file mode 100644
index 7e7445c..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/CamelSpringTestSupportActiveProfileTest.java
+++ /dev/null
@@ -1,51 +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.test.spring;
-
-import org.junit.Test;
-import org.springframework.context.support.AbstractApplicationContext;
-import org.springframework.context.support.ClassPathXmlApplicationContext;
-
-// START SNIPPET: e1
-
-/**
- * Just extend the CamelSpringTestSupport and use Camel test kit for easy Camel based unit testing.
- */
-public class CamelSpringTestSupportActiveProfileTest extends CamelSpringTestSupport {
-
- @Override
- protected AbstractApplicationContext createApplicationContext() {
- // must not refresh when using active profiles
- // lets reuse the xml file from the other test
- return new ClassPathXmlApplicationContext(new String[]{"org/apache/camel/test/spring/CamelSpringActiveProfileTest-context.xml"}, false);
- }
-
- @Override
- protected String[] activeProfiles() {
- // return the active profiles to be used
- return new String[]{"test"};
- }
-
- @Test
- public void testLoadActiveProfile() throws InterruptedException {
- getMockEndpoint("mock:test").expectedBodiesReceived("Hello World");
- template.sendBody("direct:start", "World");
- assertMockEndpointsSatisfied();
- }
-
-}
-// END SNIPPET: e1
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/TestRouteBuilder.java
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/TestRouteBuilder.java b/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/TestRouteBuilder.java
deleted file mode 100644
index 52059c4..0000000
--- a/components/camel-test-spring41/src/test/java/org/apache/camel/test/spring/TestRouteBuilder.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.test.spring;
-
-import org.apache.camel.builder.RouteBuilder;
-
-public class TestRouteBuilder extends RouteBuilder {
-
- @Override
- public void configure() throws Exception {
-
- from("direct:z")
- .routeId("excludedRoute")
- .to("log:org.apache.camel.test.junit4.spring");
- }
-}
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/jndi.properties
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/jndi.properties b/components/camel-test-spring41/src/test/resources/jndi.properties
deleted file mode 100644
index 5961589..0000000
--- a/components/camel-test-spring41/src/test/resources/jndi.properties
+++ /dev/null
@@ -1,22 +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.
-## ---------------------------------------------------------------------------
-
-# START SNIPPET: jndi
-
-java.naming.factory.initial = org.apache.camel.util.jndi.CamelInitialContextFactory
-
-# END SNIPPET: jndi
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/log4j.properties b/components/camel-test-spring41/src/test/resources/log4j.properties
deleted file mode 100644
index 1eb13a5..0000000
--- a/components/camel-test-spring41/src/test/resources/log4j.properties
+++ /dev/null
@@ -1,37 +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.
-## ------------------------------------------------------------------------
-
-#
-# The logging properties used for testing
-#
-log4j.rootLogger=INFO, file
-
-log4j.logger.org.springframework=WARN
-#log4j.logger.org.apache.camel=DEBUG
-#log4j.logger.org.apache.camel.test.junit4=DEBUG
-
-# CONSOLE appender not used by default
-log4j.appender.out=org.apache.log4j.ConsoleAppender
-log4j.appender.out.layout=org.apache.log4j.PatternLayout
-log4j.appender.out.layout.ConversionPattern=[%30.30t] %-30.30c{1} %-5p %m%n
-#log4j.appender.out.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
-
-# File appender
-log4j.appender.file=org.apache.log4j.FileAppender
-log4j.appender.file.layout=org.apache.log4j.PatternLayout
-log4j.appender.file.layout.ConversionPattern=%d %-5p %c{1} - %m %n
-log4j.appender.file.file=target/camel-spring-test.log
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/AdviceWithOnExceptionMultipleIssueTest.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/AdviceWithOnExceptionMultipleIssueTest.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/AdviceWithOnExceptionMultipleIssueTest.xml
deleted file mode 100644
index 76b18ed..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/AdviceWithOnExceptionMultipleIssueTest.xml
+++ /dev/null
@@ -1,47 +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"
- xmlns:camel="http://camel.apache.org/schema/spring"
- xsi:schemaLocation="
- http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
- <camelContext xmlns="http://camel.apache.org/schema/spring">
-
- <onException>
- <exception>java.lang.Exception</exception>
- <handled>
- <constant>true</constant>
- </handled>
- <to uri="mock:error"/>
- </onException>
-
- <route id="RouteA">
- <from uri="direct:startA"/>
- <to uri="mock:resultA"/>
- </route>
-
- <route id="RouteB">
- <from uri="direct:startB"/>
- <to uri="mock:resultB"/>
- </route>
-
- </camelContext>
-
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/MockEndpointsAndSkipTest.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/MockEndpointsAndSkipTest.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/MockEndpointsAndSkipTest.xml
deleted file mode 100644
index 81b9093..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/issues/MockEndpointsAndSkipTest.xml
+++ /dev/null
@@ -1,35 +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"
- xmlns:camel="http://camel.apache.org/schema/spring"
- xsi:schemaLocation="
- http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
- <camelContext xmlns="http://camel.apache.org/schema/spring">
-
- <route>
- <from uri="direct:start"/>
- <to uri="log:foo"/>
- <to uri="seda:foo"/>
- </route>
-
- </camelContext>
-
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanInjectTest.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanInjectTest.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanInjectTest.xml
deleted file mode 100644
index a697e1d..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanInjectTest.xml
+++ /dev/null
@@ -1,39 +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"
- xmlns:camel="http://camel.apache.org/schema/spring"
- xsi:schemaLocation="
- http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
-
- <camelContext id="camelContext" xmlns="http://camel.apache.org/schema/spring">
- <route>
- <from uri="direct:start"/>
- <transform>
- <simple>${in.body} rocks!</simple>
- </transform>
- </route>
- </camelContext>
-
- <!--bean id="camelPostProcessBean" class="org.apache.camel.spring.CamelBeanPostProcessor" /-->
-
- <bean id="myProduceBean" class="org.apache.camel.test.patterns.MyProduceBean"/>
-
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanTest.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanTest.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanTest.xml
deleted file mode 100644
index 525ed01..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/ProduceBeanTest.xml
+++ /dev/null
@@ -1,33 +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"
- xmlns:camel="http://camel.apache.org/schema/spring"
- xsi:schemaLocation="
- http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
-<camelContext id="camelContext" xmlns="http://camel.apache.org/schema/spring">
-
- <route>
- <from uri="direct:start"/>
- <bean beanType="org.apache.camel.test.patterns.MyProduceBean"/>
- </route>
- </camelContext>
-
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/applicationContext.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/applicationContext.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/applicationContext.xml
deleted file mode 100644
index 081ae23..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/patterns/applicationContext.xml
+++ /dev/null
@@ -1,38 +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"
- xmlns:camel="http://camel.apache.org/schema/spring"
- xsi:schemaLocation="
- http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
-
- <camelContext id="camelContext" xmlns="http://camel.apache.org/schema/spring" trace="true" autoStartup="true" >
-
- <route>
- <from uri="direct:start" />
- <to uri="mock:a" />
- <transform>
- <simple>Hello ${body}</simple>
- </transform>
- <to uri="mock:b" />
- </route>
- </camelContext>
-
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringActiveProfileTest-context.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringActiveProfileTest-context.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringActiveProfileTest-context.xml
deleted file mode 100644
index ceacb2d..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringActiveProfileTest-context.xml
+++ /dev/null
@@ -1,41 +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"
- xmlns:camel="http://camel.apache.org/schema/spring"
- xsi:schemaLocation="
- http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
- <camelContext id="camelContext" xmlns="http://camel.apache.org/schema/spring">
- <route>
- <from uri="direct:start" />
- <transform>
- <simple>Hello ${body}</simple>
- </transform>
- <to uri="properties:{{cool.end}}" />
- </route>
- </camelContext>
-
- <!-- setup the profile for testing -->
- <beans profile="test">
- <bean id="bridgePropertyPlaceholder" class="org.apache.camel.spring.spi.BridgePropertyPlaceholderConfigurer">
- <property name="location" value="classpath:org/apache/camel/test/spring/test.properties"/>
- </bean>
- </beans>
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest-context.xml
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest-context.xml b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest-context.xml
deleted file mode 100644
index ee2e7ce..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/CamelSpringJUnit4ClassRunnerPlainTest-context.xml
+++ /dev/null
@@ -1,50 +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://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
- http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd ">
-
- <camelContext id="camelContext" xmlns="http://camel.apache.org/schema/spring" trace="true" autoStartup="true">
- <packageScan>
- <package>org.apache.camel.test.spring</package>
- </packageScan>
- <route>
- <from uri="direct:start"/>
- <to uri="mock:a"/>
- <transform>
- <simple>Hello ${body}</simple>
- </transform>
- <to uri="mock:b"/>
- </route>
- </camelContext>
-
- <camelContext id="camelContext2" xmlns="http://camel.apache.org/schema/spring" trace="true" autoStartup="true">
- <route>
- <from uri="direct:start2"/>
- <to uri="mock:c"/>
- <transform>
- <simple>Hello ${body}</simple>
- </transform>
- <to uri="log:org.apache.camel.test.junit4.spring"/>
- <to uri="seda:context2.seda"/>
- </route>
- </camelContext>
-
-</beans>
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/test.properties
----------------------------------------------------------------------
diff --git a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/test.properties b/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/test.properties
deleted file mode 100644
index f891086..0000000
--- a/components/camel-test-spring41/src/test/resources/org/apache/camel/test/spring/test.properties
+++ /dev/null
@@ -1,18 +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.
-## ---------------------------------------------------------------------------
-
-cool.end=mock:test
\ No newline at end of file
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/components/pom.xml
----------------------------------------------------------------------
diff --git a/components/pom.xml b/components/pom.xml
index adab222..dd8e8c4 100644
--- a/components/pom.xml
+++ b/components/pom.xml
@@ -38,7 +38,7 @@
<module>camel-test-blueprint</module>
<module>camel-test-spring</module>
<module>camel-test-spring3</module>
- <module>camel-test-spring41</module>
+ <module>camel-test-spring40</module>
<module>camel-core-osgi</module>
<module>camel-core-xml</module>
<module>camel-blueprint</module>
http://git-wip-us.apache.org/repos/asf/camel/blob/7764c326/parent/pom.xml
----------------------------------------------------------------------
diff --git a/parent/pom.xml b/parent/pom.xml
index fcda654..5c9ea80 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -410,8 +410,8 @@
<spring-version-range>[3.2,4)</spring-version-range>
<spring-version>${spring4-version}</spring-version>
<spring32-version>3.2.11.RELEASE</spring32-version>
- <spring4-version>4.0.7.RELEASE</spring4-version>
- <spring41-version>4.1.0.RELEASE</spring41-version>
+ <spring40-version>4.0.7.RELEASE</spring40-version>
+ <spring4-version>4.1.0.RELEASE</spring4-version>
<spring-osgi-version>1.2.1</spring-osgi-version>
<spring-security-version>3.2.5.RELEASE</spring-security-version>
<spring-ws-version>2.1.4.RELEASE</spring-ws-version>
@@ -1361,7 +1361,7 @@
</dependency>
<dependency>
<groupId>org.apache.camel</groupId>
- <artifactId>camel-test-spring41</artifactId>
+ <artifactId>camel-test-spring40</artifactId>
<version>${project.version}</version>
</dependency>
<dependency>
|