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 2020/03/24 11:19:37 UTC

[camel] branch master updated: Camel-Mllp: Removed refs to camel-test-blueprint (camel-karaf migration)

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

acosentino 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 332fde4  Camel-Mllp: Removed refs to camel-test-blueprint (camel-karaf migration)
332fde4 is described below

commit 332fde4c6deec5f54e3020cb00d78a615b534800
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Tue Mar 24 12:19:10 2020 +0100

    Camel-Mllp: Removed refs to camel-test-blueprint (camel-karaf migration)
---
 components/camel-mllp/pom.xml                      |   5 -
 .../mllp/MllpConfigurationBeanBlueprintTest.java   |  59 -----------
 .../mllp/MllpTcpClientProducerBlueprintTest.java   | 113 ---------------------
 .../mllp/MllpTcpServerConsumerBlueprintTest.java   |  99 ------------------
 .../blueprint/mllp-configuration-bean-test.xml     |  50 ---------
 .../blueprint/mllp-tcp-client-producer-test.xml    | 105 -------------------
 .../blueprint/mllp-tcp-server-consumer-test.xml    |  45 --------
 7 files changed, 476 deletions(-)

diff --git a/components/camel-mllp/pom.xml b/components/camel-mllp/pom.xml
index b7799fa..b185183 100644
--- a/components/camel-mllp/pom.xml
+++ b/components/camel-mllp/pom.xml
@@ -50,11 +50,6 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel</groupId>
-            <artifactId>camel-test-blueprint</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.camel</groupId>
             <artifactId>camel-sjms</artifactId>
             <scope>test</scope>
         </dependency>
diff --git a/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpConfigurationBeanBlueprintTest.java b/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpConfigurationBeanBlueprintTest.java
deleted file mode 100644
index e8d2d32..0000000
--- a/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpConfigurationBeanBlueprintTest.java
+++ /dev/null
@@ -1,59 +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.component.mllp;
-
-import java.util.Dictionary;
-import java.util.Map;
-import java.util.concurrent.TimeUnit;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.impl.engine.DefaultComponentResolver;
-import org.apache.camel.spi.ComponentResolver;
-import org.apache.camel.test.blueprint.CamelBlueprintTestSupport;
-import org.apache.camel.util.KeyValueHolder;
-import org.junit.Test;
-
-public class MllpConfigurationBeanBlueprintTest extends CamelBlueprintTestSupport {
-    @EndpointInject("mock://target")
-    MockEndpoint received;
-
-    @Override
-    protected void addServicesOnStartup(Map<String, KeyValueHolder<Object, Dictionary>> services) {
-        ComponentResolver testResolver = new DefaultComponentResolver();
-
-        services.put(ComponentResolver.class.getName(), asService(testResolver, "component", "mllp"));
-    }
-
-    @Override
-    protected String getBlueprintDescriptor() {
-        return "OSGI-INF/blueprint/mllp-configuration-bean-test.xml";
-    }
-
-    @Test
-    public void testReceiveMultipleMessages() throws Exception {
-        int sendMessageCount = 5;
-        received.expectedMinimumMessageCount(5);
-
-        for (int i = 1; i <= sendMessageCount; ++i) {
-            template.sendBody("direct://source", "Message " + i);
-        }
-
-        assertMockEndpointsSatisfied(10, TimeUnit.SECONDS);
-    }
-
-}
diff --git a/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpTcpClientProducerBlueprintTest.java b/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpTcpClientProducerBlueprintTest.java
deleted file mode 100644
index c043a65..0000000
--- a/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpTcpClientProducerBlueprintTest.java
+++ /dev/null
@@ -1,113 +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.component.mllp;
-
-import java.util.Dictionary;
-import java.util.Map;
-import java.util.Properties;
-import java.util.concurrent.TimeUnit;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.impl.engine.DefaultComponentResolver;
-import org.apache.camel.spi.ComponentResolver;
-import org.apache.camel.test.AvailablePortFinder;
-import org.apache.camel.test.blueprint.CamelBlueprintTestSupport;
-import org.apache.camel.test.junit.rule.mllp.MllpServerResource;
-import org.apache.camel.test.mllp.Hl7TestMessageGenerator;
-import org.apache.camel.util.KeyValueHolder;
-import org.junit.Rule;
-import org.junit.Test;
-
-public class MllpTcpClientProducerBlueprintTest extends CamelBlueprintTestSupport {
-    static final String SOURCE_URI = "direct-vm://source";
-    static final String MOCK_ACKNOWLEDGED_URI = "mock://acknowledged";
-    static final String MOCK_TIMEOUT_URI = "mock://timeoutError-ex";
-    static final String MOCK_AE_EX_URI = "mock://ae-ack";
-    static final String MOCK_AR_EX_URI = "mock://ar-ack";
-    static final String MOCK_FRAME_EX_URI = "mock://frameError-ex";
-
-    @Rule
-    public MllpServerResource mllpServer = new MllpServerResource("0.0.0.0", AvailablePortFinder.getNextAvailable());
-
-    @EndpointInject(MOCK_ACKNOWLEDGED_URI)
-    MockEndpoint acknowledged;
-
-    @EndpointInject(MOCK_TIMEOUT_URI)
-    MockEndpoint timeout;
-
-    @EndpointInject(MOCK_AE_EX_URI)
-    MockEndpoint ae;
-
-    @EndpointInject(MOCK_AR_EX_URI)
-    MockEndpoint ar;
-
-    @EndpointInject(MOCK_FRAME_EX_URI)
-    MockEndpoint frame;
-
-    @Override
-    protected void addServicesOnStartup(Map<String, KeyValueHolder<Object, Dictionary>> services) {
-        ComponentResolver testResolver = new DefaultComponentResolver();
-
-        services.put(ComponentResolver.class.getName(), asService(testResolver, "component", "mllp"));
-    }
-
-
-    @Override
-    protected String setConfigAdminInitialConfiguration(Properties props) {
-        props.setProperty("sourceUri", SOURCE_URI);
-        props.setProperty("acknowledgedUri", MOCK_ACKNOWLEDGED_URI);
-        props.setProperty("timeoutUri", MOCK_TIMEOUT_URI);
-        props.setProperty("errorAcknowledgementUri", MOCK_AE_EX_URI);
-        props.setProperty("rejectAcknowledgementUri", MOCK_AR_EX_URI);
-
-        props.setProperty("mllp.port", Integer.toString(mllpServer.getListenPort()));
-
-        return "MllpTcpClientProducer";
-    }
-
-
-    @Override
-    protected String getBlueprintDescriptor() {
-        return "OSGI-INF/blueprint/mllp-tcp-client-producer-test.xml";
-    }
-
-    @Test()
-    public void testSendMultipleMessages() throws Exception {
-        int messageCount = 500;
-        acknowledged.expectedMessageCount(messageCount);
-        timeout.expectedMessageCount(0);
-        frame.expectedMessageCount(0);
-        ae.expectedMessageCount(0);
-        ar.expectedMessageCount(0);
-
-        startCamelContext();
-        // Uncomment one of these lines to see the NACKs handled
-        // mllpServer.setSendApplicationRejectAcknowledgementModulus(10);
-        // mllpServer.setSendApplicationErrorAcknowledgementModulus(10);
-
-        for (int i = 0; i < messageCount; ++i) {
-            log.debug("Triggering message {}", i);
-            // Thread.sleep(5000);
-            Object response = template.requestBodyAndHeader(SOURCE_URI, Hl7TestMessageGenerator.generateMessage(i), "CamelMllpMessageControlId", String.format("%05d", i));
-            log.debug("response {}\n{}", i, response);
-        }
-
-        assertMockEndpointsSatisfied(15, TimeUnit.SECONDS);
-    }
-
-}
diff --git a/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpTcpServerConsumerBlueprintTest.java b/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpTcpServerConsumerBlueprintTest.java
deleted file mode 100644
index 6cc6cb3..0000000
--- a/components/camel-mllp/src/test/java/org/apache/camel/component/mllp/MllpTcpServerConsumerBlueprintTest.java
+++ /dev/null
@@ -1,99 +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.component.mllp;
-
-import java.util.Dictionary;
-import java.util.Map;
-import java.util.Properties;
-import java.util.concurrent.TimeUnit;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.impl.engine.DefaultComponentResolver;
-import org.apache.camel.spi.ComponentResolver;
-import org.apache.camel.test.AvailablePortFinder;
-import org.apache.camel.test.blueprint.CamelBlueprintTestSupport;
-import org.apache.camel.test.junit.rule.mllp.MllpClientResource;
-import org.apache.camel.test.mllp.Hl7TestMessageGenerator;
-import org.apache.camel.util.KeyValueHolder;
-import org.junit.Rule;
-import org.junit.Test;
-
-public class MllpTcpServerConsumerBlueprintTest extends CamelBlueprintTestSupport {
-    static final String RECEIVED_URI = "mock://received";
-    static final String MLLP_HOST = "localhost";
-
-    @Rule
-    public MllpClientResource mllpClient = new MllpClientResource();
-    @EndpointInject(RECEIVED_URI)
-    MockEndpoint received;
-
-    @Override
-    protected void addServicesOnStartup(Map<String, KeyValueHolder<Object, Dictionary>> services) {
-        ComponentResolver testResolver = new DefaultComponentResolver();
-
-        services.put(ComponentResolver.class.getName(), asService(testResolver, "component", "mllp"));
-    }
-
-    @Override
-    protected String getBlueprintDescriptor() {
-        return "OSGI-INF/blueprint/mllp-tcp-server-consumer-test.xml";
-    }
-
-    @Override
-    protected Properties useOverridePropertiesWithPropertiesComponent() {
-        mllpClient.setMllpHost(MLLP_HOST);
-        mllpClient.setMllpPort(AvailablePortFinder.getNextAvailable());
-
-        Properties props = new Properties();
-
-        props.setProperty("RECEIVED_URI", RECEIVED_URI);
-        props.setProperty("mllp.host", mllpClient.getMllpHost());
-        props.setProperty("mllp.port", Integer.toString(mllpClient.getMllpPort()));
-
-        return props;
-    }
-
-    /*
-        This doesn't seem to work
-    @Override
-    protected String useOverridePropertiesWithConfigAdmin(Dictionary props) throws Exception {
-        mllpClient.setMllpPort(AvailablePortFinder.getNextAvailable());
-
-        props.put("mllp.port", mllpClient.getMllpPort() );
-
-        return "MllpTcpServerConsumerBlueprintTest";
-    }
-    */
-
-    @Test
-    public void testReceiveMultipleMessages() throws Exception {
-        int sendMessageCount = 5;
-        received.expectedMinimumMessageCount(5);
-
-        mllpClient.connect();
-
-        for (int i = 1; i <= sendMessageCount; ++i) {
-            mllpClient.sendMessageAndWaitForAcknowledgement(Hl7TestMessageGenerator.generateMessage(i));
-        }
-
-        mllpClient.close();
-
-        assertMockEndpointsSatisfied(10, TimeUnit.SECONDS);
-    }
-
-}
diff --git a/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-configuration-bean-test.xml b/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-configuration-bean-test.xml
deleted file mode 100644
index 6189670..0000000
--- a/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-configuration-bean-test.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.
-
--->
-<blueprint xmlns="http://www.osgi.org/xmlns/blueprint/v1.0.0"
-           xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-           xsi:schemaLocation="
-                http://www.osgi.org/xmlns/blueprint/v1.0.0 https://www.osgi.org/xmlns/blueprint/v1.0.0/blueprint.xsd
-                http://aries.apache.org/blueprint/xmlns/blueprint-cm/v1.1.0 http://aries.apache.org/schemas/blueprint-cm/blueprint-cm-1.1.0.xsd
-                http://camel.apache.org/schema/blueprint http://camel.apache.org/schema/blueprint/camel-blueprint.xsd">
-
-    <property-placeholder persistent-id="MllpTcpServerConsumerBlueprintTest" update-strategy="reload" xmlns="http://aries.apache.org/blueprint/xmlns/blueprint-cm/v1.1.0" >
-        <default-properties>
-            <property name="sourceUri" value="direct://source" />
-            <property name="targetUri" value="mock://target" />
-        </default-properties>
-    </property-placeholder>
-
-    <bean id="mllp-configuration" class="org.apache.camel.component.mllp.MllpConfiguration" >
-        <property name="charsetName" value="ASCII" />
-    </bean>
-
-
-    <camelContext id="mllp-configuration-bean-context" useMDCLogging="true" xmlns="http://camel.apache.org/schema/blueprint">
-        <route>
-            <from uri="{{sourceUri}}" />
-            <filter>
-                <simple>$simple{header[DummyHeader]} == 'foo'</simple>
-                <to uri="mllp://localhost:12345?configuration=#mllp-configuration&amp;autoAck=false&amp;bridgeErrorHandler=true" />
-            </filter>
-            <to uri="{{targetUri}}" />
-        </route>
-    </camelContext>
-
-</blueprint>
diff --git a/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-tcp-client-producer-test.xml b/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-tcp-client-producer-test.xml
deleted file mode 100644
index a19bd57..0000000
--- a/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-tcp-client-producer-test.xml
+++ /dev/null
@@ -1,105 +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.
-
--->
-<blueprint xmlns="http://www.osgi.org/xmlns/blueprint/v1.0.0"
-           xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-           xsi:schemaLocation="
-                http://www.osgi.org/xmlns/blueprint/v1.0.0 https://www.osgi.org/xmlns/blueprint/v1.0.0/blueprint.xsd
-                http://aries.apache.org/blueprint/xmlns/blueprint-cm/v1.1.0 http://aries.apache.org/schemas/blueprint-cm/blueprint-cm-1.1.0.xsd
-                http://camel.apache.org/schema/blueprint http://camel.apache.org/schema/blueprint/camel-blueprint.xsd">
-
-    <property-placeholder persistent-id="MllpTcpClientProducer" update-strategy="reload" xmlns="http://aries.apache.org/blueprint/xmlns/blueprint-cm/v1.1.0" >
-        <default-properties>
-            <property name="sourceUri" value="direct://source" />
-            <property name="acknowledgedUri" value="mock://acknowledged" />
-            <property name="timeoutUri" value="mock://timeout-ex" />
-            <property name="errorAcknowledgementUri" value="mock://ae-ack" />
-            <property name="rejectAcknowledgementUri" value="mock://ar-ack" />
-            <property name="mllp.host" value="0.0.0.0" />
-            <property name="mllp.port" value="7777" />
-        </default-properties>
-    </property-placeholder>
-
-
-    <errorHandler id="DefaultErrorHandler" type="DefaultErrorHandler" xmlns="http://camel.apache.org/schema/blueprint">
-        <redeliveryPolicy allowRedeliveryWhileStopping="false"/>
-    </errorHandler>
-
-    <camelContext id="mllp-tcp-client-producer-test" xmlns="http://camel.apache.org/schema/blueprint"
-                        useMDCLogging="true" trace="false"
-                        >
-
-        <onException>
-            <exception>java.net.ConnectException</exception>
-            <redeliveryPolicy
-                    allowRedeliveryWhileStopping="false"
-                    redeliveryDelay="500"
-                    maximumRedeliveryDelay="30000"
-                    backOffMultiplier="2"
-                    useExponentialBackOff="true"
-                    maximumRedeliveries="-1"
-                    logRetryAttempted="true"
-                    retryAttemptedLogLevel="WARN"
-            />
-        </onException>
-
-        <onException>
-            <exception>org.apache.camel.component.mllp.MllpAcknowledgementTimeoutException</exception>
-            <redeliveryPolicy logHandled="true"/>
-            <handled>
-                <constant>true</constant>
-            </handled>
-            <to uri="{{timeoutUri}}"/>
-        </onException>
-
-        <onException>
-            <exception>org.apache.camel.component.mllp.MllpApplicationErrorAcknowledgementException</exception>
-            <redeliveryPolicy logHandled="true" logRetryAttempted="true" retryAttemptedLogLevel="WARN" logExhausted="true" retriesExhaustedLogLevel="ERROR"
-                    allowRedeliveryWhileStopping="false"
-                    maximumRedeliveries="10"
-                    redeliveryDelay="1000"
-                    useExponentialBackOff="true"
-                    maximumRedeliveryDelay="15000"
-            />
-            <handled>
-                <constant>true</constant>
-            </handled>
-            <to uri="{{errorAcknowledgementUri}}" />
-        </onException>
-
-        <onException>
-            <exception>org.apache.camel.component.mllp.MllpApplicationRejectAcknowledgementException</exception>
-            <redeliveryPolicy logHandled="true" />
-            <handled>
-                <constant>true</constant>
-            </handled>
-            <to uri="{{rejectAcknowledgementUri}}" />
-        </onException>
-
-        <route id="direct-to-mllp">
-            <from uri="{{sourceUri}}" />
-            <log loggingLevel="DEBUG" message="sending message: $simple{header[CamelMllpMessageControlId]}" />
-            <to uri="mllp://{{mllp.host}}:{{mllp.port}}"/>
-            <to uri="{{acknowledgedUri}}"/>
-            <log loggingLevel="DEBUG" message="message sent: $simple{header[CamelMllpMessageControlId]}" />
-            <to uri="log:direct-to-mllp?level=INFO&amp;groupSize=50" />
-        </route>
-    </camelContext>
-
-</blueprint>
diff --git a/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-tcp-server-consumer-test.xml b/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-tcp-server-consumer-test.xml
deleted file mode 100644
index c7313b9..0000000
--- a/components/camel-mllp/src/test/resources/OSGI-INF/blueprint/mllp-tcp-server-consumer-test.xml
+++ /dev/null
@@ -1,45 +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.
-
--->
-<blueprint xmlns="http://www.osgi.org/xmlns/blueprint/v1.0.0"
-           xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-           xsi:schemaLocation="
-                http://www.osgi.org/xmlns/blueprint/v1.0.0 https://www.osgi.org/xmlns/blueprint/v1.0.0/blueprint.xsd
-                http://aries.apache.org/blueprint/xmlns/blueprint-cm/v1.1.0 http://aries.apache.org/schemas/blueprint-cm/blueprint-cm-1.1.0.xsd
-                http://camel.apache.org/schema/blueprint http://camel.apache.org/schema/blueprint/camel-blueprint.xsd">
-
-    <property-placeholder persistent-id="MllpTcpServerConsumerBlueprintTest" update-strategy="reload" xmlns="http://aries.apache.org/blueprint/xmlns/blueprint-cm/v1.1.0" >
-        <default-properties>
-            <property name="receivedUri" value="mock://received" />
-            <property name="mllp.host" value="localhost" />
-            <property name="mllp.port" value="7777" />
-        </default-properties>
-    </property-placeholder>
-
-
-
-    <camelContext id="tcp-server-consumer-context" useMDCLogging="true" xmlns="http://camel.apache.org/schema/blueprint">
-        <!-- TODO:  Add exception handlers -->
-        <route>
-            <from uri="mllp://{{mllp.host}}:{{mllp.port}}" />
-            <to uri="{{receivedUri}}" />
-        </route>
-    </camelContext>
-
-</blueprint>