You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@servicemix.apache.org by ch...@apache.org on 2006/02/22 00:40:29 UTC

svn commit: r379627 [19/34] - in /incubator/servicemix/trunk: ./ etc/ sandbox/servicemix-wsn-1.2/src/sa/META-INF/ sandbox/servicemix-wsn-1.2/src/su/META-INF/ servicemix-assembly/ servicemix-assembly/src/main/assembly/ servicemix-assembly/src/main/relea...

Modified: incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceConfigurationHandler.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceConfigurationHandler.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceConfigurationHandler.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceConfigurationHandler.java Tue Feb 21 15:40:05 2006
@@ -1,109 +1,109 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.sca.handler;
-
-import java.util.Map;
-
-import org.apache.tuscany.common.logging.Log;
-import org.apache.tuscany.common.logging.LogFactory;
-import org.apache.tuscany.core.addressing.EndpointReference;
-import org.apache.tuscany.core.invocation.InvocationConfiguration;
-import org.apache.tuscany.core.invocation.ProxyConfiguration;
-import org.apache.tuscany.core.message.Message;
-import org.apache.tuscany.core.message.handler.MessageHandler;
-import org.apache.tuscany.core.runtime.TuscanyModuleComponentContext;
-import org.apache.tuscany.model.assembly.Binding;
-import org.apache.tuscany.model.assembly.ConfiguredService;
-import org.apache.tuscany.model.assembly.ExternalService;
-import org.apache.tuscany.model.assembly.Interface;
-import org.apache.tuscany.model.assembly.Part;
-import org.apache.tuscany.model.types.InterfaceType;
-import org.apache.tuscany.model.types.OperationType;
-import org.osoa.sca.CurrentModuleContext;
-import org.osoa.sca.ServiceRuntimeException;
-import org.osoa.sca.model.JbiBinding;
-
-public class ExternalJbiServiceConfigurationHandler implements MessageHandler {
-    public final static Log log = LogFactory.getLog(ExternalJbiServiceConfigurationHandler.class);
-
-    /**
-     * Constructor.
-     */
-    public ExternalJbiServiceConfigurationHandler() {
-        super();
-    }
-
-    /**
-     * @see org.apache.tuscany.core.message.handler.MessageHandler#processMessage(org.apache.tuscany.core.message.Message)
-     */
-    public boolean processMessage(Message message) {
-        if (log.isEntryEnabled())
-            log.entry("processMessage");
-        try {
-
-            // Get the endpoint reference of the target service and the service model element
-            EndpointReference endpointReference = message.getEndpointReference();
-            Object portEndpoint = endpointReference.getConfiguredPort();
-
-            // Return immediately if the target is not an external service
-            if (!(portEndpoint instanceof ConfiguredService))
-                return false;
-            ConfiguredService serviceEndpoint = (ConfiguredService) portEndpoint;
-            Part part = serviceEndpoint.getPart();
-            if (!(part instanceof ExternalService))
-                return false;
-            ExternalService externalService = (ExternalService) part;
-
-            // Return immediately if this is not an external web service
-            Binding binding = externalService.getBindings().get(0);
-            if (!(binding instanceof JbiBinding))
-                return false;
-            JbiBinding jbiBinding = (JbiBinding) binding;
-
-            TuscanyModuleComponentContext context = (TuscanyModuleComponentContext) CurrentModuleContext.getContext();
-
-            // Get the proxy configuration
-            ProxyConfiguration proxyConfiguration=(ProxyConfiguration)message.getBody();
-            Map<OperationType, InvocationConfiguration> invocationConfigurations=proxyConfiguration.getInvocationConfigurations();
-            
-            // Get the business interface
-            Interface targetInterface = serviceEndpoint.getService().getInterfaceContract();
-            InterfaceType targetInterfaceType = targetInterface.getInterfaceType();
-
-            // Create the invocation configurations
-            for (InvocationConfiguration invocationConfiguration : invocationConfigurations.values()) {
-                OperationType targetOperationType=targetInterfaceType.getOperationType(invocationConfiguration.getOperationType().getName());
-
-                // Handle a business method invocation, get a message handler from the port
-                ExternalJbiServiceHandler handler = new ExternalJbiServiceHandler(context, targetOperationType, externalService, jbiBinding, endpointReference);
-                invocationConfiguration.addRequestHandler(handler);
-            }
-
-            return false;
-
-        } catch (Exception e) {
-            log.fatal(e);
-
-            throw new ServiceRuntimeException(e);
-
-        } finally {
-            if (log.isEntryEnabled())
-                log.exit("processMessage");
-        }
-
-    }
-
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.sca.handler;
+
+import java.util.Map;
+
+import org.apache.tuscany.common.logging.Log;
+import org.apache.tuscany.common.logging.LogFactory;
+import org.apache.tuscany.core.addressing.EndpointReference;
+import org.apache.tuscany.core.invocation.InvocationConfiguration;
+import org.apache.tuscany.core.invocation.ProxyConfiguration;
+import org.apache.tuscany.core.message.Message;
+import org.apache.tuscany.core.message.handler.MessageHandler;
+import org.apache.tuscany.core.runtime.TuscanyModuleComponentContext;
+import org.apache.tuscany.model.assembly.Binding;
+import org.apache.tuscany.model.assembly.ConfiguredService;
+import org.apache.tuscany.model.assembly.ExternalService;
+import org.apache.tuscany.model.assembly.Interface;
+import org.apache.tuscany.model.assembly.Part;
+import org.apache.tuscany.model.types.InterfaceType;
+import org.apache.tuscany.model.types.OperationType;
+import org.osoa.sca.CurrentModuleContext;
+import org.osoa.sca.ServiceRuntimeException;
+import org.osoa.sca.model.JbiBinding;
+
+public class ExternalJbiServiceConfigurationHandler implements MessageHandler {
+    public final static Log log = LogFactory.getLog(ExternalJbiServiceConfigurationHandler.class);
+
+    /**
+     * Constructor.
+     */
+    public ExternalJbiServiceConfigurationHandler() {
+        super();
+    }
+
+    /**
+     * @see org.apache.tuscany.core.message.handler.MessageHandler#processMessage(org.apache.tuscany.core.message.Message)
+     */
+    public boolean processMessage(Message message) {
+        if (log.isEntryEnabled())
+            log.entry("processMessage");
+        try {
+
+            // Get the endpoint reference of the target service and the service model element
+            EndpointReference endpointReference = message.getEndpointReference();
+            Object portEndpoint = endpointReference.getConfiguredPort();
+
+            // Return immediately if the target is not an external service
+            if (!(portEndpoint instanceof ConfiguredService))
+                return false;
+            ConfiguredService serviceEndpoint = (ConfiguredService) portEndpoint;
+            Part part = serviceEndpoint.getPart();
+            if (!(part instanceof ExternalService))
+                return false;
+            ExternalService externalService = (ExternalService) part;
+
+            // Return immediately if this is not an external web service
+            Binding binding = externalService.getBindings().get(0);
+            if (!(binding instanceof JbiBinding))
+                return false;
+            JbiBinding jbiBinding = (JbiBinding) binding;
+
+            TuscanyModuleComponentContext context = (TuscanyModuleComponentContext) CurrentModuleContext.getContext();
+
+            // Get the proxy configuration
+            ProxyConfiguration proxyConfiguration=(ProxyConfiguration)message.getBody();
+            Map<OperationType, InvocationConfiguration> invocationConfigurations=proxyConfiguration.getInvocationConfigurations();
+            
+            // Get the business interface
+            Interface targetInterface = serviceEndpoint.getService().getInterfaceContract();
+            InterfaceType targetInterfaceType = targetInterface.getInterfaceType();
+
+            // Create the invocation configurations
+            for (InvocationConfiguration invocationConfiguration : invocationConfigurations.values()) {
+                OperationType targetOperationType=targetInterfaceType.getOperationType(invocationConfiguration.getOperationType().getName());
+
+                // Handle a business method invocation, get a message handler from the port
+                ExternalJbiServiceHandler handler = new ExternalJbiServiceHandler(context, targetOperationType, externalService, jbiBinding, endpointReference);
+                invocationConfiguration.addRequestHandler(handler);
+            }
+
+            return false;
+
+        } catch (Exception e) {
+            log.fatal(e);
+
+            throw new ServiceRuntimeException(e);
+
+        } finally {
+            if (log.isEntryEnabled())
+                log.exit("processMessage");
+        }
+
+    }
+
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceConfigurationHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceHandler.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceHandler.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceHandler.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceHandler.java Tue Feb 21 15:40:05 2006
@@ -1,103 +1,103 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.sca.handler;
-
-import java.io.ByteArrayOutputStream;
-import java.lang.reflect.Method;
-
-import javax.jbi.messaging.DeliveryChannel;
-import javax.jbi.messaging.ExchangeStatus;
-import javax.jbi.messaging.InOut;
-import javax.jbi.messaging.NormalizedMessage;
-import javax.xml.bind.JAXBContext;
-import javax.xml.namespace.QName;
-
-import org.apache.servicemix.jbi.jaxp.StringSource;
-import org.apache.servicemix.sca.ScaServiceUnit;
-import org.apache.tuscany.core.addressing.EndpointReference;
-import org.apache.tuscany.core.message.Message;
-import org.apache.tuscany.core.message.handler.MessageHandler;
-import org.apache.tuscany.core.runtime.TuscanyModuleComponentContext;
-import org.apache.tuscany.model.assembly.ExternalService;
-import org.apache.tuscany.model.types.OperationType;
-import org.apache.tuscany.model.types.java.JavaOperationType;
-import org.osoa.sca.model.JbiBinding;
-
-public class ExternalJbiServiceHandler implements MessageHandler {
-
-	private TuscanyModuleComponentContext context;
-	private OperationType type;
-	private ExternalService externalService;
-	private JbiBinding jbiBinding;
-	private EndpointReference endpointReference;
-	private ScaServiceUnit serviceUnit;
-	
-	public ExternalJbiServiceHandler(TuscanyModuleComponentContext context, 
-									 OperationType type, 
-									 ExternalService externalService, 
-									 JbiBinding jbiBinding, 
-									 EndpointReference endpointReference) {
-		this.context = context;
-		this.type = type;
-		this.externalService = externalService;
-		this.jbiBinding = jbiBinding;
-		this.endpointReference = endpointReference;
-		this.serviceUnit = ScaServiceUnit.getCurrentScaServiceUnit();
-	}
-
-	public boolean processMessage(Message message) {
-		try {
-			QName interfaceName;
-			String[] parts = jbiBinding.getPort().split("#");
-			if (parts.length > 1) {
-				interfaceName = new QName(parts[0], parts[1]);
-			} else {
-				interfaceName = new QName(parts[0]);
-			}
-			
-			Object payload = message.getPayload();
-			if (payload instanceof Object[]) {
-				payload = ((Object[]) payload)[0];
-			}
-			
-			Method method = ((JavaOperationType) type).getJavaMethod();
-			Class inputClass = method.getParameterTypes()[0];
-			Class outputClass = method.getReturnType();
-			JAXBContext context = JAXBContext.newInstance(inputClass, outputClass);
-			ByteArrayOutputStream baos = new ByteArrayOutputStream();
-			context.createMarshaller().marshal(payload, baos);
-			
-			DeliveryChannel channel = serviceUnit.getComponent().getComponentContext().getDeliveryChannel();
-			// TODO: in-only case ?
-			InOut inout = channel.createExchangeFactory(interfaceName).createInOutExchange();
-			NormalizedMessage in = inout.createMessage();
-			inout.setInMessage(in);
-			in.setContent(new StringSource(baos.toString()));
-			boolean sent = channel.sendSync(inout);
-			// TODO: check for error ?
-			NormalizedMessage out = inout.getOutMessage();
-			Object response = context.createUnmarshaller().unmarshal(out.getContent());
-			message.setPayload(response);
-			message.getCallbackChannel().send(message);
-			inout.setStatus(ExchangeStatus.DONE);
-			channel.send(inout);
-			return false;
-		} catch (Exception e) {
-			throw new RuntimeException(e);
-		}
-	}
-
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.sca.handler;
+
+import java.io.ByteArrayOutputStream;
+import java.lang.reflect.Method;
+
+import javax.jbi.messaging.DeliveryChannel;
+import javax.jbi.messaging.ExchangeStatus;
+import javax.jbi.messaging.InOut;
+import javax.jbi.messaging.NormalizedMessage;
+import javax.xml.bind.JAXBContext;
+import javax.xml.namespace.QName;
+
+import org.apache.servicemix.jbi.jaxp.StringSource;
+import org.apache.servicemix.sca.ScaServiceUnit;
+import org.apache.tuscany.core.addressing.EndpointReference;
+import org.apache.tuscany.core.message.Message;
+import org.apache.tuscany.core.message.handler.MessageHandler;
+import org.apache.tuscany.core.runtime.TuscanyModuleComponentContext;
+import org.apache.tuscany.model.assembly.ExternalService;
+import org.apache.tuscany.model.types.OperationType;
+import org.apache.tuscany.model.types.java.JavaOperationType;
+import org.osoa.sca.model.JbiBinding;
+
+public class ExternalJbiServiceHandler implements MessageHandler {
+
+	private TuscanyModuleComponentContext context;
+	private OperationType type;
+	private ExternalService externalService;
+	private JbiBinding jbiBinding;
+	private EndpointReference endpointReference;
+	private ScaServiceUnit serviceUnit;
+	
+	public ExternalJbiServiceHandler(TuscanyModuleComponentContext context, 
+									 OperationType type, 
+									 ExternalService externalService, 
+									 JbiBinding jbiBinding, 
+									 EndpointReference endpointReference) {
+		this.context = context;
+		this.type = type;
+		this.externalService = externalService;
+		this.jbiBinding = jbiBinding;
+		this.endpointReference = endpointReference;
+		this.serviceUnit = ScaServiceUnit.getCurrentScaServiceUnit();
+	}
+
+	public boolean processMessage(Message message) {
+		try {
+			QName interfaceName;
+			String[] parts = jbiBinding.getPort().split("#");
+			if (parts.length > 1) {
+				interfaceName = new QName(parts[0], parts[1]);
+			} else {
+				interfaceName = new QName(parts[0]);
+			}
+			
+			Object payload = message.getPayload();
+			if (payload instanceof Object[]) {
+				payload = ((Object[]) payload)[0];
+			}
+			
+			Method method = ((JavaOperationType) type).getJavaMethod();
+			Class inputClass = method.getParameterTypes()[0];
+			Class outputClass = method.getReturnType();
+			JAXBContext context = JAXBContext.newInstance(inputClass, outputClass);
+			ByteArrayOutputStream baos = new ByteArrayOutputStream();
+			context.createMarshaller().marshal(payload, baos);
+			
+			DeliveryChannel channel = serviceUnit.getComponent().getComponentContext().getDeliveryChannel();
+			// TODO: in-only case ?
+			InOut inout = channel.createExchangeFactory(interfaceName).createInOutExchange();
+			NormalizedMessage in = inout.createMessage();
+			inout.setInMessage(in);
+			in.setContent(new StringSource(baos.toString()));
+			boolean sent = channel.sendSync(inout);
+			// TODO: check for error ?
+			NormalizedMessage out = inout.getOutMessage();
+			Object response = context.createUnmarshaller().unmarshal(out.getContent());
+			message.setPayload(response);
+			message.getCallbackChannel().send(message);
+			inout.setStatus(ExchangeStatus.DONE);
+			channel.send(inout);
+			return false;
+		} catch (Exception e) {
+			throw new RuntimeException(e);
+		}
+	}
+
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/main/java/org/apache/servicemix/sca/handler/ExternalJbiServiceHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/main/java/org/osoa/sca/model/JbiBinding.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/main/java/org/osoa/sca/model/JbiBinding.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/main/java/org/osoa/sca/model/JbiBinding.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/main/java/org/osoa/sca/model/JbiBinding.java Tue Feb 21 15:40:05 2006
@@ -1,24 +1,24 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.osoa.sca.model;
-
-public interface JbiBinding extends Binding {
-
-	void setPort(String port);
-	
-	String getPort();
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.osoa.sca.model;
+
+public interface JbiBinding extends Binding {
+
+	void setPort(String port);
+	
+	String getPort();
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/main/java/org/osoa/sca/model/JbiBinding.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/main/resources/META-INF/DISCLAIMER.txt
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/main/resources/META-INF/DISCLAIMER.txt?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/main/resources/META-INF/DISCLAIMER.txt (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/main/resources/META-INF/DISCLAIMER.txt Tue Feb 21 15:40:05 2006
@@ -1,7 +1,7 @@
-ActiveMQ is an effort undergoing incubation at the Apache Software Foundation
-(ASF), sponsored by the Geronimo PMC. Incubation is required of all newly
-accepted projects until a further review indicates that the infrastructure,
-communications, and decision making process have stabilized in a manner
-consistent with other successful ASF projects. While incubation status is not
-necessarily a reflection of the completeness or stability of the code, it does
+ActiveMQ is an effort undergoing incubation at the Apache Software Foundation
+(ASF), sponsored by the Geronimo PMC. Incubation is required of all newly
+accepted projects until a further review indicates that the infrastructure,
+communications, and decision making process have stabilized in a manner
+consistent with other successful ASF projects. While incubation status is not
+necessarily a reflection of the completeness or stability of the code, it does
 indicate that the project has yet to be fully endorsed by the ASF.

Propchange: incubator/servicemix/trunk/servicemix-sca/src/main/resources/META-INF/DISCLAIMER.txt
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/main/resources/META-INF/LICENSE.txt
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/AssemblyLoaderTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/ScaComponentTest.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/ScaComponentTest.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/ScaComponentTest.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/ScaComponentTest.java Tue Feb 21 15:40:05 2006
@@ -1,108 +1,108 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.sca;
-
-import java.io.ByteArrayOutputStream;
-import java.io.File;
-import java.net.URL;
-
-import javax.naming.InitialContext;
-import javax.xml.bind.JAXBContext;
-import javax.xml.namespace.QName;
-import javax.xml.transform.Source;
-import javax.xml.transform.dom.DOMSource;
-
-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.client.ServiceMixClient;
-import org.apache.servicemix.components.util.MockServiceComponent;
-import org.apache.servicemix.jbi.container.ActivationSpec;
-import org.apache.servicemix.jbi.container.JBIContainer;
-import org.apache.servicemix.jbi.jaxp.SourceTransformer;
-import org.apache.servicemix.jbi.jaxp.StringSource;
-import org.apache.servicemix.jbi.resolver.ServiceNameEndpointResolver;
-import org.apache.servicemix.sca.bigbank.stockquote.StockQuoteResponse;
-import org.w3c.dom.Node;
-
-public class ScaComponentTest extends TestCase {
-
-    private static Log log =  LogFactory.getLog(ScaComponentTest.class);
-    
-    protected JBIContainer container;
-    
-    protected void setUp() throws Exception {
-        container = new JBIContainer();
-        container.setUseMBeanServer(false);
-        container.setCreateMBeanServer(false);
-        container.setMonitorInstallationDirectory(false);
-        container.setNamingContext(new InitialContext());
-        container.setEmbedded(true);
-        container.init();
-    }
-    
-    protected void tearDown() throws Exception {
-        if (container != null) {
-            container.shutDown();
-        }
-    }
-    
-    public void testDeploy() throws Exception {
-        ScaComponent component = new ScaComponent();
-        container.activateComponent(component, "JSR181Component");
-
-        MockServiceComponent mock = new MockServiceComponent();
-        mock.setService(new QName("StockQuoteService"));
-        mock.setEndpoint("Mock");
-        ByteArrayOutputStream baos = new ByteArrayOutputStream();
-        StockQuoteResponse r = new StockQuoteResponse();
-        r.setResult(8.23f);
-        JAXBContext.newInstance(StockQuoteResponse.class).createMarshaller().marshal(r, baos);
-        mock.setResponseXml(baos.toString());
-        ActivationSpec as = new ActivationSpec();
-        as.setInterfaceName(new QName("http://www.quickstockquote.com/StockQuoteService", "StockQuoteServiceJBI"));
-        as.setComponent(mock);
-        container.activateComponent(as);
-        
-        // Start container
-        container.start();
-        
-        // Deploy SU
-        component.getServiceUnitManager().deploy("su", getServiceUnitPath("org/apache/servicemix/sca/bigbank"));
-        component.getServiceUnitManager().init("su", getServiceUnitPath("org/apache/servicemix/sca/bigbank"));
-        component.getServiceUnitManager().start("su");
-        
-        ServiceMixClient client = new DefaultServiceMixClient(container);
-        Source req = new StringSource("<AccountReportRequest><CustomerID>id</CustomerID></AccountReportRequest>");
-        Object rep = client.request(new ServiceNameEndpointResolver(
-        										new QName("http://www.bigbank.com/AccountService/", "AccountService")),
-        			   						 null, null, req);
-        if (rep instanceof Node) {
-            rep = new DOMSource((Node) rep);
-        }
-        log.info(new SourceTransformer().toString((Source) rep));
-    }
-     
-    protected String getServiceUnitPath(String name) {
-        URL url = getClass().getClassLoader().getResource(name + "/sca.module");
-        File path = new File(url.getFile());
-        path = path.getParentFile();
-        return path.getAbsolutePath();
-    }
-    
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.sca;
+
+import java.io.ByteArrayOutputStream;
+import java.io.File;
+import java.net.URL;
+
+import javax.naming.InitialContext;
+import javax.xml.bind.JAXBContext;
+import javax.xml.namespace.QName;
+import javax.xml.transform.Source;
+import javax.xml.transform.dom.DOMSource;
+
+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.client.ServiceMixClient;
+import org.apache.servicemix.components.util.MockServiceComponent;
+import org.apache.servicemix.jbi.container.ActivationSpec;
+import org.apache.servicemix.jbi.container.JBIContainer;
+import org.apache.servicemix.jbi.jaxp.SourceTransformer;
+import org.apache.servicemix.jbi.jaxp.StringSource;
+import org.apache.servicemix.jbi.resolver.ServiceNameEndpointResolver;
+import org.apache.servicemix.sca.bigbank.stockquote.StockQuoteResponse;
+import org.w3c.dom.Node;
+
+public class ScaComponentTest extends TestCase {
+
+    private static Log log =  LogFactory.getLog(ScaComponentTest.class);
+    
+    protected JBIContainer container;
+    
+    protected void setUp() throws Exception {
+        container = new JBIContainer();
+        container.setUseMBeanServer(false);
+        container.setCreateMBeanServer(false);
+        container.setMonitorInstallationDirectory(false);
+        container.setNamingContext(new InitialContext());
+        container.setEmbedded(true);
+        container.init();
+    }
+    
+    protected void tearDown() throws Exception {
+        if (container != null) {
+            container.shutDown();
+        }
+    }
+    
+    public void testDeploy() throws Exception {
+        ScaComponent component = new ScaComponent();
+        container.activateComponent(component, "JSR181Component");
+
+        MockServiceComponent mock = new MockServiceComponent();
+        mock.setService(new QName("StockQuoteService"));
+        mock.setEndpoint("Mock");
+        ByteArrayOutputStream baos = new ByteArrayOutputStream();
+        StockQuoteResponse r = new StockQuoteResponse();
+        r.setResult(8.23f);
+        JAXBContext.newInstance(StockQuoteResponse.class).createMarshaller().marshal(r, baos);
+        mock.setResponseXml(baos.toString());
+        ActivationSpec as = new ActivationSpec();
+        as.setInterfaceName(new QName("http://www.quickstockquote.com/StockQuoteService", "StockQuoteServiceJBI"));
+        as.setComponent(mock);
+        container.activateComponent(as);
+        
+        // Start container
+        container.start();
+        
+        // Deploy SU
+        component.getServiceUnitManager().deploy("su", getServiceUnitPath("org/apache/servicemix/sca/bigbank"));
+        component.getServiceUnitManager().init("su", getServiceUnitPath("org/apache/servicemix/sca/bigbank"));
+        component.getServiceUnitManager().start("su");
+        
+        ServiceMixClient client = new DefaultServiceMixClient(container);
+        Source req = new StringSource("<AccountReportRequest><CustomerID>id</CustomerID></AccountReportRequest>");
+        Object rep = client.request(new ServiceNameEndpointResolver(
+        										new QName("http://www.bigbank.com/AccountService/", "AccountService")),
+        			   						 null, null, req);
+        if (rep instanceof Node) {
+            rep = new DOMSource((Node) rep);
+        }
+        log.info(new SourceTransformer().toString((Source) rep));
+    }
+     
+    protected String getServiceUnitPath(String name) {
+        URL url = getClass().getClassLoader().getResource(name + "/sca.module");
+        File path = new File(url.getFile());
+        path = path.getParentFile();
+        return path.getAbsolutePath();
+    }
+    
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/ScaComponentTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountReportRequest.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountReportRequest.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountReportRequest.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountReportRequest.java Tue Feb 21 15:40:05 2006
@@ -1,40 +1,40 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.sca.bigbank.account;
-
-import javax.xml.bind.annotation.AccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlType;
-
-@XmlAccessorType(AccessType.FIELD)
-@XmlType(name = "", propOrder = { "customerID" })
-@XmlRootElement(name = "AccountReportRequest")
-public class AccountReportRequest {
-
-    @XmlElement(name = "CustomerID")
-	private String customerID;
-	
-	public String getCustomerID() {
-		return customerID;
-	}
-
-	public void setCustomerID(String customerID) {
-		this.customerID = customerID;
-	}
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.sca.bigbank.account;
+
+import javax.xml.bind.annotation.AccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlRootElement;
+import javax.xml.bind.annotation.XmlType;
+
+@XmlAccessorType(AccessType.FIELD)
+@XmlType(name = "", propOrder = { "customerID" })
+@XmlRootElement(name = "AccountReportRequest")
+public class AccountReportRequest {
+
+    @XmlElement(name = "CustomerID")
+	private String customerID;
+	
+	public String getCustomerID() {
+		return customerID;
+	}
+
+	public void setCustomerID(String customerID) {
+		this.customerID = customerID;
+	}
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountReportRequest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountReportResponse.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountService.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountServiceImpl.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/account/AccountSummary.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/accountdata/AccountDataService.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/accountdata/AccountDataServiceImpl.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/accountdata/CheckingAccount.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/accountdata/SavingsAccount.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/accountdata/StockAccount.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteRequest.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteRequest.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteRequest.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteRequest.java Tue Feb 21 15:40:05 2006
@@ -1,40 +1,40 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.sca.bigbank.stockquote;
-
-import javax.xml.bind.annotation.AccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlType;
-
-@XmlAccessorType(AccessType.FIELD)
-@XmlType(name = "", propOrder = { "symbol" })
-@XmlRootElement(name = "StockQuoteRequest")
-public class StockQuoteRequest {
-
-    @XmlElement(name = "Symbol")
-	private String symbol;
-
-	public String getSymbol() {
-		return symbol;
-	}
-
-	public void setSymbol(String symbol) {
-		this.symbol = symbol;
-	}
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.sca.bigbank.stockquote;
+
+import javax.xml.bind.annotation.AccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlRootElement;
+import javax.xml.bind.annotation.XmlType;
+
+@XmlAccessorType(AccessType.FIELD)
+@XmlType(name = "", propOrder = { "symbol" })
+@XmlRootElement(name = "StockQuoteRequest")
+public class StockQuoteRequest {
+
+    @XmlElement(name = "Symbol")
+	private String symbol;
+
+	public String getSymbol() {
+		return symbol;
+	}
+
+	public void setSymbol(String symbol) {
+		this.symbol = symbol;
+	}
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteRequest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteResponse.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteResponse.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteResponse.java (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteResponse.java Tue Feb 21 15:40:05 2006
@@ -1,40 +1,40 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.sca.bigbank.stockquote;
-
-import javax.xml.bind.annotation.AccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlType;
-
-@XmlAccessorType(AccessType.FIELD)
-@XmlType(name = "", propOrder = { "result" })
-@XmlRootElement(name = "StockQuoteResponse")
-public class StockQuoteResponse {
-
-    @XmlElement(name = "Result")
-	private float result;
-
-	public float getResult() {
-		return result;
-	}
-
-	public void setResult(float result) {
-		this.result = result;
-	}
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.sca.bigbank.stockquote;
+
+import javax.xml.bind.annotation.AccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlRootElement;
+import javax.xml.bind.annotation.XmlType;
+
+@XmlAccessorType(AccessType.FIELD)
+@XmlType(name = "", propOrder = { "result" })
+@XmlRootElement(name = "StockQuoteResponse")
+public class StockQuoteResponse {
+
+    @XmlElement(name = "Result")
+	private float result;
+
+	public float getResult() {
+		return result;
+	}
+
+	public void setResult(float result) {
+		this.result = result;
+	}
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteResponse.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-sca/src/test/java/org/apache/servicemix/sca/bigbank/stockquote/StockQuoteService.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j-tests.properties
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j-tests.properties?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j-tests.properties (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j-tests.properties Tue Feb 21 15:40:05 2006
@@ -1,21 +1,21 @@
-#
-# The logging properties used during tests..
-#
-log4j.rootLogger=DEBUG, out
-
-log4j.logger.org.apache.activemq=INFO
-log4j.logger.org.apache.activemq.spring=WARN
-log4j.logger.org.apache.activemq.store.journal=INFO
-log4j.logger.org.activeio.journal=INFO
-
-# CONSOLE appender not used by default
-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
+#
+# The logging properties used during tests..
+#
+log4j.rootLogger=DEBUG, out
+
+log4j.logger.org.apache.activemq=INFO
+log4j.logger.org.apache.activemq.spring=WARN
+log4j.logger.org.apache.activemq.store.journal=INFO
+log4j.logger.org.activeio.journal=INFO
+
+# CONSOLE appender not used by default
+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: incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j-tests.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j.properties?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j.properties (original)
+++ incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j.properties Tue Feb 21 15:40:05 2006
@@ -1,21 +1,21 @@
-#
-# The logging properties used during tests..
-#
-log4j.rootLogger=DEBUG, stdout
-
-log4j.logger.org.apache.activemq=INFO
-log4j.logger.org.apache.activemq.spring=WARN
-log4j.logger.org.apache.activemq.store.journal=INFO
-log4j.logger.org.activeio.journal=INFO
-
-# CONSOLE appender not used by default
-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
+#
+# The logging properties used during tests..
+#
+log4j.rootLogger=DEBUG, stdout
+
+log4j.logger.org.apache.activemq=INFO
+log4j.logger.org.apache.activemq.spring=WARN
+log4j.logger.org.apache.activemq.store.journal=INFO
+log4j.logger.org.activeio.journal=INFO
+
+# CONSOLE appender not used by default
+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: incubator/servicemix/trunk/servicemix-sca/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-soap/maven.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-soap/pom.xml
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-soap/pom.xml?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-soap/pom.xml (original)
+++ incubator/servicemix/trunk/servicemix-soap/pom.xml Tue Feb 21 15:40:05 2006
@@ -1,63 +1,63 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Copyright 2005 The Apache Software Foundation
-
-    Licensed 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.
--->
-<!-- $Rev: 356052 $ $Date: 2005-12-11 14:41:20 -0800 (dim., 11 déc. 2005) $ -->
-<project xmlns="http://maven.apache.org/POM/4.0.0">
-
-    <parent>
-        <groupId>incubator-servicemix</groupId>
-        <artifactId>servicemix</artifactId>
-        <version>3.0-SNAPSHOT</version>
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-
-    <modelVersion>4.0.0</modelVersion>
-    <groupId>incubator-servicemix</groupId>
-    <artifactId>servicemix-soap</artifactId>
-    <packaging>jar</packaging>
-    <name>ServiceMix :: SOAP</name>
-    <description>SOAP Stack</description>
-
-    <dependencies>
-        <dependency>
-            <groupId>stax</groupId>
-            <artifactId>stax-api</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>incubator-servicemix</groupId>
-            <artifactId>servicemix-core</artifactId>
-            <scope>provided</scope>
-        </dependency>
-        <dependency>
-            <groupId>incubator-servicemix</groupId>
-            <artifactId>servicemix-common</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>commons-logging</groupId>
-            <artifactId>commons-logging</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.geronimo.specs</groupId>
-            <artifactId>geronimo-javamail_1.3.1_spec</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>geronimo</groupId>
-            <artifactId>geronimo-activation</artifactId>
-        </dependency>
-    </dependencies>
-
-</project>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Copyright 2005 The Apache Software Foundation
+
+    Licensed 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.
+-->
+<!-- $Rev: 356052 $ $Date: 2005-12-11 14:41:20 -0800 (dim., 11 déc. 2005) $ -->
+<project xmlns="http://maven.apache.org/POM/4.0.0">
+
+    <parent>
+        <groupId>incubator-servicemix</groupId>
+        <artifactId>servicemix</artifactId>
+        <version>3.0-SNAPSHOT</version>
+        <relativePath>../pom.xml</relativePath>
+    </parent>
+
+    <modelVersion>4.0.0</modelVersion>
+    <groupId>incubator-servicemix</groupId>
+    <artifactId>servicemix-soap</artifactId>
+    <packaging>jar</packaging>
+    <name>ServiceMix :: SOAP</name>
+    <description>SOAP Stack</description>
+
+    <dependencies>
+        <dependency>
+            <groupId>stax</groupId>
+            <artifactId>stax-api</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>incubator-servicemix</groupId>
+            <artifactId>servicemix-core</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>incubator-servicemix</groupId>
+            <artifactId>servicemix-common</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>commons-logging</groupId>
+            <artifactId>commons-logging</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-javamail_1.3.1_spec</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>geronimo</groupId>
+            <artifactId>geronimo-activation</artifactId>
+        </dependency>
+    </dependencies>
+
+</project>

Propchange: incubator/servicemix/trunk/servicemix-soap/pom.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-soap/project.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/servicemix/trunk/servicemix-soap/project.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Context.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Context.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Context.java (original)
+++ incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Context.java Tue Feb 21 15:40:05 2006
@@ -1,49 +1,49 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.soap;
-
-import java.util.HashMap;
-import java.util.Map;
-
-/**
- * 
- * @author Guillaume Nodet
- * @version $Revision: 1.5 $
- * @since 3.0
- */
-public class Context {
-
-	public static final String SOAP_MESSAGE = "org.apache.servicemix.SoapMessage";
-	public static final String INTERFACE = "org.apache.servicemix.Interface";
-	public static final String OPERATION = "org.apache.servicemix.Operation";
-	public static final String SERVICE = "org.apache.servicemix.Service";
-	public static final String ENDPOINT = "org.apache.servicemix.Endpoint";
-	
-	private Map properties;
-	
-	public Context() {
-		this.properties = new HashMap();
-	}
-	
-	public Object getProperty(String name) {
-		return properties.get(name);
-	}
-	
-	public void setProperty(String name, Object value) {
-		properties.put(name, value);
-	}
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.soap;
+
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * 
+ * @author Guillaume Nodet
+ * @version $Revision: 1.5 $
+ * @since 3.0
+ */
+public class Context {
+
+	public static final String SOAP_MESSAGE = "org.apache.servicemix.SoapMessage";
+	public static final String INTERFACE = "org.apache.servicemix.Interface";
+	public static final String OPERATION = "org.apache.servicemix.Operation";
+	public static final String SERVICE = "org.apache.servicemix.Service";
+	public static final String ENDPOINT = "org.apache.servicemix.Endpoint";
+	
+	private Map properties;
+	
+	public Context() {
+		this.properties = new HashMap();
+	}
+	
+	public Object getProperty(String name) {
+		return properties.get(name);
+	}
+	
+	public void setProperty(String name, Object value) {
+		properties.put(name, value);
+	}
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Context.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Handler.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Handler.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Handler.java (original)
+++ incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Handler.java Tue Feb 21 15:40:05 2006
@@ -1,31 +1,31 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.soap;
-
-/**
- * 
- * @author Guillaume Nodet
- * @version $Revision: 1.5 $
- * @since 3.0
- */
-public interface Handler {
-
-	public void process(Context context) throws Exception;
-	
-	public void onComplete(Context context);
-	
-	public void onException(Context context, Exception e);
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.soap;
+
+/**
+ * 
+ * @author Guillaume Nodet
+ * @version $Revision: 1.5 $
+ * @since 3.0
+ */
+public interface Handler {
+
+	public void process(Context context) throws Exception;
+	
+	public void onComplete(Context context);
+	
+	public void onException(Context context, Exception e);
+}

Propchange: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/Handler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapEndpoint.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapEndpoint.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapEndpoint.java (original)
+++ incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapEndpoint.java Tue Feb 21 15:40:05 2006
@@ -1,26 +1,26 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.soap;
-
-import java.net.URI;
-
-import org.apache.servicemix.common.Endpoint;
-
-public abstract class SoapEndpoint extends Endpoint {
-
-	public abstract URI getDefaultMep();
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.soap;
+
+import java.net.URI;
+
+import org.apache.servicemix.common.Endpoint;
+
+public abstract class SoapEndpoint extends Endpoint {
+
+	public abstract URI getDefaultMep();
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapEndpoint.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapFault.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapFault.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapFault.java (original)
+++ incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapFault.java Tue Feb 21 15:40:05 2006
@@ -1,93 +1,93 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.soap;
-
-import javax.xml.transform.Source;
-
-/**
- * Represents a SOAP fault which occurred while processing the
- * message.
- *
- * @author Guillaume Nodet
- * @version $Revision: 1.5 $
- * @since 3.0
- */
-public class SoapFault extends Exception {
-	
-	public static final String SENDER = "Sender";
-	public static final String RECEIVER = "Receiver";
-	
-    private String code;
-    private String subcode;
-    private String reason;
-    private String node;
-    private String role;
-    private Source details;
-
-    public SoapFault(Exception cause) {
-        super(cause);
-    }
-
-    public SoapFault(String code, String reason) {
-        this.code = code;
-        this.reason = reason;
-    }
-
-    public SoapFault(String code, String subcode, String reason) {
-        this.code = code;
-        this.subcode = subcode;
-        this.reason = reason;
-    }
-
-    public SoapFault(String code, String reason, String node, String role) {
-        this.code = code;
-        this.reason = reason;
-        this.node = node;
-        this.role = role;
-    }
-
-    public SoapFault(String code, String reason, String node, String role, Source details) {
-        this.code = code;
-        this.reason = reason;
-        this.node = node;
-        this.role = role;
-        this.details = details;
-    }
-
-    public String getCode() {
-        return code;
-    }
-
-    public String getSubcode() {
-        return subcode;
-    }
-
-    public String getReason() {
-        return reason;
-    }
-
-    public String getNode() {
-        return node;
-    }
-
-    public String getRole() {
-        return role;
-    }
-
-	public Source getDetails() {
-		return details;
-	}
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.soap;
+
+import javax.xml.transform.Source;
+
+/**
+ * Represents a SOAP fault which occurred while processing the
+ * message.
+ *
+ * @author Guillaume Nodet
+ * @version $Revision: 1.5 $
+ * @since 3.0
+ */
+public class SoapFault extends Exception {
+	
+	public static final String SENDER = "Sender";
+	public static final String RECEIVER = "Receiver";
+	
+    private String code;
+    private String subcode;
+    private String reason;
+    private String node;
+    private String role;
+    private Source details;
+
+    public SoapFault(Exception cause) {
+        super(cause);
+    }
+
+    public SoapFault(String code, String reason) {
+        this.code = code;
+        this.reason = reason;
+    }
+
+    public SoapFault(String code, String subcode, String reason) {
+        this.code = code;
+        this.subcode = subcode;
+        this.reason = reason;
+    }
+
+    public SoapFault(String code, String reason, String node, String role) {
+        this.code = code;
+        this.reason = reason;
+        this.node = node;
+        this.role = role;
+    }
+
+    public SoapFault(String code, String reason, String node, String role, Source details) {
+        this.code = code;
+        this.reason = reason;
+        this.node = node;
+        this.role = role;
+        this.details = details;
+    }
+
+    public String getCode() {
+        return code;
+    }
+
+    public String getSubcode() {
+        return subcode;
+    }
+
+    public String getReason() {
+        return reason;
+    }
+
+    public String getNode() {
+        return node;
+    }
+
+    public String getRole() {
+        return role;
+    }
+
+	public Source getDetails() {
+		return details;
+	}
+}

Propchange: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapFault.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapHelper.java
URL: http://svn.apache.org/viewcvs/incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapHelper.java?rev=379627&r1=379626&r2=379627&view=diff
==============================================================================
--- incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapHelper.java (original)
+++ incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapHelper.java Tue Feb 21 15:40:05 2006
@@ -1,188 +1,188 @@
-/*
- * Copyright 2005-2006 The Apache Software Foundation.
- *
- * Licensed 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.soap;
-
-import java.net.URI;
-import java.util.ArrayList;
-import java.util.Iterator;
-import java.util.List;
-
-import javax.jbi.component.ComponentContext;
-import javax.jbi.messaging.DeliveryChannel;
-import javax.jbi.messaging.MessageExchange;
-import javax.jbi.messaging.MessageExchangeFactory;
-import javax.jbi.messaging.MessagingException;
-import javax.jbi.messaging.NormalizedMessage;
-import javax.jbi.servicedesc.ServiceEndpoint;
-import javax.wsdl.Definition;
-import javax.wsdl.Operation;
-import javax.wsdl.PortType;
-import javax.wsdl.factory.WSDLFactory;
-import javax.wsdl.xml.WSDLReader;
-import javax.xml.namespace.QName;
-
-import org.apache.servicemix.soap.marshalers.JBIMarshaler;
-import org.apache.servicemix.soap.marshalers.SoapMessage;
-import org.w3c.dom.Document;
-
-/**
- * Helper class for working with soap endpoints
- *
- * @author Guillaume Nodet
- * @version $Revision: 1.5 $
- * @since 3.0
- */
-public class SoapHelper {
-
-    public static final URI IN_ONLY = URI.create("http://www.w3.org/2004/08/wsdl/in-only");
-    public static final URI IN_OUT = URI.create("http://www.w3.org/2004/08/wsdl/in-out");
-    public static final URI ROBUST_IN_ONLY = URI.create("http://www.w3.org/2004/08/wsdl/robust-in-only");
-    
-	private SoapEndpoint endpoint;
-    private List policies;
-    private JBIMarshaler jbiMarshaler;
-	
-	public SoapHelper() {
-		this.policies = new ArrayList();
-        this.jbiMarshaler = new JBIMarshaler();
-	}
-	
-	public SoapHelper(SoapEndpoint endpoint) {
-		this();
-		this.endpoint = endpoint;
-	}
-	
-    public void addPolicy(Handler policy) {
-    	policies.add(policy);
-    }
-
-	public Context createContext(SoapMessage message) {
-		Context context = new Context();
-		context.setProperty(Context.SOAP_MESSAGE, message);
-		context.setProperty(Context.OPERATION, message.getBodyName());
-		context.setProperty(Context.INTERFACE, endpoint.getInterfaceName());
-		context.setProperty(Context.SERVICE, endpoint.getService());
-		context.setProperty(Context.ENDPOINT, endpoint.getEndpoint());
-		return context;
-	}
-	
-	public MessageExchange createExchange(SoapMessage message) throws Exception {
-		Context context = createContext(message);
-		analyzeHeaders(context);
-		URI mep = findMep(context);
-		if (mep == null) {
-			mep = endpoint.getDefaultMep();
-		}
-        MessageExchange exchange = createExchange(mep);
-        exchange.setService((QName) context.getProperty(Context.SERVICE));
-        exchange.setInterfaceName((QName) context.getProperty(Context.INTERFACE));
-        exchange.setOperation((QName) context.getProperty(Context.OPERATION));
-        if (context.getProperty(Context.ENDPOINT) != null) {
-    		ComponentContext componentContext = endpoint.getServiceUnit().getComponent().getComponentContext();
-    		QName serviceName = (QName) context.getProperty(Context.SERVICE);
-    		String endpointName = (String) context.getProperty(Context.ENDPOINT);
-    		ServiceEndpoint se = componentContext.getEndpoint(serviceName, endpointName);
-    		if (se != null) {
-    			exchange.setEndpoint(se);
-    		}
-        }
-        NormalizedMessage inMessage = exchange.createMessage();
-        jbiMarshaler.toNMS(inMessage, message);
-        exchange.setMessage(inMessage, "in");
-        return exchange;
-	}
-	
-    public void analyzeHeaders(Context context) throws Exception {
-    	for (Iterator it = policies.iterator(); it.hasNext();) {
-    		Handler policy = (Handler) it.next();
-    		policy.process(context);
-    	}
-    }
-	
-    public MessageExchange createExchange(URI mep) throws MessagingException {
-        ComponentContext context = endpoint.getServiceUnit().getComponent().getComponentContext();
-        DeliveryChannel channel = context.getDeliveryChannel();
-        MessageExchangeFactory factory = channel.createExchangeFactory();
-        MessageExchange exchange = factory.createExchange(mep);
-        return exchange;
-    }
-    
-    public URI findMep(Context context) throws Exception {
-		QName interfaceName = (QName) context.getProperty(Context.INTERFACE);
-		QName serviceName = (QName) context.getProperty(Context.SERVICE);
-		QName operationName = (QName) context.getProperty(Context.OPERATION);
-		String endpointName = (String) context.getProperty(Context.ENDPOINT);
-		ComponentContext componentContext = endpoint.getServiceUnit().getComponent().getComponentContext();
-		// Find target endpoint
-		ServiceEndpoint se = null;
-		if (serviceName != null && endpointName != null) {
-			se = componentContext.getEndpoint(serviceName, endpointName);
-		}
-		if (se == null && interfaceName != null) {
-			ServiceEndpoint[] ses = componentContext.getEndpoints(interfaceName);
-			if (ses != null && ses.length > 0) {
-				se = ses[0];
-			}
-		}
-		// Find WSDL description
-        Definition definition = null;
-		if (se == null) {
-			// Get this endpoint definition
-			definition = endpoint.getDefinition();
-			if (definition == null && endpoint.getDescription() != null) {
-				// Eventually parse the definition
-	            WSDLFactory factory = WSDLFactory.newInstance();
-	            WSDLReader reader = factory.newWSDLReader();
-	            definition = reader.readWSDL(null, endpoint.getDescription());
-            	endpoint.setDefinition(definition);
-			}
-		} else {
-			// Find endpoint description from the component context
-			Document description = componentContext.getEndpointDescriptor(se);
-			if (description != null) {
-				// Parse WSDL
-				WSDLFactory factory = WSDLFactory.newInstance();
-				WSDLReader reader = factory.newWSDLReader();
-				definition = reader.readWSDL(null, description);
-			}
-		}
-		
-		// Find operation within description
-        URI mep = null;
-        if (interfaceName != null && operationName != null && definition != null) {
-        	PortType portType = definition.getPortType(interfaceName);
-        	if (portType != null) {
-	        	Operation oper = portType.getOperation(operationName.getLocalPart(), null, null);
-	        	if (oper != null) {
-	        		boolean output = oper.getOutput() != null && 
-	        		                 oper.getOutput().getMessage() != null &&
-	        		                 oper.getOutput().getMessage().getParts().size() > 0;
-	        		boolean faults = oper.getFaults().size() > 0;
-	        		if (output) {
-	        			mep = IN_OUT;
-	        		} else if (faults) {
-	        			mep = ROBUST_IN_ONLY;
-	        		} else {
-	        			mep = IN_ONLY;
-	        		}
-	        	}
-        	}
-        }
-        return mep;
-    }
-    
-	
-}
+/*
+ * Copyright 2005-2006 The Apache Software Foundation.
+ *
+ * Licensed 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.soap;
+
+import java.net.URI;
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
+
+import javax.jbi.component.ComponentContext;
+import javax.jbi.messaging.DeliveryChannel;
+import javax.jbi.messaging.MessageExchange;
+import javax.jbi.messaging.MessageExchangeFactory;
+import javax.jbi.messaging.MessagingException;
+import javax.jbi.messaging.NormalizedMessage;
+import javax.jbi.servicedesc.ServiceEndpoint;
+import javax.wsdl.Definition;
+import javax.wsdl.Operation;
+import javax.wsdl.PortType;
+import javax.wsdl.factory.WSDLFactory;
+import javax.wsdl.xml.WSDLReader;
+import javax.xml.namespace.QName;
+
+import org.apache.servicemix.soap.marshalers.JBIMarshaler;
+import org.apache.servicemix.soap.marshalers.SoapMessage;
+import org.w3c.dom.Document;
+
+/**
+ * Helper class for working with soap endpoints
+ *
+ * @author Guillaume Nodet
+ * @version $Revision: 1.5 $
+ * @since 3.0
+ */
+public class SoapHelper {
+
+    public static final URI IN_ONLY = URI.create("http://www.w3.org/2004/08/wsdl/in-only");
+    public static final URI IN_OUT = URI.create("http://www.w3.org/2004/08/wsdl/in-out");
+    public static final URI ROBUST_IN_ONLY = URI.create("http://www.w3.org/2004/08/wsdl/robust-in-only");
+    
+	private SoapEndpoint endpoint;
+    private List policies;
+    private JBIMarshaler jbiMarshaler;
+	
+	public SoapHelper() {
+		this.policies = new ArrayList();
+        this.jbiMarshaler = new JBIMarshaler();
+	}
+	
+	public SoapHelper(SoapEndpoint endpoint) {
+		this();
+		this.endpoint = endpoint;
+	}
+	
+    public void addPolicy(Handler policy) {
+    	policies.add(policy);
+    }
+
+	public Context createContext(SoapMessage message) {
+		Context context = new Context();
+		context.setProperty(Context.SOAP_MESSAGE, message);
+		context.setProperty(Context.OPERATION, message.getBodyName());
+		context.setProperty(Context.INTERFACE, endpoint.getInterfaceName());
+		context.setProperty(Context.SERVICE, endpoint.getService());
+		context.setProperty(Context.ENDPOINT, endpoint.getEndpoint());
+		return context;
+	}
+	
+	public MessageExchange createExchange(SoapMessage message) throws Exception {
+		Context context = createContext(message);
+		analyzeHeaders(context);
+		URI mep = findMep(context);
+		if (mep == null) {
+			mep = endpoint.getDefaultMep();
+		}
+        MessageExchange exchange = createExchange(mep);
+        exchange.setService((QName) context.getProperty(Context.SERVICE));
+        exchange.setInterfaceName((QName) context.getProperty(Context.INTERFACE));
+        exchange.setOperation((QName) context.getProperty(Context.OPERATION));
+        if (context.getProperty(Context.ENDPOINT) != null) {
+    		ComponentContext componentContext = endpoint.getServiceUnit().getComponent().getComponentContext();
+    		QName serviceName = (QName) context.getProperty(Context.SERVICE);
+    		String endpointName = (String) context.getProperty(Context.ENDPOINT);
+    		ServiceEndpoint se = componentContext.getEndpoint(serviceName, endpointName);
+    		if (se != null) {
+    			exchange.setEndpoint(se);
+    		}
+        }
+        NormalizedMessage inMessage = exchange.createMessage();
+        jbiMarshaler.toNMS(inMessage, message);
+        exchange.setMessage(inMessage, "in");
+        return exchange;
+	}
+	
+    public void analyzeHeaders(Context context) throws Exception {
+    	for (Iterator it = policies.iterator(); it.hasNext();) {
+    		Handler policy = (Handler) it.next();
+    		policy.process(context);
+    	}
+    }
+	
+    public MessageExchange createExchange(URI mep) throws MessagingException {
+        ComponentContext context = endpoint.getServiceUnit().getComponent().getComponentContext();
+        DeliveryChannel channel = context.getDeliveryChannel();
+        MessageExchangeFactory factory = channel.createExchangeFactory();
+        MessageExchange exchange = factory.createExchange(mep);
+        return exchange;
+    }
+    
+    public URI findMep(Context context) throws Exception {
+		QName interfaceName = (QName) context.getProperty(Context.INTERFACE);
+		QName serviceName = (QName) context.getProperty(Context.SERVICE);
+		QName operationName = (QName) context.getProperty(Context.OPERATION);
+		String endpointName = (String) context.getProperty(Context.ENDPOINT);
+		ComponentContext componentContext = endpoint.getServiceUnit().getComponent().getComponentContext();
+		// Find target endpoint
+		ServiceEndpoint se = null;
+		if (serviceName != null && endpointName != null) {
+			se = componentContext.getEndpoint(serviceName, endpointName);
+		}
+		if (se == null && interfaceName != null) {
+			ServiceEndpoint[] ses = componentContext.getEndpoints(interfaceName);
+			if (ses != null && ses.length > 0) {
+				se = ses[0];
+			}
+		}
+		// Find WSDL description
+        Definition definition = null;
+		if (se == null) {
+			// Get this endpoint definition
+			definition = endpoint.getDefinition();
+			if (definition == null && endpoint.getDescription() != null) {
+				// Eventually parse the definition
+	            WSDLFactory factory = WSDLFactory.newInstance();
+	            WSDLReader reader = factory.newWSDLReader();
+	            definition = reader.readWSDL(null, endpoint.getDescription());
+            	endpoint.setDefinition(definition);
+			}
+		} else {
+			// Find endpoint description from the component context
+			Document description = componentContext.getEndpointDescriptor(se);
+			if (description != null) {
+				// Parse WSDL
+				WSDLFactory factory = WSDLFactory.newInstance();
+				WSDLReader reader = factory.newWSDLReader();
+				definition = reader.readWSDL(null, description);
+			}
+		}
+		
+		// Find operation within description
+        URI mep = null;
+        if (interfaceName != null && operationName != null && definition != null) {
+        	PortType portType = definition.getPortType(interfaceName);
+        	if (portType != null) {
+	        	Operation oper = portType.getOperation(operationName.getLocalPart(), null, null);
+	        	if (oper != null) {
+	        		boolean output = oper.getOutput() != null && 
+	        		                 oper.getOutput().getMessage() != null &&
+	        		                 oper.getOutput().getMessage().getParts().size() > 0;
+	        		boolean faults = oper.getFaults().size() > 0;
+	        		if (output) {
+	        			mep = IN_OUT;
+	        		} else if (faults) {
+	        			mep = ROBUST_IN_ONLY;
+	        		} else {
+	        			mep = IN_ONLY;
+	        		}
+	        	}
+        	}
+        }
+        return mep;
+    }
+    
+	
+}

Propchange: incubator/servicemix/trunk/servicemix-soap/src/main/java/org/apache/servicemix/soap/SoapHelper.java
------------------------------------------------------------------------------
    svn:eol-style = native