You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ode.apache.org by mr...@apache.org on 2008/05/20 00:57:26 UTC

svn commit: r658024 [1/4] - in /ode/trunk: ./ axis2-war/src/test/java/org/apache/ode/axis2/ axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/ axis2-war/src/test/java/org/apache/ode/axis2/management/ axis2-war/src/test/resources/TestHttpBinding/...

Author: mriou
Date: Mon May 19 15:57:24 2008
New Revision: 658024

URL: http://svn.apache.org/viewvc?rev=658024&view=rev
Log:
Second (and last) part of the big 1.1 to trunk merge.

Added:
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/ArithmeticsJettyWrapper.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/HttpBindingTest.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/RetireTest.java
    ode/trunk/axis2-war/src/test/resources/TestHttpBinding/
    ode/trunk/axis2-war/src/test/resources/TestHttpBinding/Arithmetics.wsdl
    ode/trunk/axis2-war/src/test/resources/TestHttpBinding/deploy.xml
    ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.bpel
    ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.wsdl
    ode/trunk/axis2-war/src/test/resources/TestHttpBinding/testRequest.soap
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.bpel
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.wsdl
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/deploy.xml
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest1.soap
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest2.soap
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.bpel
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.wsdl
    ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/deploy.xml
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/SoapExternalService.java
      - copied, changed from r658020, ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ExternalService.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpBindingValidator.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpExternalService.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpMethodBuilder.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/Messages.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/URLEncodedTransformer.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/UrlReplacementTransformer.java
    ode/trunk/axis2/src/test/java/org/apache/ode/axis2/httpbinding/
    ode/trunk/axis2/src/test/java/org/apache/ode/axis2/httpbinding/HttpBindingValidatorTest.java
    ode/trunk/axis2/src/test/java/org/apache/ode/axis2/httpbinding/HttpMethodBuilderTest.java
    ode/trunk/axis2/src/test/java/org/apache/ode/axis2/util/
    ode/trunk/axis2/src/test/java/org/apache/ode/axis2/util/UrlEncodedTransformerTest.java
    ode/trunk/axis2/src/test/java/org/apache/ode/axis2/util/UrlReplacementTransformerTest.java
    ode/trunk/axis2/src/test/resources/http-binding-validator.wsdl
    ode/trunk/axis2/src/test/resources/http-method-builder.wsdl
    ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/RetriesTest.java
    ode/trunk/utils/src/main/java/org/apache/ode/utils/fs/FileWatchDog.java
    ode/trunk/utils/src/main/java/org/apache/ode/utils/wsdl/
    ode/trunk/utils/src/main/java/org/apache/ode/utils/wsdl/Messages.java
    ode/trunk/utils/src/main/java/org/apache/ode/utils/wsdl/WsdlUtils.java
    ode/trunk/utils/src/test/java/org/apache/ode/utils/wsdl/
    ode/trunk/utils/src/test/java/org/apache/ode/utils/wsdl/WsdlUtilsTest.java
    ode/trunk/utils/src/test/resources/wsdl-utils.wsdl
Modified:
    ode/trunk/Rakefile
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/Axis2TestBase.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/ServiceFaultCatchTest.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/SoapHeaderTest.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/XSDReferencesDeployTest.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/DeploymentTest.java
    ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/InstanceManagementTest.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ExternalService.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/MessageExchangeContextImpl.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/Messages.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEServer.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEService.java
    ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/SoapMessageConverter.java
    ode/trunk/bpel-obj/src/main/java/org/apache/ode/bpel/o/OExpressionLanguage.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelProcess.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelRuntimeContextImpl.java
    ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/MockBpelServer.java
    ode/trunk/bpel-store/src/main/java/org/apache/ode/store/ProcessStoreImpl.java
    ode/trunk/bpel-store/src/main/java/org/apache/ode/store/hib/DbConfStoreConnectionFactory.java
    ode/trunk/bpel-store/src/test/java/org/apache/ode/store/hib/DaoTest.java
    ode/trunk/bpel-test/src/main/java/org/apache/ode/test/BPELTestAbstract.java
    ode/trunk/bpel-test/src/test/java/org/apache/ode/test/MessageRouting20Test.java
    ode/trunk/bpel-test/src/test/resources/log4j.properties
    ode/trunk/dao-hibernate/src/main/java/org/apache/ode/daohib/bpel/BpelDAOConnectionFactoryImpl.java
    ode/trunk/dao-hibernate/src/main/java/org/apache/ode/daohib/bpel/CorrelatorDaoImpl.java
    ode/trunk/dao-hibernate/src/main/java/org/apache/ode/daohib/bpel/hobj/HCorrelatorSelector.java
    ode/trunk/dao-jpa/src/main/java/org/apache/ode/dao/jpa/CorrelatorDAOImpl.java
    ode/trunk/dao-jpa/src/main/java/org/apache/ode/dao/jpa/MessageDAOImpl.java
    ode/trunk/il-common/src/main/java/org/apache/ode/il/epr/WSDL11Endpoint.java
    ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeLifeCycle.java
    ode/trunk/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SimpleScheduler.java
    ode/trunk/utils/src/main/java/org/apache/ode/utils/Namespaces.java
    ode/trunk/utils/src/main/java/org/apache/ode/utils/SerializableUtils.java

Modified: ode/trunk/Rakefile
URL: http://svn.apache.org/viewvc/ode/trunk/Rakefile?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/Rakefile (original)
+++ ode/trunk/Rakefile Mon May 19 15:57:24 2008
@@ -134,7 +134,7 @@
   define "axis2" do
     compile.with projects("bpel-api", "bpel-compiler", "bpel-connector", "bpel-dao", "il-common", "bpel-runtime",
       "scheduler-simple", "bpel-schemas", "bpel-store", "utils"),
-      AXIOM, AXIS2_ALL, COMMONS.logging, COMMONS.collections, DERBY, GERONIMO.kernel, GERONIMO.transaction,
+      AXIOM, AXIS2_ALL, COMMONS.logging, COMMONS.collections, COMMONS.httpclient, DERBY, GERONIMO.kernel, GERONIMO.transaction,
       JAVAX.activation, JAVAX.servlet, JAVAX.stream, JAVAX.transaction, JENCKS, WSDL4J, WS_COMMONS.xml_schema,
       XMLBEANS
 
@@ -179,7 +179,7 @@
       end
     end
     
-    test.with projects("tools"), libs, AXIS2_TEST, AXIOM, JAVAX.servlet
+    test.with projects("tools"), libs, AXIS2_TEST, AXIOM, JAVAX.servlet, Buildr::Jetty::REQUIRES
     test.setup task(:prepare_webapp) do |task|
       cp_r _("src/main/webapp"), _("target/test-classes")
       cp Dir[_("src/main/webapp/WEB-INF/classes/*")], _("target/test-classes")
@@ -284,7 +284,7 @@
 
   desc "ODE Process Store"
   define "bpel-store" do
-    compile.with projects("bpel-api", "bpel-compiler", "bpel-dao", "bpel-obj", "bpel-schemas",
+    compile.with projects("bpel-api", "bpel-compiler", "bpel-dao", "bpel-obj", "bpel-schemas", "il-common",
       "dao-hibernate", "utils"),
       COMMONS.logging, JAVAX.persistence, JAVAX.stream, HIBERNATE, HSQLDB, XMLBEANS, XERCES, WSDL4J
     compile { open_jpa_enhance }
@@ -464,7 +464,7 @@
 
   desc "ODE Utils"
   define "utils" do
-    compile.with COMMONS.logging, COMMONS.pool, LOG4J, XERCES, JAVAX.stream
+    compile.with COMMONS.logging, COMMONS.pool, LOG4J, XERCES, JAVAX.stream, WSDL4J
 	test.exclude "*TestResources"
     package :jar
   end

Modified: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/Axis2TestBase.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/Axis2TestBase.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/Axis2TestBase.java (original)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/Axis2TestBase.java Mon May 19 15:57:24 2008
@@ -9,27 +9,19 @@
 import org.apache.axis2.engine.AxisServer;
 import org.apache.axis2.engine.MessageReceiver;
 import org.apache.ode.tools.sendsoap.cline.HttpSoapSender;
-import org.apache.ode.bpel.compiler.wsdl.WSDLFactory4BPEL;
-import org.apache.ode.bpel.compiler.wsdl.WSDLFactoryBPEL20;
-import org.apache.ode.bpel.compiler.wsdl.Definition4BPEL;
-import org.apache.ode.bpel.compiler.DefaultResourceFinder;
-import org.apache.ode.bpel.compiler.WSDLLocatorImpl;
 import org.apache.ode.axis2.util.Axis2UriResolver;
 import org.apache.ode.axis2.util.Axis2WSDLLocator;
 import org.apache.ode.axis2.hooks.ODEAxisService;
-import org.apache.ode.axis2.hooks.ODEMessageReceiver;
 
 import javax.servlet.ServletException;
-import javax.wsdl.xml.WSDLReader;
 import javax.wsdl.WSDLException;
 import javax.xml.namespace.QName;
 import java.io.*;
 import java.net.URL;
 import java.net.URI;
-import java.net.MalformedURLException;
 import java.net.URISyntaxException;
-import java.util.ArrayList;
 import java.util.Iterator;
+import java.util.Collection;
 
 /**
  * @author Matthieu Riou <mr...@apache.org>
@@ -38,12 +30,26 @@
 
     protected ODEAxis2Server server;
 
-    public void start() throws Exception {
+    public void startServer() throws Exception {
         String webappPath = getClass().getClassLoader().getResource("webapp").getFile();
         server = new ODEAxis2Server(webappPath);
         server.start();
     }
 
+    public void stopServer() throws AxisFault {
+        server.stop();
+    }
+
+    protected void setUp() throws Exception {
+        super.setUp();
+        startServer();
+    }
+
+    protected void tearDown() throws Exception {
+        stopServer();
+        super.tearDown();
+    }
+
     protected class ODEAxis2Server extends AxisServer {
         ODEServer _ode = new ODEServer();
         String webappPath;
@@ -68,17 +74,17 @@
         }
 
         public void stop() throws AxisFault {
-            super.stop();
             _ode.shutDown();
+            super.stop();
         }
 
-        protected void deployProcess(String bundleName) {
-            _ode.getProcessStore().deploy(new File(getBundleDir(bundleName)));
+        public Collection<QName> deployProcess(String bundleName) {
+            return _ode.getProcessStore().deploy(new File(getBundleDir(bundleName)));
         }
-        protected void undeployProcess(String bundleName) {
+        public void undeployProcess(String bundleName) {
             _ode.getProcessStore().undeploy(new File(getBundleDir(bundleName)));
         }
-        protected boolean isDeployed(String bundleName) {
+        public boolean isDeployed(String bundleName) {
             return _ode.getProcessStore().getPackages().contains(bundleName);
         }
 
@@ -113,7 +119,7 @@
             getConfigurationContext().getAxisConfiguration().addService(axisService);            
         }
 
-        protected String sendRequestFile(String endpoint, String bundleName, String filename) {
+        public String sendRequestFile(String endpoint, String bundleName, String filename) {
             try {
                 return HttpSoapSender.doSend(new URL(endpoint),
                         new FileInputStream(getBundleDir(bundleName)+"/" + filename), null, 0, null, null, null);
@@ -142,6 +148,10 @@
             }
             configContext.getAxisConfiguration().getService(serviceName).printWSDL(fos);
         }
+
+        public ODEServer getODEServer() {
+            return _ode;
+        }
     }
 
 }

Modified: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/ServiceFaultCatchTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/ServiceFaultCatchTest.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/ServiceFaultCatchTest.java (original)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/ServiceFaultCatchTest.java Mon May 19 15:57:24 2008
@@ -18,7 +18,7 @@
         String bundleName = "TestStructuredFault";
         // deploy the required service
         server.deployService(DummyService.class.getCanonicalName());
-        if (!server.isDeployed("TestStructuredFault")) server.deployProcess("TestStructuredFault");
+        if (!server.isDeployed(bundleName)) server.deployProcess(bundleName);
 
         try {
             String response = server.sendRequestFile("http://localhost:8080/processes/helloWorld",

Modified: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/SoapHeaderTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/SoapHeaderTest.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/SoapHeaderTest.java (original)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/SoapHeaderTest.java Mon May 19 15:57:24 2008
@@ -1,6 +1,5 @@
 package org.apache.ode.axis2;
 
-import org.apache.axis2.description.AxisService;
 import org.apache.axis2.engine.MessageReceiver;
 import org.apache.axis2.engine.AxisEngine;
 import org.apache.axis2.context.MessageContext;
@@ -21,13 +20,6 @@
  */
 public class SoapHeaderTest extends Axis2TestBase {
 
-    protected void setUp() throws Exception {
-        start();
-    }
-    protected void tearDown() throws Exception {
-        server.stop();
-    }
-
     public void testSimplePassing() throws Exception {
         server.deployService("TestSoapHeader", "dummy-service.wsdl",
                 new QName("http://axis2.ode.apache.org", "DummyService"), "DummyServiceSOAP11port_http", 

Modified: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/XSDReferencesDeployTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/XSDReferencesDeployTest.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/XSDReferencesDeployTest.java (original)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/XSDReferencesDeployTest.java Mon May 19 15:57:24 2008
@@ -5,10 +5,6 @@
  */
 public class XSDReferencesDeployTest extends Axis2TestBase {
 
-    protected void setUp() throws Exception {
-        start();
-    }
-
     public void testSimpleFaultCatch() throws Exception {
         server.deployService(DummyService.class.getCanonicalName());
         // If we have a bug, this will throw an exception, no need to assert

Added: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/ArithmeticsJettyWrapper.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/ArithmeticsJettyWrapper.java?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/ArithmeticsJettyWrapper.java (added)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/ArithmeticsJettyWrapper.java Mon May 19 15:57:24 2008
@@ -0,0 +1,247 @@
+/*
+ * 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.ode.axis2.httpbinding;
+
+import org.mortbay.jetty.handler.AbstractHandler;
+import org.mortbay.jetty.handler.ContextHandler;
+import org.mortbay.jetty.handler.ContextHandlerCollection;
+import org.mortbay.jetty.Server;
+import org.mortbay.jetty.Handler;
+import org.mortbay.jetty.Request;
+import org.apache.ode.utils.DOMUtils;
+import org.apache.ode.utils.StreamUtils;
+import org.w3c.dom.Document;
+import org.w3c.dom.Element;
+import org.xml.sax.SAXException;
+
+import javax.servlet.http.HttpServletRequest;
+import javax.servlet.http.HttpServletResponse;
+import javax.servlet.ServletException;
+import javax.servlet.ServletInputStream;
+import java.io.IOException;
+
+/**
+ * @author <a href="mailto:midon@intalio.com">Alexis Midon</a>
+ */
+public class ArithmeticsJettyWrapper {
+
+    protected Server server;
+    private ContextHandlerCollection handlerColl;
+
+    public ArithmeticsJettyWrapper() throws Exception {
+        this(7070);
+    }
+
+    public ArithmeticsJettyWrapper(int port) throws Exception {
+        server = new Server(port);
+        // Adding the buildr handler to control our server lifecycle
+        ContextHandler context = new ContextHandler();
+        context.setContextPath("/HttpBindingTestService");
+        Handler handler = new ArithmeticsServiceHandler();
+        context.setHandler(handler);
+
+        handlerColl = new ContextHandlerCollection();
+        handlerColl.setHandlers(new Handler[]{context});
+
+        server.addHandler(handlerColl);
+    }
+
+    private class ArithmeticsServiceHandler extends AbstractHandler {
+        /*
+        6 urls to handle:
+        (GET)   http://localhost:8080/HttpBindingTestService/OlaElMundo-GET/plus/(left):(right)
+        (GET)   http://         ........                    /OlaElMundo-GET/minus?left=&right=
+        (POST)  http://         ........                    /OlaElMundo-POST/plus
+        (POST)  http://         ........                    /OlaElMundo-POST/minus
+        (POST)  http://         ........                    /SalutLaTerre/addition
+        (POST)  http://         ........                    /SalutLaTerre/sumOfIntegers
+        */
+        public void handle(String s, HttpServletRequest request, HttpServletResponse response, int i) throws IOException, ServletException {
+
+            try {
+                String method = request.getMethod();
+                String uri = request.getRequestURI();
+                if ("/HttpBindingTestService/".equals(uri)) {
+                    response.getWriter().println("HttpBindingTestService ready!");
+                } else if (uri.contains("OlaElMundo-GET") || uri.contains("OlaElMundo-DELETE")) {
+//                    if (!"GET".equalsIgnoreCase(method)) {
+                    if (false) {
+                        response.sendError(405, "Expecting method is GET");
+                    } else {
+                        if (!uri.contains("plus") && !uri.contains("minus")) {
+                            response.sendError(404);
+                        } else {
+                            boolean ok = true;
+                            int left = 0, right = 0;
+                            try {
+                                if (uri.contains("plus")) {
+                                    int index = uri.lastIndexOf("/");
+                                    String[] op = uri.substring(index + 1).split(":");
+                                    left = Integer.parseInt(op[0]);
+                                    right = Integer.parseInt(op[1]);
+                                } else if (uri.contains("minus")) {
+                                    left = Integer.parseInt(request.getParameter("left"));
+                                    right = -1 * Integer.parseInt(request.getParameter("right"));
+                                } else {
+                                    ok = false;
+                                }
+                            } catch (NumberFormatException e) {
+                                ok = false;
+                            }
+
+                            if (!ok) {
+                                response.sendError(400);
+                            } else {
+                                Document doc = DOMUtils.newDocument();
+                                Element resElt = doc.createElement("theresult");
+                                resElt.setTextContent(String.valueOf(left + right));
+                                response.getOutputStream().print(DOMUtils.domToString(resElt));
+                                response.getOutputStream().close();
+                                response.setStatus(200);
+                            }
+                        }
+                    }
+                } else if (uri.contains("OlaElMundo-POST") || uri.contains("OlaElMundo-PUT")) {
+//                    if (!"POST".equalsIgnoreCase(method)) {
+                    if (false) {
+                        response.sendError(405, "Expecting method is POST");
+                        return;
+                    } else {
+                        String operation;
+                        if (!uri.contains("plus") && !uri.contains("minus")) {
+                            response.sendError(404);
+                        } else {
+                            // parse body, form-urlencoded
+                            int res = Integer.MIN_VALUE;
+                            boolean ok = true;
+                            StringBuffer sb = null;
+                            String body = new String(StreamUtils.read(request.getInputStream()));
+                            if (!body.matches("[^=]*=[+-]?\\d*&[^=]*=[+-]?\\d*")) {
+                                ok = false;
+                            } else {
+                                String[] sp = body.split("&");
+                                String[] op0 = sp[0].split("=");
+                                String[] op1 = sp[1].split("=");
+                                try {
+                                    int left, right;
+                                    if (op0[0].equals("left")) {
+                                        left = Integer.valueOf(op0[1]);
+                                        right = Integer.valueOf(op1[1]);
+                                    } else {
+                                        left = Integer.valueOf(op1[1]);
+                                        right = Integer.valueOf(op0[1]);
+                                    }
+                                    if (uri.contains("minus")) {
+                                        right = -1 * right;
+                                    }
+                                    res = left + right;
+                                } catch (NumberFormatException e) {
+                                    ok = false;
+                                }
+                            }
+                            if (!ok) {
+                                response.sendError(400);
+                            } else {
+                                Element resElt = DOMUtils.newDocument().createElement("theresult");
+                                resElt.setTextContent(String.valueOf(res));
+                                response.getOutputStream().print(DOMUtils.domToString(resElt));
+                                response.setStatus(200);
+                            }
+                        }
+                    }
+                } else if (uri.contains("SalutLaTerre")) {
+                    if (!"POST".equalsIgnoreCase(method)) {
+                        response.sendError(405, "Expecting method is POST");
+                        return;
+                    } else {
+                        if (uri.contains("addition")) {
+                            Document bodyDoc = parseBody(request.getInputStream(), response);
+                            if (bodyDoc != null) {
+                                // we expect the element operandList
+                                if (!"operandList".equals(bodyDoc.getDocumentElement().getNodeName())) {
+                                    response.sendError(400, "The first element should be named operandList");
+                                } else {
+                                    Element firstOperand = DOMUtils.getFirstChildElement(bodyDoc.getDocumentElement());
+                                    Element secondElement = DOMUtils.getNextSiblingElement(firstOperand);
+                                    String left = DOMUtils.getTextContent(firstOperand);
+                                    String right = DOMUtils.getTextContent(secondElement);
+                                    Element res = bodyDoc.createElementNS("http://ode/bpel/arithmetics", "theresult");
+                                    res.setTextContent(String.valueOf(Integer.valueOf(left) + Integer.valueOf(right)));
+                                    response.getOutputStream().print(DOMUtils.domToString(res));
+                                    response.setStatus(200);
+                                }
+                            }
+
+                        } else if (uri.contains("sumOfIntegers")) {
+                            Document bodyDoc = parseBody(request.getInputStream(), response);
+                            if (bodyDoc != null) {
+                                Element firstOperand = DOMUtils.getFirstChildElement(bodyDoc.getDocumentElement());
+                                Element secondElement = DOMUtils.getNextSiblingElement(firstOperand);
+                                int left = Integer.valueOf(DOMUtils.getTextContent(firstOperand));
+                                int right = Integer.valueOf(DOMUtils.getTextContent(secondElement));
+
+                                int min = Math.min(left,right);
+                                int max = Math.max(left,right);
+//                                Element arrayElt = bodyDoc.createElement("sumOfInteger");
+                                Element anElt = bodyDoc.createElementNS("http://ode/bpel/arithmetics", "sumOfInteger");
+                                Element msg = bodyDoc.createElement("msg");
+                                Element resultIs = bodyDoc.createElement("resultIs");
+                                msg.setTextContent("A dummy message we don't care about. Only purpose is to have a complex type");
+                                resultIs.setTextContent(String.valueOf((max*(max+1)-min*(min+1))/2));
+
+                                anElt.appendChild(msg);
+                                anElt.appendChild(resultIs);
+                                response.getOutputStream().print(DOMUtils.domToString(anElt));
+                                response.setStatus(200);
+                            }
+                        } else {
+                            response.sendError(404);
+                        }
+                    }
+                }
+            } catch (Exception e) {
+                response.sendError(500, e.getMessage());
+            } finally {
+                ((Request) request).setHandled(true);
+            }
+        }
+
+        private Document parseBody(ServletInputStream bodyStream, HttpServletResponse response) throws IOException {
+            if (bodyStream == null) {
+                response.sendError(400, "Missing body!");
+            } else {
+                try {
+                    return DOMUtils.parse(bodyStream);
+                } catch (SAXException e) {
+                    response.sendError(400, "Failed to parse body! " + e.getMessage());
+                }
+            }
+            return null;
+        }
+    }
+
+    public static void main(String[] args) {
+        try {
+            new ArithmeticsJettyWrapper();
+        } catch (Exception e) {
+            e.printStackTrace();
+        }
+    }
+}

Added: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/HttpBindingTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/HttpBindingTest.java?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/HttpBindingTest.java (added)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/httpbinding/HttpBindingTest.java Mon May 19 15:57:24 2008
@@ -0,0 +1,62 @@
+package org.apache.ode.axis2.httpbinding;
+
+import org.apache.ode.axis2.Axis2TestBase;
+
+import java.util.concurrent.CountDownLatch;
+
+/**
+ * <p/>
+ * This unit test passes an integer to a BPEL. Then the BPEL invokes the 6 operations of Arithmetics.wsdl.
+ * These operations are set up to use the various Http binding configurations.  
+ * <p/>
+ * From a "business" standpoint:<br/>
+ * Let N be the input number, stored in the testRequest1.soap file<br/>
+ * This test will compute the Sum of the first (N + 5) positive integers.
+ * <p/>
+ * If N=10, the expected result is 15*(15+1)/2 = 120
+ *
+ * @author <a href="mailto:midon@intalio.com">Alexis Midon</a>
+ */
+public class HttpBindingTest extends Axis2TestBase {
+    protected ArithmeticsJettyWrapper jettyWrapper;
+
+    CountDownLatch latch;
+
+    protected void setUp() throws Exception {
+        super.setUp();
+        latch = new CountDownLatch(1);
+        jettyWrapper = new ArithmeticsJettyWrapper(7070);
+        new Thread("HttpBindingJetty") {
+            public void run() {
+                try {
+                    jettyWrapper.server.start();
+                    latch.countDown();
+                } catch (Exception e) {
+                    e.printStackTrace();
+                }
+            }
+        }.start();
+    }
+
+    protected void tearDown() throws Exception {
+        jettyWrapper.server.stop();
+        super.tearDown();
+    }
+
+    public void testHttpBinding() throws Exception {
+        // wait for jetty to be ready
+        latch.await();
+        String bundleName = "TestHttpBinding";
+        // deploy the required service
+        if (!server.isDeployed(bundleName)) server.deployProcess(bundleName);
+        try {
+            String response = server.sendRequestFile("http://localhost:8080/processes/helloWorld",
+                    bundleName, "testRequest.soap");
+            int valueInSoapRequest = 100;
+            int n = 5 + valueInSoapRequest;
+            assertTrue(response.indexOf(String.valueOf(n * (n + 1) / 2)) >= 0);
+        } finally {
+            server.undeployProcess(bundleName);
+        }
+    }
+}

Modified: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/DeploymentTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/DeploymentTest.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/DeploymentTest.java (original)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/DeploymentTest.java Mon May 19 15:57:24 2008
@@ -19,7 +19,6 @@
 
 package org.apache.ode.axis2.management;
 
-import junit.framework.TestCase;
 import org.apache.axiom.om.*;
 import org.apache.axiom.om.util.Base64;
 import org.apache.axis2.AxisFault;
@@ -131,7 +130,7 @@
     }
 
     protected void setUp() throws Exception {
-        start();
+        super.setUp();
         // Create a factory
         _factory = OMAbstractFactory.getOMFactory();
         _client = new ServiceClientUtil();
@@ -146,7 +145,7 @@
 
     protected void tearDown() throws Exception {
         undeploy(_package);
-        server.stop();        
+        super.tearDown();
     }
 
     private String deploy(String packageName) throws Exception {

Modified: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/InstanceManagementTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/InstanceManagementTest.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/InstanceManagementTest.java (original)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/InstanceManagementTest.java Mon May 19 15:57:24 2008
@@ -159,7 +159,7 @@
     }
 
     protected void setUp() throws Exception {
-        start();
+        super.setUp();
 
         // Create a factory
         _factory = OMAbstractFactory.getOMFactory();
@@ -214,7 +214,7 @@
         OMElement result = sendToPM(listRoot);
         assert(result.toString().indexOf("process-info") < 0);
 
-        server.stop();
+        super.tearDown();
     }
 
     private OMElement sendToPM(OMElement msg) throws AxisFault {

Added: ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/RetireTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/RetireTest.java?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/RetireTest.java (added)
+++ ode/trunk/axis2-war/src/test/java/org/apache/ode/axis2/management/RetireTest.java Mon May 19 15:57:24 2008
@@ -0,0 +1,35 @@
+package org.apache.ode.axis2.management;
+
+import org.apache.ode.axis2.Axis2TestBase;
+import org.apache.ode.axis2.DummyService;
+
+import javax.xml.namespace.QName;
+
+/**
+ * @author Matthieu Riou <mr...@apache.org>
+ */
+public class RetireTest extends Axis2TestBase {
+
+    public void testRetiredInstance() throws Exception {
+        String bundleName = "TestInstanceRetire";
+        System.out.println("=> " + server.getODEServer().getProcessStore().getPackages());
+        if (server.isDeployed("1")) server.undeployProcess(bundleName + "/1");
+        if (server.isDeployed("2")) server.undeployProcess(bundleName + "/2");
+        
+        QName deployedQName = server.deployProcess(bundleName + "/1").iterator().next();
+
+        server.sendRequestFile("http://localhost:8080/processes/testretire",
+                bundleName + "/1", "testRequest1.soap");
+
+        server.getODEServer().getProcessManagement().setRetired(deployedQName, true);
+        server.deployProcess(bundleName + "/2");
+        
+        String response = server.sendRequestFile("http://localhost:8080/processes/testretire",
+                bundleName + "/1", "testRequest2.soap");
+
+        System.out.println("###############################################");
+        System.out.println(response);
+        System.out.println("###############################################");
+        assertTrue(response.indexOf("DONE") > 0);
+    }
+}

Added: ode/trunk/axis2-war/src/test/resources/TestHttpBinding/Arithmetics.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestHttpBinding/Arithmetics.wsdl?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestHttpBinding/Arithmetics.wsdl (added)
+++ ode/trunk/axis2-war/src/test/resources/TestHttpBinding/Arithmetics.wsdl Mon May 19 15:57:24 2008
@@ -0,0 +1,245 @@
+<?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.
+  -->
+
+<wsdl:definitions
+        xmlns="http://schemas.xmlsoap.org/wsdl/"
+        xmlns:http="http://schemas.xmlsoap.org/wsdl/http/"
+        xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/"
+        xmlns:tns="http://ode/bpel/arithmetics"
+        xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/"
+        xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+        targetNamespace="http://ode/bpel/arithmetics">
+
+
+    <wsdl:types>
+        <xsd:schema xmlns:xsd="http://www.w3.org/2001/XMLSchema" targetNamespace="http://ode/bpel/arithmetics">
+            <xsd:complexType name="operandListType">
+                <xsd:sequence>
+                    <xsd:element name="operand" type="xsd:string" maxOccurs="unbounded" minOccurs="2"/>
+                </xsd:sequence>
+            </xsd:complexType>
+
+            <xsd:element name="operandList" type="tns:operandListType"/>
+
+            <xsd:complexType name="resultType">
+                <xsd:sequence>
+                    <xsd:element name="msg" type="xsd:string"/>
+                    <xsd:element name="resultIs" type="xsd:int"/>
+                </xsd:sequence>
+            </xsd:complexType>
+
+            <xsd:element name="theresult" type="xsd:int"/>
+        </xsd:schema>
+    </wsdl:types>
+
+
+    <wsdl:message name="twoOperandRequest">
+        <wsdl:part name="left" type="xsd:integer"/>
+        <wsdl:part name="right" type="xsd:integer"/>
+    </wsdl:message>
+    <wsdl:message name="resultResponse">
+        <wsdl:part name="result" type="xsd:integer"/>
+    </wsdl:message>
+    <wsdl:message name="additionRequest">
+        <wsdl:part name="operands" element="tns:operandList"/>
+    </wsdl:message>
+    <wsdl:message name="additionResponse">
+        <wsdl:part name="result" element="tns:theresult"/>
+    </wsdl:message>
+    <wsdl:message name="sumOfIntegersRequest">
+        <wsdl:part name="range" type="tns:operandListType"/>
+    </wsdl:message>
+    <wsdl:message name="sumOfIntegersResponse">
+        <wsdl:part name="result" type="tns:resultType"/>
+    </wsdl:message>
+
+
+    <wsdl:portType name="OlaElMundoPortType">
+        <!-- will use with GET + urlReplacement + simple types (input/output)-->
+        <wsdl:operation name="plus">
+            <wsdl:input message="tns:twoOperandRequest"/>
+            <wsdl:output message="tns:resultResponse"/>
+        </wsdl:operation>
+        <!-- will use with GET + urlEncoded + simple types (input/output) -->
+        <wsdl:operation name="minus">
+            <wsdl:input message="tns:twoOperandRequest"/>
+            <wsdl:output message="tns:resultResponse"/>
+        </wsdl:operation>
+    </wsdl:portType>
+    <wsdl:portType name="SalutLaTerrePortType">
+        <!-- will use with POST + text/xml + elements (input/output) -->
+        <wsdl:operation name="addition">
+            <wsdl:input message="tns:additionRequest"/>
+            <wsdl:output message="tns:additionResponse"/>
+        </wsdl:operation>
+        <!-- will use with POST + text/xml + complex type (input/output) -->
+        <wsdl:operation name="sumOfIntegers">
+            <wsdl:input message="tns:sumOfIntegersRequest"/>
+            <wsdl:output message="tns:sumOfIntegersResponse"/>
+        </wsdl:operation>
+    </wsdl:portType>
+
+
+    <wsdl:binding name="OlaElMundoHttpBinding-GET" type="tns:OlaElMundoPortType">
+        <http:binding verb="GET"/>
+        <wsdl:operation name="plus">
+            <http:operation location="plus/(left):(right)"/>
+            <wsdl:input>
+                <http:urlReplacement/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="minus">
+            <http:operation location="minus"/>
+            <wsdl:input>
+                <http:urlEncoded/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+
+    <wsdl:binding name="OlaElMundoHttpBinding-POST" type="tns:OlaElMundoPortType">
+        <http:binding verb="POST"/>
+        <wsdl:operation name="plus">
+            <http:operation location="plus"/>
+            <wsdl:input>
+                <mime:content type="application/x-www-form-urlencoded"/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="minus">
+            <http:operation location="minus"/>
+            <wsdl:input>
+                <http:urlEncoded/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+
+
+    <wsdl:binding name="OlaElMundoHttpBinding-PUT" type="tns:OlaElMundoPortType">
+        <http:binding verb="PUT"/>
+        <wsdl:operation name="plus">
+            <http:operation location="plus"/>
+            <wsdl:input>
+                <mime:content type="application/x-www-form-urlencoded"/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="minus">
+            <http:operation location="minus"/>
+            <wsdl:input>
+                <http:urlEncoded/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+
+
+    <wsdl:binding name="OlaElMundoHttpBinding-DELETE" type="tns:OlaElMundoPortType">
+        <http:binding verb="DELETE"/>
+        <wsdl:operation name="plus">
+            <http:operation location="plus/(left):(right)"/>
+            <wsdl:input>
+                <http:urlReplacement/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="minus">
+            <http:operation location="minus"/>
+            <wsdl:input>
+                <http:urlEncoded/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+
+
+    <wsdl:binding name="SalutLaTerreHttpBinding" type="tns:SalutLaTerrePortType">
+        <http:binding verb="POST"/>
+        <wsdl:operation name="addition">
+            <http:operation location="addition"/>
+            <wsdl:input>
+                <mime:content type="text/xml" part="operands"/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="sumOfIntegers">
+            <http:operation location="sumOfIntegers"/>
+            <wsdl:input>
+                <mime:content type="text/xml" part="range"/>
+            </wsdl:input>
+            <wsdl:output>
+                <mime:content type="text/xml" part="result"/>
+            </wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+
+
+    <!--
+        6 urls to handle:
+        (GET)       http://localhost:8080/HttpBindingTestService/OlaElMundo-GET/plus/(left):(right)
+        (GET)       http://         ........                    /OlaElMundo-GET/minus?left=&right=
+        (DELETE)    http://localhost:8080/HttpBindingTestService/OlaElMundo-DELETE/plus/(left):(right)
+        (DELETE)    http://         ........                    /OlaElMundo-DELETE/minus?left=&right=
+        (POST)      http://         ........                    /OlaElMundo-POST/plus
+        (POST)      http://         ........                    /OlaElMundo-POST/minus
+        (PUT)       http://         ........                    /OlaElMundo-PUT/plus
+        (PUT)       http://         ........                    /OlaElMundo-PUT/minus
+        (POST)      http://         ........                    /SalutLaTerre/addition
+        (POST)      http://         ........                    /SalutLaTerre/sumOfIntegers
+    -->
+    <wsdl:service name="HttpBindingTestService">
+        <wsdl:port name="OlaElMundo-GET_httpport" binding="tns:OlaElMundoHttpBinding-GET">
+            <http:address location="http://localhost:7070/HttpBindingTestService/OlaElMundo-GET"/>
+        </wsdl:port>
+        <wsdl:port name="OlaElMundo-POST_httpport" binding="tns:OlaElMundoHttpBinding-POST">
+            <http:address location="http://localhost:7070/HttpBindingTestService/OlaElMundo-POST"/>
+        </wsdl:port>
+        <wsdl:port name="OlaElMundo-PUT_httpport" binding="tns:OlaElMundoHttpBinding-PUT">
+            <http:address location="http://localhost:7070/HttpBindingTestService/OlaElMundo-PUT"/>
+        </wsdl:port>
+        <wsdl:port name="OlaElMundo-DELETE_httpport" binding="tns:OlaElMundoHttpBinding-DELETE">
+            <http:address location="http://localhost:7070/HttpBindingTestService/OlaElMundo-DELETE"/>
+        </wsdl:port>
+        <wsdl:port name="SalutLaTerre_httpport" binding="tns:SalutLaTerreHttpBinding">
+            <http:address location="http://localhost:7070/HttpBindingTestService/SalutLaTerre"/>
+        </wsdl:port>
+    </wsdl:service>
+</wsdl:definitions>
+

Added: ode/trunk/axis2-war/src/test/resources/TestHttpBinding/deploy.xml
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestHttpBinding/deploy.xml?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestHttpBinding/deploy.xml (added)
+++ ode/trunk/axis2-war/src/test/resources/TestHttpBinding/deploy.xml Mon May 19 15:57:24 2008
@@ -0,0 +1,46 @@
+<!--
+  ~ 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.
+  -->
+<deploy xmlns="http://www.apache.org/ode/schemas/dd/2007/03"
+	xmlns:pns="http://ode/bpel/unit-test" 
+	xmlns:wns="http://ode/bpel/unit-test.wsdl"
+    xmlns:dns="http://ode/bpel/arithmetics">
+
+
+	<process name="pns:HttpBindingTest">
+		<active>true</active>
+		<provide partnerLink="helloPartnerLink">
+			<service name="wns:HelloService" port="HelloPort"/>
+		</provide>
+        <invoke partnerLink="salutPartnerLink">
+            <service name="dns:HttpBindingTestService" port="SalutLaTerre_httpport"/>
+        </invoke>
+        <invoke partnerLink="olaGetPartnerLink">
+            <service name="dns:HttpBindingTestService" port="OlaElMundo-GET_httpport"/>
+        </invoke>
+        <invoke partnerLink="olaPostPartnerLink">
+            <service name="dns:HttpBindingTestService" port="OlaElMundo-POST_httpport"/>
+        </invoke>
+        <invoke partnerLink="olaPutPartnerLink">
+            <service name="dns:HttpBindingTestService" port="OlaElMundo-PUT_httpport"/>
+        </invoke>
+        <invoke partnerLink="olaDeletePartnerLink">
+            <service name="dns:HttpBindingTestService" port="OlaElMundo-DELETE_httpport"/>
+        </invoke>
+    </process>
+</deploy>

Added: ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.bpel?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.bpel (added)
+++ ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.bpel Mon May 19 15:57:24 2008
@@ -0,0 +1,246 @@
+<!--
+  ~ 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.
+  -->
+<process name="HttpBindingTest"
+         targetNamespace="http://ode/bpel/unit-test"
+         xmlns="http://docs.oasis-open.org/wsbpel/2.0/process/executable"
+         xmlns:tns="http://ode/bpel/unit-test"
+         xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+         xmlns:test="http://ode/bpel/unit-test.wsdl"
+         xmlns:dummy="http://ode/bpel/arithmetics"
+         queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
+         expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
+
+    <import location="http-binding-test.wsdl"
+            namespace="http://ode/bpel/unit-test.wsdl"
+            importType="http://schemas.xmlsoap.org/wsdl/"/>
+
+    <partnerLinks>
+        <partnerLink name="helloPartnerLink"
+                     partnerLinkType="test:HelloPartnerLinkType" myRole="me"/>
+        <partnerLink name="salutPartnerLink"
+                     partnerLinkType="test:SalutLinkType" partnerRole="salut"/>
+        <partnerLink name="olaGetPartnerLink"
+                     partnerLinkType="test:OlaLinkType" partnerRole="ola"/>
+        <partnerLink name="olaPostPartnerLink"
+                     partnerLinkType="test:OlaLinkType" partnerRole="ola"/>
+        <partnerLink name="olaPutPartnerLink"
+                     partnerLinkType="test:OlaLinkType" partnerRole="ola"/>
+        <partnerLink name="olaDeletePartnerLink"
+                     partnerLinkType="test:OlaLinkType" partnerRole="ola"/>
+    </partnerLinks>
+
+    <variables>
+        <variable name="inputVar" messageType="test:HelloMessage"/>
+        <variable name="outputVar" messageType="test:HelloMessage"/>
+        <variable name="operands" messageType="dummy:twoOperandRequest"/>
+        <variable name="result" messageType="dummy:resultResponse"/>
+        <variable name="additionInput" messageType="dummy:additionRequest"/>
+        <variable name="additionOutput" messageType="dummy:additionResponse"/>
+        <variable name="sumOfIntegersInput" messageType="dummy:sumOfIntegersRequest"/>
+        <variable name="sumOfIntegersOutput" messageType="dummy:sumOfIntegersResponse"/>
+    </variables>
+
+    <!-- ###################################################### -->
+    <!-- ###################################################### -->
+    <!-- let N be the input number -->
+    <!-- This sequence will compute the Sum of the first (N + 5) positive integers -->
+    <!-- ###################################################### -->
+    <!-- ###################################################### -->
+    <sequence>
+        <receive name="start" partnerLink="helloPartnerLink" portType="test:HelloPortType"
+                 operation="hello" variable="inputVar" createInstance="yes"/>
+
+        <!-- Compute r = x + 1 -->
+        <assign>
+            <copy>
+                <from>$inputVar.TestPart</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>1</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+
+        <invoke partnerLink="olaGetPartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="plus" inputVariable="operands" outputVariable="result"/>
+
+        <!-- Compute r = r - 2  (= x - 1)    -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>2</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaGetPartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="minus" inputVariable="operands" outputVariable="result"/>
+
+        <!-- Compute r = r + 3 (= x + 2) -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>3</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaPostPartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="plus" inputVariable="operands" outputVariable="result"/>
+
+        <!-- Compute r = r - 4 (= x - 2) -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>4</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaPostPartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="minus" inputVariable="operands" outputVariable="result"/>
+
+
+
+        <!-- Compute r = r + 5 (= x + 3) -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>5</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaDeletePartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="plus" inputVariable="operands" outputVariable="result"/>
+
+        <!-- Compute r = r - 6 (= x - 3) -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>6</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaDeletePartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="minus" inputVariable="operands" outputVariable="result"/>
+
+
+
+        <!-- Compute r = r + 7 (= x + 4) -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>7</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaPutPartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="plus" inputVariable="operands" outputVariable="result"/>
+
+        <!-- Compute r = r - 9 (= x - 5) -->
+        <assign>
+            <copy>
+                <from>$result.result</from>
+                <to>$operands.left</to>
+            </copy>
+            <copy>
+                <from>9</from>
+                <to>$operands.right</to>
+            </copy>
+        </assign>
+        <invoke partnerLink="olaPutPartnerLink" portType="dummy:OlaElMundoPortType"
+                operation="minus" inputVariable="operands" outputVariable="result"/>
+
+
+        <!-- Compute r = r + 10 (= x + 5) -->
+        <assign>
+            <!-- First, build the proper element -->
+            <copy>
+                <from>
+                    <literal>
+                        <dummy:operandList>
+                            <dummy:operand></dummy:operand>
+                            <dummy:operand>10</dummy:operand>
+                        </dummy:operandList>
+                    </literal>
+                </from>
+                <to>$additionInput.operands</to>
+            </copy>
+            <!-- then assign the value from the previous result -->
+            <copy>
+                <from>$result.result</from>
+                <to>$additionInput.operands/dummy:operand[1]</to>
+                <!--<to>$additionInput.operands//dummy:operandList/dummy:operand[1]</to>-->
+            </copy>
+        </assign>
+        <invoke partnerLink="salutPartnerLink" portType="dummy:SalutLaTerrePortType"
+                operation="addition" inputVariable="additionInput" outputVariable="additionOutput"/>
+
+
+        <assign>
+            <!-- First, build the proper element -->
+            <copy>
+                <from>
+                    <literal>
+                        <dummy:myList>
+                            <dummy:operand>0</dummy:operand>
+                            <dummy:operand></dummy:operand>
+                        </dummy:myList>
+                    </literal>
+                </from>
+                <to>$sumOfIntegersInput.range</to>
+            </copy>
+            <!-- then assign the value from the previous result -->
+            <copy>
+                <from>$additionOutput.result</from>
+                <to>$sumOfIntegersInput.range/dummy:operand[2]</to>
+                <!--<to>$additionInput.operands//dummy:operandList/dummy:operand[1]</to>-->
+            </copy>
+        </assign>
+        <invoke partnerLink="salutPartnerLink" portType="dummy:SalutLaTerrePortType"
+                operation="sumOfIntegers" inputVariable="sumOfIntegersInput" outputVariable="sumOfIntegersOutput"/>
+
+
+        <assign>
+            <copy>
+                <from>$sumOfIntegersOutput.result/dummy:resultIs</from>
+                <to>$outputVar.TestPart</to>
+            </copy>
+        </assign>
+        <reply name="end" partnerLink="helloPartnerLink" portType="test:HelloPortType"
+               operation="hello" variable="outputVar"/>
+    </sequence>
+
+</process>

Added: ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.wsdl?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.wsdl (added)
+++ ode/trunk/axis2-war/src/test/resources/TestHttpBinding/http-binding-test.wsdl Mon May 19 15:57:24 2008
@@ -0,0 +1,77 @@
+<?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.
+  -->
+
+<wsdl:definitions 
+    targetNamespace="http://ode/bpel/unit-test.wsdl"
+    xmlns="http://schemas.xmlsoap.org/wsdl/"
+    xmlns:tns="http://ode/bpel/unit-test.wsdl"
+    xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" 
+    xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+    xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/"
+    xmlns:dummy="http://ode/bpel/arithmetics"
+    xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype">
+
+    <wsdl:import namespace="http://axis2.ode.apache.org"
+                 location="Arithmetics.wsdl"/>
+
+    <wsdl:message name="HelloMessage">
+        <wsdl:part name="TestPart" type="xsd:int"/>
+    </wsdl:message>
+    
+    <wsdl:portType name="HelloPortType">
+        <wsdl:operation name="hello">
+            <wsdl:input message="tns:HelloMessage" name="TestIn"/>
+            <wsdl:output message="tns:HelloMessage" name="TestOut"/>
+        </wsdl:operation>    
+    </wsdl:portType>
+    
+     <wsdl:binding name="HelloSoapBinding" type="tns:HelloPortType">
+        <soap:binding style="rpc" transport="http://schemas.xmlsoap.org/soap/http"/>
+        <wsdl:operation name="hello">
+            <soap:operation soapAction="" style="rpc"/>
+            <wsdl:input>
+                <soap:body
+                    namespace="http://ode/bpel/unit-test.wsdl"
+                    use="literal"/>
+            </wsdl:input>
+            <wsdl:output>
+                <soap:body
+                    namespace="http://ode/bpel/unit-test.wsdl" 
+                    use="literal"/>
+            </wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+    <wsdl:service name="HelloService">
+		<wsdl:port name="HelloPort" binding="tns:HelloSoapBinding">
+     		<soap:address location="http://localhost:8080/ode/processes/helloWorld"/>
+		</wsdl:port>
+    </wsdl:service>
+    
+   <plnk:partnerLinkType name="HelloPartnerLinkType">
+       <plnk:role name="me" portType="tns:HelloPortType"/>
+   </plnk:partnerLinkType>
+    <plnk:partnerLinkType name="SalutLinkType">
+        <plnk:role name="salut" portType="dummy:SalutLaTerrePortType"/>
+    </plnk:partnerLinkType>
+    <plnk:partnerLinkType name="OlaLinkType">
+        <plnk:role name="ola" portType="dummy:OlaElMundoPortType"/>
+    </plnk:partnerLinkType>
+</wsdl:definitions>
+

Added: ode/trunk/axis2-war/src/test/resources/TestHttpBinding/testRequest.soap
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestHttpBinding/testRequest.soap?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestHttpBinding/testRequest.soap (added)
+++ ode/trunk/axis2-war/src/test/resources/TestHttpBinding/testRequest.soap Mon May 19 15:57:24 2008
@@ -0,0 +1,28 @@
+<?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.
+  -->
+
+<SOAP-ENV:Envelope xmlns:SOAP-ENV="http://schemas.xmlsoap.org/soap/envelope/">
+  <!-- test soap message -->
+  <SOAP-ENV:Body>
+    <ns1:hello xmlns:ns1="http://ode/bpel/unit-test.wsdl">
+        <TestPart xmlns="">100</TestPart>
+    </ns1:hello>
+  </SOAP-ENV:Body>
+</SOAP-ENV:Envelope>

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.bpel?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.bpel (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.bpel Mon May 19 15:57:24 2008
@@ -0,0 +1,66 @@
+<?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.
+  -->
+
+<process name="TestRetire"
+         targetNamespace="http://ode/bpel/test/retire"
+         xmlns="http://docs.oasis-open.org/wsbpel/2.0/process/executable"
+         xmlns:tns="http://ode/bpel/responder"
+         xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+         xmlns:resp="http://ode/bpel/test/retire/responder.wsdl">
+
+    <import location="TestRetire.wsdl" namespace="http://ode/bpel/test/retire.wsdl"
+            importType="http://schemas.xmlsoap.org/wsdl/" />
+
+    <partnerLinks>
+        <partnerLink name="testRetirePartnerLink" partnerLinkType="resp:TestRetirePartnerLinkType" myRole="responder"/>
+    </partnerLinks>
+
+    <variables>
+        <variable name="dummy" messageType="resp:TestRetireMessage"/>
+    </variables>
+
+    <correlationSets>
+        <correlationSet name="dummyCorr" properties="resp:dummyProp" />
+    </correlationSets>
+
+    <sequence>
+        <receive name="start" partnerLink="testRetirePartnerLink" variable="dummy" operation="first" createInstance="yes">
+            <correlations>
+                <correlation set="dummyCorr" initiate="yes"/>
+            </correlations>
+        </receive>
+        <reply name="reply-endpoint" partnerLink="testRetirePartnerLink" operation="first" variable="dummy"/>
+
+
+        <receive name="second" partnerLink="testRetirePartnerLink" variable="dummy" operation="second">
+            <correlations>
+                <correlation set="dummyCorr" initiate="no"/>
+            </correlations>
+        </receive>
+        <assign>
+            <copy>
+                <from><literal>DONE</literal></from>
+                <to>$dummy.TestPart</to>
+            </copy>
+        </assign>
+        <reply name="reply-ack" partnerLink="testRetirePartnerLink" operation="second" variable="dummy"/>
+
+    </sequence>
+</process>
\ No newline at end of file

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.wsdl?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.wsdl (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/TestRetire.wsdl Mon May 19 15:57:24 2008
@@ -0,0 +1,74 @@
+<?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.
+  -->
+
+<wsdl:definitions 
+    targetNamespace="http://ode/bpel/test/retire/responder.wsdl"
+    xmlns="http://schemas.xmlsoap.org/wsdl/"
+    xmlns:tns="http://ode/bpel/test/retire/responder.wsdl"
+    xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" 
+    xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+    xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/"
+    xmlns:dummy="http://axis2.ode.apache.org"
+    xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype"
+    xmlns:prop="http://docs.oasis-open.org/wsbpel/2.0/varprop">
+
+    <wsdl:message name="TestRetireMessage">
+        <wsdl:part name="TestPart" type="xsd:string"/>
+    </wsdl:message>
+    
+    <wsdl:portType name="TestRetirePortType">
+        <wsdl:operation name="first">
+            <wsdl:input message="tns:TestRetireMessage" name="TestIn"/>
+            <wsdl:output message="tns:TestRetireMessage" name="TestOut"/>
+        </wsdl:operation>    
+        <wsdl:operation name="second">
+            <wsdl:input message="tns:TestRetireMessage" name="TestIn"/>
+            <wsdl:output message="tns:TestRetireMessage" name="TestOut"/>
+        </wsdl:operation>
+    </wsdl:portType>
+    
+     <wsdl:binding name="TestRetireSoapBinding" type="tns:TestRetirePortType">
+        <soap:binding style="rpc" transport="http://schemas.xmlsoap.org/soap/http"/>
+        <wsdl:operation name="first">
+            <soap:operation soapAction="" style="rpc"/>
+            <wsdl:input><soap:body namespace="http://ode/bpel/test/retire/responder.wsdl" use="literal"/></wsdl:input>
+            <wsdl:output><soap:body namespace="http://ode/bpel/unit-test.wsdl" use="literal"/></wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="second">
+            <soap:operation soapAction="" style="rpc"/>
+            <wsdl:input><soap:body namespace="http://ode/bpel/test/retire/responder.wsdl" use="literal"/></wsdl:input>
+            <wsdl:output><soap:body namespace="http://ode/bpel/unit-test.wsdl" use="literal"/></wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+    <wsdl:service name="TestRetireService">
+		<wsdl:port name="TestRetirePort" binding="tns:TestRetireSoapBinding">
+     		<soap:address location="http://localhost:8080/ode/processes/testretire"/>
+		</wsdl:port>
+    </wsdl:service>
+    
+    <plnk:partnerLinkType name="TestRetirePartnerLinkType">
+        <plnk:role name="responder" portType="tns:TestRetirePortType"/>
+    </plnk:partnerLinkType>
+
+    <prop:property name="dummyProp" type="xsd:string"/>
+    <prop:propertyAlias propertyName="tns:dummyProp" messageType="tns:TestRetireMessage" part="TestPart"/>
+
+</wsdl:definitions>
+

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/deploy.xml
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/deploy.xml?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/deploy.xml (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/deploy.xml Mon May 19 15:57:24 2008
@@ -0,0 +1,29 @@
+<!--
+  ~ 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.
+  -->
+<deploy xmlns="http://www.apache.org/ode/schemas/dd/2007/03"
+	xmlns:pns="http://ode/bpel/test/retire"
+	xmlns:wns="http://ode/bpel/test/retire/responder.wsdl">
+
+	<process name="pns:TestRetire">
+		<active>true</active>
+		<provide partnerLink="testRetirePartnerLink">
+			<service name="wns:TestRetireService" port="TestRetirePort"/>
+		</provide>
+    </process>
+</deploy>

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest1.soap
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest1.soap?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest1.soap (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest1.soap Mon May 19 15:57:24 2008
@@ -0,0 +1,25 @@
+<?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.
+  -->
+
+<SOAP-ENV:Envelope xmlns:SOAP-ENV="http://schemas.xmlsoap.org/soap/envelope/">
+    <SOAP-ENV:Body>
+        <tns:first xmlns:tns="http://ode/bpel/test/retire/responder.wsdl"><TestPart>XYZ</TestPart></tns:first>
+    </SOAP-ENV:Body>
+</SOAP-ENV:Envelope>

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest2.soap
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest2.soap?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest2.soap (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/1/testRequest2.soap Mon May 19 15:57:24 2008
@@ -0,0 +1,25 @@
+<?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.
+  -->
+
+<SOAP-ENV:Envelope xmlns:SOAP-ENV="http://schemas.xmlsoap.org/soap/envelope/">
+    <SOAP-ENV:Body>
+        <tns:second xmlns:tns="http://ode/bpel/test/retire/responder.wsdl"><TestPart>XYZ</TestPart></tns:second>
+    </SOAP-ENV:Body>
+</SOAP-ENV:Envelope>

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.bpel?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.bpel (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.bpel Mon May 19 15:57:24 2008
@@ -0,0 +1,59 @@
+<?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.
+  -->
+
+<process name="TestRetire"
+         targetNamespace="http://ode/bpel/test/retire"
+         xmlns="http://docs.oasis-open.org/wsbpel/2.0/process/executable"
+         xmlns:tns="http://ode/bpel/responder"
+         xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+         xmlns:resp="http://ode/bpel/test/retire/responder.wsdl">
+
+  <import location="TestRetire.wsdl" namespace="http://ode/bpel/test/retire.wsdl"
+     importType="http://schemas.xmlsoap.org/wsdl/" />
+
+  <partnerLinks>
+    <partnerLink name="testRetirePartnerLink" partnerLinkType="resp:TestRetirePartnerLinkType" myRole="responder"/>
+  </partnerLinks>
+
+  <variables>
+    <variable name="dummy" messageType="resp:TestRetireMessage"/>
+  </variables>
+
+  <correlationSets>
+    <correlationSet name="dummyCorr" properties="resp:dummyProp" />
+  </correlationSets>
+
+  <sequence>
+    <receive name="start" partnerLink="testRetirePartnerLink" variable="dummy" operation="first" createInstance="yes">
+      <correlations>
+        <correlation set="dummyCorr" initiate="yes"/>
+      </correlations>
+    </receive>
+    <reply name="reply-endpoint" partnerLink="testRetirePartnerLink" operation="first" variable="dummy"/>
+
+    <receive name="second" partnerLink="testRetirePartnerLink" variable="dummy" operation="second">
+      <correlations>
+        <correlation set="dummyCorr" initiate="no"/>
+      </correlations>
+    </receive>
+    <reply name="reply-ack" partnerLink="testRetirePartnerLink" operation="second" variable="dummy"/>
+
+  </sequence>
+</process>
\ No newline at end of file

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.wsdl?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.wsdl (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/TestRetire.wsdl Mon May 19 15:57:24 2008
@@ -0,0 +1,74 @@
+<?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.
+  -->
+
+<wsdl:definitions 
+    targetNamespace="http://ode/bpel/test/retire/responder.wsdl"
+    xmlns="http://schemas.xmlsoap.org/wsdl/"
+    xmlns:tns="http://ode/bpel/test/retire/responder.wsdl"
+    xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" 
+    xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+    xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/"
+    xmlns:dummy="http://axis2.ode.apache.org"
+    xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype"
+    xmlns:prop="http://docs.oasis-open.org/wsbpel/2.0/varprop">
+
+    <wsdl:message name="TestRetireMessage">
+        <wsdl:part name="TestPart" type="xsd:string"/>
+    </wsdl:message>
+    
+    <wsdl:portType name="TestRetirePortType">
+        <wsdl:operation name="first">
+            <wsdl:input message="tns:TestRetireMessage" name="TestIn"/>
+            <wsdl:output message="tns:TestRetireMessage" name="TestOut"/>
+        </wsdl:operation>    
+        <wsdl:operation name="second">
+            <wsdl:input message="tns:TestRetireMessage" name="TestIn"/>
+            <wsdl:output message="tns:TestRetireMessage" name="TestOut"/>
+        </wsdl:operation>
+    </wsdl:portType>
+    
+     <wsdl:binding name="TestRetireSoapBinding" type="tns:TestRetirePortType">
+        <soap:binding style="rpc" transport="http://schemas.xmlsoap.org/soap/http"/>
+        <wsdl:operation name="first">
+            <soap:operation soapAction="" style="rpc"/>
+            <wsdl:input><soap:body namespace="http://ode/bpel/test/retire/responder.wsdl" use="literal"/></wsdl:input>
+            <wsdl:output><soap:body namespace="http://ode/bpel/unit-test.wsdl" use="literal"/></wsdl:output>
+        </wsdl:operation>
+        <wsdl:operation name="second">
+            <soap:operation soapAction="" style="rpc"/>
+            <wsdl:input><soap:body namespace="http://ode/bpel/test/retire/responder.wsdl" use="literal"/></wsdl:input>
+            <wsdl:output><soap:body namespace="http://ode/bpel/unit-test.wsdl" use="literal"/></wsdl:output>
+        </wsdl:operation>
+    </wsdl:binding>
+    <wsdl:service name="TestRetireService">
+		<wsdl:port name="TestRetirePort" binding="tns:TestRetireSoapBinding">
+     		<soap:address location="http://localhost:8080/ode/processes/testretire"/>
+		</wsdl:port>
+    </wsdl:service>
+    
+    <plnk:partnerLinkType name="TestRetirePartnerLinkType">
+        <plnk:role name="responder" portType="tns:TestRetirePortType"/>
+    </plnk:partnerLinkType>
+
+    <prop:property name="dummyProp" type="xsd:string"/>
+    <prop:propertyAlias propertyName="tns:dummyProp" messageType="tns:TestRetireMessage" part="TestPart"/>
+
+</wsdl:definitions>
+

Added: ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/deploy.xml
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/deploy.xml?rev=658024&view=auto
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/deploy.xml (added)
+++ ode/trunk/axis2-war/src/test/resources/TestInstanceRetire/2/deploy.xml Mon May 19 15:57:24 2008
@@ -0,0 +1,29 @@
+<!--
+  ~ 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.
+  -->
+<deploy xmlns="http://www.apache.org/ode/schemas/dd/2007/03"
+	xmlns:pns="http://ode/bpel/test/retire"
+	xmlns:wns="http://ode/bpel/test/retire/responder.wsdl">
+
+	<process name="pns:TestRetire">
+		<active>true</active>
+		<provide partnerLink="testRetirePartnerLink">
+			<service name="wns:TestRetireService" port="TestRetirePort"/>
+		</provide>
+    </process>
+</deploy>

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java?rev=658024&r1=658023&r2=658024&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java Mon May 19 15:57:24 2008
@@ -78,7 +78,7 @@
             throw new ContextException("Cannot find definition for service " + initialPartnerEndpoint.serviceName
                                        + " in the context of process "+processId);
         }
-        return _server.createExternalService(wsdl, initialPartnerEndpoint.serviceName, initialPartnerEndpoint.portName);
+        return _server.createExternalService(wsdl, initialPartnerEndpoint.serviceName, initialPartnerEndpoint.portName, pconf);
     }
 
 }