You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@servicemix.apache.org by lh...@apache.org on 2009/01/26 22:49:15 UTC

svn commit: r737876 [2/2] - in /servicemix/components/bindings/servicemix-smpp/trunk: ./ src/ src/main/ src/main/java/ src/main/java/org/ src/main/java/org/apache/ src/main/java/org/apache/servicemix/ src/main/java/org/apache/servicemix/smpp/ src/main/...

Added: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppMarshalerTest.java
URL: http://svn.apache.org/viewvc/servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppMarshalerTest.java?rev=737876&view=auto
==============================================================================
--- servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppMarshalerTest.java (added)
+++ servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppMarshalerTest.java Mon Jan 26 21:49:14 2009
@@ -0,0 +1,273 @@
+/*
+ * 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.servicemix.smpp;
+
+import java.io.IOException;
+import java.util.concurrent.atomic.AtomicBoolean;
+
+import javax.jbi.messaging.MessageExchange;
+import javax.jbi.messaging.MessageExchangeFactory;
+import javax.jbi.messaging.MessagingException;
+import javax.jbi.messaging.NormalizedMessage;
+import javax.xml.parsers.ParserConfigurationException;
+import javax.xml.transform.TransformerException;
+
+import junit.framework.TestCase;
+
+import org.apache.servicemix.id.IdGenerator;
+import org.apache.servicemix.jbi.helper.MessageExchangePattern;
+import org.apache.servicemix.jbi.jaxp.SourceTransformer;
+import org.apache.servicemix.jbi.jaxp.StringSource;
+import org.apache.servicemix.jbi.messaging.MessageExchangeFactoryImpl;
+import org.apache.servicemix.smpp.marshaler.DefaultSmppMarshaler;
+import org.apache.servicemix.smpp.marshaler.SmppMarshalerSupport;
+import org.jsmpp.bean.MessageRequest;
+import org.jsmpp.bean.NumberingPlanIndicator;
+import org.jsmpp.bean.SubmitSm;
+import org.jsmpp.bean.TypeOfNumber;
+import org.xml.sax.SAXException;
+
+/**
+ * Unit tests on the SMPP marshaler
+ * 
+ * @author jbonofre
+ */
+public class SmppMarshalerTest extends TestCase {
+
+    private static final String SOURCE = "0123456789";
+    private static final String DESTINATION = "9876543210";
+    private static final String TEXT = "This is a SMPP test ...";
+    private static final String NPI = "NATIONAL";
+    private static final String TON = "INTERNATIONAL";
+
+    private static final String MSG_VALID = "<message><source>" + SOURCE + "</source><destination>"
+                                            + DESTINATION + "</destination><text>" + TEXT + "</text><npi>"
+                                            + NPI + "</npi><ton>" + TON + "</ton></message>";
+    private static final String MSG_INVALID = "Test breaker ...";
+    private static final String MSG_INVALID_DEST = "<message><source>" + SOURCE + "</source><text>" + TEXT
+                                                   + "</text><npi>" + NPI + "</npi><ton>" + TON
+                                                   + "</ton></message>";
+    private static final String MSG_INVALID_TON = "<message><source>" + SOURCE + "</source><destination>"
+                                                  + DESTINATION + "</destination><text>" + TEXT
+                                                  + "</text><npi>" + NPI + "</npi></message>";
+    private static final String MSG_INVALID_NPI = "<message><source>" + SOURCE + "</source><destination>"
+                                                  + DESTINATION + "</destination><text>" + TEXT
+                                                  + "</text><ton>" + TON + "</ton></message>";
+
+    private SmppMarshalerSupport marshaler;
+    private MessageExchangeFactory factory;
+
+    /**
+     * @see junit.framework.TestCase#setUp()
+     */
+    public void setUp() throws Exception {
+        this.marshaler = new DefaultSmppMarshaler();
+        this.factory = new MessageExchangeFactoryImpl(new IdGenerator(), new AtomicBoolean(false));
+    }
+
+    /**
+     * @see junit.framework.TestCase#tearDown()
+     */
+    public void tearDown() {
+        this.marshaler = null;
+        this.factory = null;
+    }
+
+    // UNIT TESTS
+
+    public void testFromNMSValid() {
+        try {
+            // construct the MessageExchange and NormalizedMessage
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            message.setContent(new StringSource(MSG_VALID));
+            exchange.setMessage(message, "in");
+            // use the marshaler to converts the NormalizedMessage to a
+            // MessageRequest
+            MessageRequest mr = marshaler.fromNMS(exchange, message);
+            assertEquals("The message text is not the same: ", TEXT, new String(mr.getShortMessage()));
+            assertEquals("The destination address is not the same: ", mr.getDestAddress(), DESTINATION);
+            assertEquals("The source address is not the same: ", SOURCE, mr.getSourceAddr());
+            assertEquals("The destination type of number is not the same: ", TON, TypeOfNumber
+                .valueOf(mr.getDestAddrTon()).toString());
+            assertEquals("The source type of number is not the same: ", TON, TypeOfNumber
+                .valueOf(mr.getSourceAddrTon()).toString());
+            assertEquals("The destination numbering plan indicator is not the same: ", NPI,
+                         NumberingPlanIndicator.valueOf(mr.getDestAddrNpi()).toString());
+            assertEquals("The source numbering plan indicator is not the same: ", NPI, NumberingPlanIndicator
+                .valueOf(mr.getSourceAddrNpi()).toString());
+        } catch (MessagingException messagingException) {
+            fail("Messaging exception occurs when constructing the exchange and the normalized message : "
+                 + messagingException.getMessage());
+        } catch (TransformerException transformerException) {
+            fail("Transformer exception occurs while using the marshaler to converts the normalized message to the message request : "
+                 + transformerException.getMessage());
+        }
+    }
+
+    public void testFromNMSNullExchange() {
+        try {
+            marshaler.fromNMS(null, null);
+            fail("Seems we processed a message with null exchange...");
+        } catch (TransformerException transformerException) {
+            // fine
+        }
+    }
+
+    public void testFromNMSInvalid() {
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            message.setContent(new StringSource(MSG_INVALID));
+            exchange.setMessage(message, "in");
+            // use the marshaler to converts the NormalizedMessage to a
+            // MessageRequest
+            MessageRequest mr = marshaler.fromNMS(exchange, message);
+            fail("Seems we processed a invalid message...");
+        } catch (MessagingException messagingException) {
+            fail("Messaging exception occurs : " + messagingException.getMessage());
+        } catch (TransformerException transformerException) {
+            // fine
+        }
+    }
+
+    public void testFromNMSInvalidDest() {
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            message.setContent(new StringSource(MSG_INVALID_DEST));
+            exchange.setMessage(message, "in");
+            // use the marshaler to converts the NormalizedMessage to a
+            // MessageRequest
+            MessageRequest mr = marshaler.fromNMS(exchange, message);
+            fail("Seems we processed a message with a invalid destination...");
+        } catch (MessagingException messagingException) {
+            fail("Messaging exception occurs : " + messagingException.getMessage());
+        } catch (TransformerException transformerException) {
+            // fine
+        }
+    }
+
+    public void testFromNMSInvalidTon() {
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            message.setContent(new StringSource(MSG_INVALID_TON));
+            exchange.setMessage(message, "in");
+            // use the marshaler to converts the NormalizedMessage to a
+            // MessageRequest
+            MessageRequest mr = marshaler.fromNMS(exchange, message);
+            fail("Seems we processed a message with a invlid type of number...");
+        } catch (MessagingException messagingException) {
+            fail("Messaging exception occurs : " + messagingException.getMessage());
+        } catch (TransformerException transformerException) {
+            // fine
+        }
+    }
+
+    public void testFromNMSInvalidNpi() {
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            message.setContent(new StringSource(MSG_INVALID_NPI));
+            exchange.setMessage(message, "in");
+            // use the marshaler to converts the NormalizedMessage to a
+            // MessageRequest
+            MessageRequest mr = marshaler.fromNMS(exchange, message);
+            fail("Seems we processed a message with a invlid numbering plan indicator...");
+        } catch (MessagingException messagingException) {
+            fail("Messaging exception occurs : " + messagingException.getMessage());
+        } catch (TransformerException transformerException) {
+            // fine
+        }
+    }
+
+    public void testToNMSValid() {
+        // constructs the MessageRequest
+        MessageRequest mr = new SubmitSm();
+        mr.setDestAddress(DESTINATION);
+        mr.setDestAddrNpi(NumberingPlanIndicator.valueOf(NPI).value());
+        mr.setDestAddrTon(TypeOfNumber.valueOf(TON).value());
+        mr.setSourceAddr(SOURCE);
+        mr.setSourceAddrNpi(NumberingPlanIndicator.valueOf(NPI).value());
+        mr.setSourceAddrTon(TypeOfNumber.valueOf(TON).value());
+        mr.setShortMessage(TEXT.getBytes());
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            exchange.setMessage(message, "in");
+            marshaler.toNMS(message, mr);
+            SourceTransformer sourceTransformer = new SourceTransformer();
+            assertEquals("Message not correct: ", MSG_VALID, sourceTransformer.contentToString(message));
+        } catch (MessagingException messagingException) {
+            fail("Messaging exception occurs during the construction of the MessageExchange and NormalizedMessage: "
+                 + messagingException.getMessage());
+        } catch (TransformerException transformerException) {
+            fail("Transformer exception occurs using the marshaler: " + transformerException.getMessage());
+        } catch (ParserConfigurationException parserConfigurationException) {
+            fail("Parser configuration exception occurs using the SourceTransformer: "
+                 + parserConfigurationException.getMessage());
+        } catch (SAXException saxException) {
+            fail("SAX exception occurs using the SourceTransformer: " + saxException.getMessage());
+        } catch (IOException ioException) {
+            fail("IO exception occurs using the SourceTransformer: " + ioException.getMessage());
+        }
+    }
+
+    public void testToNMSInvalid() {
+        // constructs a invalid MessageRequest (without destination, source,
+        // NPI, TON)
+        MessageRequest mr = new SubmitSm();
+        mr.setShortMessage(TEXT.getBytes());
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            exchange.setMessage(message, "in");
+            marshaler.toNMS(message, mr);
+            fail("Seems we processed an invalid MessageRequest...");
+        } catch (MessagingException messagingException) {
+            // fine
+        }
+    }
+
+    public void testToNMSNullMessageRequest() {
+        MessageRequest mr = null;
+        try {
+            MessageExchange exchange = this.factory.createExchange(MessageExchangePattern.IN_ONLY);
+            NormalizedMessage message = exchange.createMessage();
+            exchange.setMessage(message, "in");
+            marshaler.toNMS(message, mr);
+            fail("Seems we processed a Null MessageRequest...");
+        } catch (MessagingException messagingException) {
+            // fine
+        }
+    }
+
+    public void testToNMSNullMessage() {
+        // constructs a invalid MessageRequest (without destination, source,
+        // NPI, TON)
+        MessageRequest mr = new SubmitSm();
+        mr.setShortMessage(TEXT.getBytes());
+        try {
+            marshaler.toNMS(null, mr);
+            fail("Seems we processed a MessageRequest with a Null NormalizedMessage...");
+        } catch (MessagingException messagingException) {
+            // fine
+        }
+    }
+
+}

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppMarshalerTest.java
------------------------------------------------------------------------------
    svn:executable = *

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppMarshalerTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppXBeanDeployerTest.java
URL: http://svn.apache.org/viewvc/servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppXBeanDeployerTest.java?rev=737876&view=auto
==============================================================================
--- servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppXBeanDeployerTest.java (added)
+++ servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppXBeanDeployerTest.java Mon Jan 26 21:49:14 2009
@@ -0,0 +1,89 @@
+package org.apache.servicemix.smpp;
+
+import java.io.File;
+import java.net.URI;
+import java.net.URL;
+
+import javax.jbi.messaging.InOut;
+import javax.xml.namespace.QName;
+
+import junit.framework.TestCase;
+
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.servicemix.client.DefaultServiceMixClient;
+import org.apache.servicemix.jbi.container.JBIContainer;
+import org.apache.servicemix.jbi.jaxp.StringSource;
+
+/**
+ * Validate the SMPP XBean descriptor
+ * 
+ * @author jbonofre
+ */
+public class SmppXBeanDeployerTest extends TestCase {
+
+    private final static transient Log log = LogFactory.getLog(SmppXBeanDeployerTest.class);
+
+    protected JBIContainer container;
+
+    protected void setUp() throws Exception {
+        container = new JBIContainer();
+        container.setUseMBeanServer(false);
+        container.setCreateMBeanServer(false);
+        container.setEmbedded(true);
+        container.init();
+    }
+
+    protected void tearDown() throws Exception {
+        if (container != null) {
+            container.shutDown();
+        }
+    }
+
+    /**
+     * Main test that check xbean deployment
+     * 
+     * @throws Exception in case of deployment errors
+     */
+    public void test() throws Exception {
+        // SMPP component
+        SmppComponent component = new SmppComponent();
+        container.activateComponent(component, "SMPPComponent");
+
+        // add a receiver component
+        // ActivationSpec asEcho = new ActivationSpec("echo", new
+        // EchoComponent() {
+        //	
+        // });
+
+        // start the container
+        container.start();
+
+        // deploy SU
+        URL url = getClass().getClassLoader().getResource("xbean/xbean.xml");
+        File path = new File(new URI(url.toString()));
+        path = path.getParentFile();
+        component.getServiceUnitManager().deploy("xbean", path.getAbsolutePath());
+        component.getServiceUnitManager().init("xbean", path.getAbsolutePath());
+        component.getServiceUnitManager().start("xbean");
+
+        // test if endpoint present
+        assertNotNull("The endpoint http://test/server/sender is not found in the JBI container", container
+            .getRegistry().getEndpoint(new QName("http://test", "service"), "sender"));
+        // test if the endpoint descriptor contains something
+        // TODO add WSDLs support in the SMPP component
+        // assertNotNull("The endpoint http://test/server/sender descriptor is null",
+        // container.getRegistry().getEndpointDescriptor(container.getRegistry().getEndpoint(new
+        // QName("http://test", "service"), "sender")));
+
+        // main test
+        DefaultServiceMixClient client = new DefaultServiceMixClient(container);
+        InOut me = client.createInOutExchange();
+        me.setService(new QName("http://test", "service"));
+        me.getInMessage().setContent(new StringSource("<test>Test</test>"));
+        client.sendSync(me);
+        // TODO test the MessageExchange ERROR status and fault
+        client.done(me);
+    }
+
+}

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppXBeanDeployerTest.java
------------------------------------------------------------------------------
    svn:executable = *

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SmppXBeanDeployerTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SpringComponentTest.java
URL: http://svn.apache.org/viewvc/servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SpringComponentTest.java?rev=737876&view=auto
==============================================================================
--- servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SpringComponentTest.java (added)
+++ servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SpringComponentTest.java Mon Jan 26 21:49:14 2009
@@ -0,0 +1,44 @@
+package org.apache.servicemix.smpp;
+
+import javax.jbi.messaging.ExchangeStatus;
+import javax.jbi.messaging.InOut;
+import javax.jbi.messaging.NormalizedMessage;
+import javax.xml.namespace.QName;
+
+import org.apache.servicemix.client.DefaultServiceMixClient;
+import org.apache.servicemix.client.ServiceMixClient;
+import org.apache.servicemix.jbi.jaxp.SourceTransformer;
+import org.apache.servicemix.jbi.jaxp.StringSource;
+import org.apache.servicemix.tck.SpringTestSupport;
+import org.apache.xbean.spring.context.ClassPathXmlApplicationContext;
+import org.springframework.context.support.AbstractXmlApplicationContext;
+
+/**
+ * @author jbonofre
+ */
+public class SpringComponentTest extends SpringTestSupport {
+
+    private final static String MESSAGE = "<message>" + "<source>0123456789</source>"
+                                          + "<destination>9876543210</destination>"
+                                          + "<text>SMPP Component Test</text>" + "<ton>NATIONAL</ton>"
+                                          + "<npi>NATIONAL</npi>" + "</message>";
+
+    public void testSending() throws Exception {
+        ServiceMixClient client = new DefaultServiceMixClient(jbi);
+        InOut me = client.createInOutExchange();
+        me.setService(new QName("http://test", "service"));
+        NormalizedMessage message = me.getInMessage();
+        message.setContent(new StringSource(MESSAGE));
+        client.sendSync(me);
+        if (me.getStatus() == ExchangeStatus.ERROR) {
+            fail("Received ERROR status: " + me.getError().getMessage());
+        } else if (me.getFault() != null) {
+            fail("Received fault: " + new SourceTransformer().toString(me.getFault().getContent()));
+        }
+    }
+
+    protected AbstractXmlApplicationContext createBeanFactory() {
+        return new ClassPathXmlApplicationContext("spring.xml");
+    }
+
+}

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SpringComponentTest.java
------------------------------------------------------------------------------
    svn:executable = *

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/java/org/apache/servicemix/smpp/SpringComponentTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewvc/servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/log4j.properties?rev=737876&view=auto
==============================================================================
--- servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/log4j.properties (added)
+++ servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/log4j.properties Mon Jan 26 21:49:14 2009
@@ -0,0 +1,43 @@
+# 
+# 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 during tests..
+#
+log4j.rootLogger=INFO, stdout
+
+log4j.logger.org.springframework=INFO
+log4j.logger.org.apache.activemq=INFO
+log4j.logger.org.apache.activemq.spring=WARN
+
+
+log4j.logger.org.apache.servicemix=DEBUG
+
+# CONSOLE appender 
+log4j.appender.stdout=org.apache.log4j.ConsoleAppender
+log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
+log4j.appender.stdout.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
+
+# File appender
+log4j.appender.out=org.apache.log4j.FileAppender
+log4j.appender.out.layout=org.apache.log4j.PatternLayout
+log4j.appender.out.layout.ConversionPattern=%d [%-15.15t] %-5p %-30.30c{1} - %m%n
+log4j.appender.out.file=target/servicemix-test.log
+log4j.appender.out.append=true

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:executable = *

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/spring.xml
URL: http://svn.apache.org/viewvc/servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/spring.xml?rev=737876&view=auto
==============================================================================
--- servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/spring.xml (added)
+++ servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/spring.xml Mon Jan 26 21:49:14 2009
@@ -0,0 +1,44 @@
+<?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:sm="http://servicemix.apache.org/config/1.0"
+       xmlns:smpp="http://servicemix.apache.org/smpp/1.0"
+       xmlns:test="http://test">
+       
+    <bean class="org.springframework.beans.factory.config.PropertyPlaceholderConfigurer"/>
+    
+    <sm:container id="jbi" embedded="true" createMBeanServer="false">
+        <sm:activationSpecs>
+            <sm:activationSpec>
+                <sm:component>
+                    <smpp:component>
+                        <smpp:endpoints>
+                            <smpp:sender service="test:service" endpoint="endpoint"
+                                host="localhost"
+                                port="2700"
+                                systemId="test"
+                                password="test"/>
+                        </smpp:endpoints>
+                    </smpp:component>
+                </sm:component>
+            </sm:activationSpec>
+        </sm:activationSpecs>
+    </sm:container>
+       
+</beans>
\ No newline at end of file

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/spring.xml
------------------------------------------------------------------------------
    svn:executable = *

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/spring.xml
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/xbean/xbean.xml
URL: http://svn.apache.org/viewvc/servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/xbean/xbean.xml?rev=737876&view=auto
==============================================================================
--- servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/xbean/xbean.xml (added)
+++ servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/xbean/xbean.xml Mon Jan 26 21:49:14 2009
@@ -0,0 +1,30 @@
+<?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:smpp="http://servicemix.apache.org/smpp/1.0"
+       xmlns:test="http://test">
+       
+    <smpp:sender service="test:service"
+                 endpoint="sender"
+                 host="localhost"
+                 port="2700"
+                 systemId="test"
+                 password="test"/>
+       
+</beans>
\ No newline at end of file

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/xbean/xbean.xml
------------------------------------------------------------------------------
    svn:executable = *

Propchange: servicemix/components/bindings/servicemix-smpp/trunk/src/test/resources/xbean/xbean.xml
------------------------------------------------------------------------------
    svn:mime-type = text/plain