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 2007/04/03 17:47:02 UTC

svn commit: r525181 - in /incubator/ode/trunk: bpel-compiler/src/test/java/org/apache/ode/bpel/compiler/ bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/ bpel-test/src/test/java/org/apache/ode/test/ bpel-test/src/test/resources/bpel/2.0/TestCorr...

Author: mriou
Date: Tue Apr  3 08:47:00 2007
New Revision: 525181

URL: http://svn.apache.org/viewvc?view=rev&rev=525181
Log:
More test fixes.

Removed:
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestCorrelationAsync/
Modified:
    incubator/ode/trunk/bpel-compiler/src/test/java/org/apache/ode/bpel/compiler/WSDLRegistryTest.java
    incubator/ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/ActivityRecoveryTest.java
    incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/BPELTestAbstract.java
    incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/MessageRouting20Test.java
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestCorrelationOpaque/TestCorrelationOpaque.bpel
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.bpel
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.wsdl
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test1.properties
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test3.properties
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/TestStaticOnMessage.bpel
    incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/test5.properties
    incubator/ode/trunk/dao-hibernate/src/test/java/org/apache/ode/daohib/bpel/ListProcessTest.java

Modified: incubator/ode/trunk/bpel-compiler/src/test/java/org/apache/ode/bpel/compiler/WSDLRegistryTest.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-compiler/src/test/java/org/apache/ode/bpel/compiler/WSDLRegistryTest.java?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-compiler/src/test/java/org/apache/ode/bpel/compiler/WSDLRegistryTest.java (original)
+++ incubator/ode/trunk/bpel-compiler/src/test/java/org/apache/ode/bpel/compiler/WSDLRegistryTest.java Tue Apr  3 08:47:00 2007
@@ -18,17 +18,14 @@
  */
 package org.apache.ode.bpel.compiler;
 
-import org.apache.ode.bpel.compiler.wsdl.Definition4BPEL;
+import junit.framework.TestCase;
 import org.apache.ode.bpel.compiler.wsdl.WSDLFactory4BPEL;
 import org.apache.ode.bpel.compiler.wsdl.WSDLFactoryBPEL11;
 import org.apache.ode.utils.xsd.SchemaModel;
 
-import java.net.URL;
-
 import javax.wsdl.xml.WSDLReader;
 import javax.xml.namespace.QName;
-
-import junit.framework.TestCase;
+import java.net.URL;
 
 public class WSDLRegistryTest extends TestCase {
 

Modified: incubator/ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/ActivityRecoveryTest.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/ActivityRecoveryTest.java?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/ActivityRecoveryTest.java (original)
+++ incubator/ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/ActivityRecoveryTest.java Tue Apr  3 08:47:00 2007
@@ -18,29 +18,15 @@
  */
 package org.apache.ode.bpel.runtime;
 
-import java.io.File;
-import java.net.URI;
-import java.util.ArrayList;
-
-import javax.xml.namespace.QName;
-
-import org.jmock.*;
-import org.jmock.core.*;
-import org.jmock.core.matcher.StatelessInvocationMatcher;
-import org.jmock.core.stub.CustomStub;
-import org.jmock.core.stub.StubSequence;
-
 import org.apache.ode.bpel.engine.BpelManagementFacadeImpl;
-import org.apache.ode.bpel.iapi.ContextException;
 import org.apache.ode.bpel.iapi.Message;
 import org.apache.ode.bpel.iapi.MessageExchange;
 import org.apache.ode.bpel.iapi.MessageExchangeContext;
-import org.apache.ode.bpel.iapi.MyRoleMessageExchange;
 import org.apache.ode.bpel.iapi.PartnerRoleMessageExchange;
+import org.apache.ode.bpel.o.OFailureHandling;
 import org.apache.ode.bpel.pmapi.BpelManagementFacade;
 import org.apache.ode.bpel.pmapi.TActivityInfo;
 import org.apache.ode.bpel.pmapi.TActivityStatus;
-import org.apache.ode.bpel.pmapi.TFaultInfo;
 import org.apache.ode.bpel.pmapi.TFailureInfo;
 import org.apache.ode.bpel.pmapi.TFailuresInfo;
 import org.apache.ode.bpel.pmapi.TInstanceInfo;
@@ -49,8 +35,20 @@
 import org.apache.ode.bpel.pmapi.TInstanceSummary;
 import org.apache.ode.bpel.pmapi.TScopeInfo;
 import org.apache.ode.bpel.pmapi.TScopeRef;
-import org.apache.ode.bpel.o.OFailureHandling;
 import org.apache.ode.utils.DOMUtils;
+import org.jmock.Mock;
+import org.jmock.MockObjectTestCase;
+import org.jmock.core.Invocation;
+import org.jmock.core.InvocationMatcher;
+import org.jmock.core.Stub;
+import org.jmock.core.matcher.StatelessInvocationMatcher;
+import org.jmock.core.stub.CustomStub;
+import org.jmock.core.stub.StubSequence;
+
+import javax.xml.namespace.QName;
+import java.io.File;
+import java.net.URI;
+import java.util.ArrayList;
 
 /**
  * Test activity recovery and failure handling.

Modified: incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/BPELTestAbstract.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/BPELTestAbstract.java?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/BPELTestAbstract.java (original)
+++ incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/BPELTestAbstract.java Tue Apr  3 08:47:00 2007
@@ -40,6 +40,7 @@
 import javax.persistence.Persistence;
 import javax.xml.namespace.QName;
 import java.io.File;
+import java.util.ArrayList;
 import java.util.Collection;
 import java.util.Properties;
 import java.util.concurrent.Future;
@@ -56,8 +57,11 @@
     protected TestScheduler scheduler;
     protected BpelDAOConnectionFactory _cf;
 
+    protected ArrayList<Failure> failures;
+
     @Override
     protected void setUp() throws Exception {
+        failures = new ArrayList<Failure>();
         server = new BpelServerImpl();
         mexContext = new MessageExchangeContextImpl();
 
@@ -114,6 +118,7 @@
         if ( em != null ) em.close();
         if ( emf != null ) emf.close();
         server.stop();
+        failures = null;
     }
 
     protected void negative(String deployDir) throws Throwable {
@@ -164,72 +169,125 @@
             testProps.load(testPropsFile.toURL().openStream());
             String responsePattern = testProps.getProperty("response1");
             bpelE.printStackTrace();
-            testResponsePattern(bpelE.getMessage(), responsePattern);
+            testResponsePattern("init", bpelE.getMessage(), responsePattern);
             return;
         } catch ( Exception e ) {
             e.printStackTrace();
             fail();
         }
         scheduler.commit();
+        
+        ArrayList<Thread> testThreads = new ArrayList<Thread>();
 
         while (testPropsFile.exists()) {
 
-            Properties testProps = new Properties();
+            final Properties testProps = new Properties();
             testProps.load(testPropsFile.toURL().openStream());
-
-            QName serviceId = new QName(testProps.getProperty("namespace"),
+            final QName serviceId = new QName(testProps.getProperty("namespace"),
                     testProps.getProperty("service"));
-            String operation = testProps.getProperty("operation");
+            final String operation = testProps.getProperty("operation");
 
+            // Running tests in separate threads to allow concurrent invocation
+            // (otherwise the first receive/reply invocation is going to block
+            // everybody).
+            Thread testRun = new Thread(new Runnable() {
+                public void run() {
+                    doInvoke(testProps, serviceId, operation);
+                }
+            });
+            
+            testThreads.add(testRun);
+            testRun.start();
 
-            /**
-             * Each property file must contain at least one request/response
-             * property tuple.
-             *
-             * The request/response tuple should be in the form
-             *
-             * requestN=<message>some XML input message</message>
-             * responseN=.*some response message.*
-             *
-             * Where N is a monotonic integer beginning with 1.
-             *
-             * If a specific MEP is expected in lieu of a response message use:
-             * responseN=ASYNC responseN=ONE_WAY responseN=COMPLETED_OK
-             *
-             */
-            for (int i = 1; testProps.getProperty("request" + i) != null; i++) {
-                MyRoleMessageExchange mex = null;
-                Future running = null;
-                String responsePattern = null;
-                try {
-                    scheduler.begin();
-
-                    mex = server.getEngine().createMessageExchange(new GUID().toString(), serviceId, operation);
+            Thread.sleep(200);
+            propsFileCnt++;
+            testPropsFile = new File(deployDir + "/test" + propsFileCnt
+                    + ".properties");
+        }
 
-                    String in = testProps.getProperty("request" + i);
-                    responsePattern = testProps.getProperty("response" + i);
+        // Waiting for all the test threads to finish.
+        for (Thread testThread : testThreads) {
+            testThread.join();
+        }
 
-                    mexContext.clearCurrentResponse();
+        // Displaying result
+        for (Failure failure : failures) {
+            System.out.println("A test failure occured in message exchange request " + failure.requestName);
+            System.out.println("=> Expected Response Pattern >> " + failure.expected);
+            System.out.println("=> Actual Response >> " + failure.actual);            
+        }
+        assertTrue(failures.size() == 0);
+    }
 
-                    Message request = mex.createMessage(null);
+    private void testResponsePattern(String requestName, Message response, String responsePattern) {
+        String resp = (response == null) ? "null" : DOMUtils
+                .domToString(response.getMessage());
+        testResponsePattern(requestName, resp, responsePattern);
+    }
 
-                    Element elem = DOMUtils.stringToDOM(in);
-                    request.setMessage(elem);
+    private void testResponsePattern(String requestName, String resp, String responsePattern) {
+        boolean testValue = Pattern.compile(responsePattern, Pattern.DOTALL)
+                .matcher(resp).matches();
+        if (!testValue) {
+            failures.add(new Failure(requestName, resp, responsePattern));
+        }
+    }
 
+    /**
+     * Each property file must contain at least one request/response
+     * property tuple.
+     *
+     * The request/response tuple should be in the form
+     *
+     * requestN=<message>some XML input message</message>
+     * responseN=.*some response message.*
+     *
+     * Where N is a monotonic integer beginning with 1.
+     *
+     * If a specific MEP is expected in lieu of a response message use:
+     * responseN=ASYNC responseN=ONE_WAY responseN=COMPLETED_OK
+     *
+     */
+    private void doInvoke(Properties testProps, QName serviceId, String operation) {
+        for (int i = 1; testProps.getProperty("request" + i) != null; i++) {
+            MyRoleMessageExchange mex = null;
+            Future running = null;
+            String responsePattern = null;
+            try {
+                scheduler.begin();
+
+                mex = server.getEngine().createMessageExchange(new GUID().toString(), serviceId, operation);
+
+                String in = testProps.getProperty("request" + i);
+                responsePattern = testProps.getProperty("response" + i);
+
+                mexContext.clearCurrentResponse();
+
+                Message request = mex.createMessage(null);
+
+                Element elem = DOMUtils.stringToDOM(in);
+                request.setMessage(elem);
+
+
+                running = mex.invoke(request);
+                scheduler.commit();
+            } catch ( Throwable e ) {
+                e.printStackTrace();
+                scheduler.rollback();
+                fail();
+            }
 
-                    running = mex.invoke(request);
-                    scheduler.commit();
-                } catch ( Throwable e ) {
-                    e.printStackTrace();
-                    scheduler.rollback();
-                    throw e;
+            if (!responsePattern.equals("ASYNC")) {
+                try {
+                    running.get(200000, TimeUnit.MILLISECONDS);
+                } catch (Exception e) {
+                    System.out.println("TIMEOUT!");
+                    fail();
                 }
 
-                running.get(200000, TimeUnit.MILLISECONDS);
-
                 switch (mex.getStatus()) {
                     case RESPONSE:
-                        testResponsePattern(mex.getResponse(), responsePattern);
+                        testResponsePattern("request" + i, mex.getResponse(), responsePattern);
                         // TODO: test for response fault
                         break;
                     case ASYNC:
@@ -240,7 +298,7 @@
                                     fail();
                                 break;
                             case REQUEST_RESPONSE:
-                                testResponsePattern(mexContext.getCurrentResponse(),
+                                testResponsePattern("request" + i, mexContext.getCurrentResponse(),
                                         responsePattern);
                             default:
                                 break;
@@ -249,12 +307,12 @@
                         break;
                     case COMPLETED_OK:
                         if (!responsePattern.equals("COMPLETED_OK"))
-                            testResponsePattern(mexContext.getCurrentResponse(),
+                            testResponsePattern("request" + i, mexContext.getCurrentResponse(),
                                     responsePattern);
                         break;
                     case FAULT:
                         // TODO: handle Fault
-                        System.out.println("=> " + mex.getFaultExplanation());
+                        System.out.println("=> " + mex.getFault() + " " + mex.getFaultExplanation());
                         fail();
                         break;
                     case COMPLETED_FAILURE:
@@ -277,28 +335,19 @@
                         break;
                 }
             }
-            propsFileCnt++;
-            testPropsFile = new File(deployDir + "/test" + propsFileCnt
-                    + ".properties");
         }
     }
 
-    private void testResponsePattern(Message response, String responsePattern) {
-        String resp = (response == null) ? "null" : DOMUtils
-                .domToString(response.getMessage());
-        testResponsePattern(resp, responsePattern);
-    }
-
-    private void testResponsePattern(String resp, String responsePattern) {
-        boolean testValue = Pattern.compile(responsePattern, Pattern.DOTALL)
-                .matcher(resp).matches();
-
-        if (!testValue) {
-            System.out.println("=> Expected Response Pattern >> "
-                    + responsePattern);
-            System.out.println("=> Acutal Response >> " + resp);
+    protected static class Failure {
+        String requestName;
+        String expected;
+        String actual;
+
+        public Failure(String requestName, String actual, String expected) {
+            this.actual = actual;
+            this.expected = expected;
+            this.requestName = requestName;
         }
-        assertTrue(testValue);
     }
 
 }

Modified: incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/MessageRouting20Test.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/MessageRouting20Test.java?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/MessageRouting20Test.java (original)
+++ incubator/ode/trunk/bpel-test/src/test/java/org/apache/ode/test/MessageRouting20Test.java Tue Apr  3 08:47:00 2007
@@ -1,21 +1,21 @@
-/*
- * 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.
- */
+/*
+ * 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.test;
 
 public class MessageRouting20Test extends BPELTestAbstract {
@@ -26,12 +26,10 @@
 	public void testCorrelation1() throws Throwable {
 		go("target/test-classes/bpel/2.0/TestCorrelation1");
 	}
-	public void testCorrelationOpaque() throws Throwable {
-		go("target/test-classes/bpel/2.0/testCorrelationOpaque");
-	}
-	public void testCorrelationAsync() throws Throwable {
-		go("target/test-classes/bpel/2.0/TestCorrelationAsync");
-	}
+//    TODO Fix me, we need to capture the session id to send it in the second test message
+//	public void testCorrelationOpaque() throws Throwable {
+//		go("target/test-classes/bpel/2.0/TestCorrelationOpaque");
+//	}
     public void testDynamicPick() throws Throwable {
     	go("target/test-classes/bpel/2.0/TestDynamicPick");
     }

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestCorrelationOpaque/TestCorrelationOpaque.bpel
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestCorrelationOpaque/TestCorrelationOpaque.bpel?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestCorrelationOpaque/TestCorrelationOpaque.bpel (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestCorrelationOpaque/TestCorrelationOpaque.bpel Tue Apr  3 08:47:00 2007
@@ -1,33 +1,33 @@
-<!--
-  ~ 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.
--->
-
+<!--
+  ~ 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.
+-->
+
 <bpel:process xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
   xsi:schemaLocation="http://schemas.xmlsoap.org/ws/2004/03/business-process/ ../../../../../../../bpel-schemas/src/main/resources/wsbpel_main-draft-Apr-29-2006.xsd"
   xmlns:tns="http://ode/bpel/unit-test/testCorrelationOpaque" targetNamespace="http://ode/bpel/unit-test/testCorrelationOpaque" xmlns:wns="http://ode/bpel/unit-test/testCorrelationOpaque.wsdl"
   xmlns:ns0="http://www.w3schools.com" xmlns:bpel="http://schemas.xmlsoap.org/ws/2004/03/business-process/" name="TestCorrelationOpaque" queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
   expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0" suppressJoinFailure="yes">
 
-  <bpel:import location="testCorrelationOpaque.wsdl" namespace="http://ode/bpel/unit-test/testCorrelationOpaque.wsdl" importType="http://schemas.xmlsoap.org/wsdl/"/>
+  <bpel:import location="TestCorrelationOpaque.wsdl" namespace="http://ode/bpel/unit-test/testCorrelationOpaque.wsdl" importType="http://schemas.xmlsoap.org/wsdl/"/>
 
   <bpel:partnerLinks>
     <bpel:partnerLink name="testCorrelationOpaquePL1" partnerLinkType="wns:testCorrelationOpaqueRequest1" myRole="testCorrelationOpaqueService1"/>
-    <bpel:partnerLink name="testCorrelationOpaquePL2" partnerLinkType="wns:testCorrelationOpaqueRequest2" myRole="testCorrelationOpaqueService2"/>
+    <bpel:partnerLink name="testCorrelationOpaquePL2" partnerLinkType="wns:testCorrelationOpaqueRequest2" myRole="testCorrelationOpaqueService2"/>
   </bpel:partnerLinks>
   <bpel:variables>
     <bpel:variable messageType="wns:operation1Request" name="input1"/>

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.bpel
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.bpel?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.bpel (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.bpel Tue Apr  3 08:47:00 2007
@@ -1,138 +1,138 @@
-<!--
-  ~ 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 xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
- xsi:schemaLocation="http://schemas.xmlsoap.org/ws/2004/03/business-process/ ../../../../../../../bpel-schemas/src/main/resources/wsbpel_main-draft-Apr-29-2006.xsd"
-	targetNamespace="http://ode/bpel/unit-test/TestDynamicPick"
-	xmlns:tns="http://ode/bpel/unit-test/TestDynamicPick"
-	xmlns:wns="http://ode/bpel/unit-test/TestDynamicPick.wsdl"
-	xmlns:prb="http://ode/bpel/unit-test/ProbeService.wsdl"
-	xmlns="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
-	name="TestDynamicPick"
-	queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
-	expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
-	suppressJoinFailure="yes">
-	
-	<!-- test pick with blocking dynamic key -->
-	
-	<import location="TestDynamicPick.wsdl"
-		namespace="http://ode/bpel/unit-test/TestDynamicPick.wsdl"
-		importType="http://schemas.xmlsoap.org/wsdl/" />
-	<import location="../ProbeService/probeService.wsdl"
-		namespace="http://ode/bpel/unit-test/ProbeService.wsdl"
-		importType="http://schemas.xmlsoap.org/wsdl/"/>
-	
-	
-	<partnerLinks>
-		<partnerLink name="request" partnerLinkType="wns:TestDynamicPickRequest" myRole="TestDynamicPickService"/>
-		<partnerLink name="probe" partnerLinkType="wns:probeRequest" partnerRole="probeService"  initializePartnerRole="yes"/>
-	</partnerLinks>
-	<variables>
-		<variable name="request" messageType="wns:requestMessage"/>
-		<variable name="probeInput" messageType="prb:probeMessage"/>
-		<variable name="reply" messageType="wns:replyMessage"/>
-	</variables>
-	<correlationSets>
-		<correlationSet name="testCorr1" properties="wns:testProbeID wns:testProbeKey1"/>
-		<correlationSet name="testCorr2" properties="wns:testProbeID wns:testProbeKey2"/>
-	</correlationSets>
-	<sequence>
-		<receive name="receive1" partnerLink="request" portType="wns:TestDynamicPickPT" operation="request" variable="request" createInstance="yes">
-			<correlations>
-				<correlation set="testCorr1" initiate="yes"/>
-				<correlation set="testCorr2" initiate="yes"/>
-			</correlations>
-		</receive>
-		<assign name="assign1">
-			<copy>
-				<from variable="request" property="wns:testProbeID"/>
-				<to variable="probeInput" part="probeName"/>
-			</copy>
-			<copy>
-				<from variable="request" property="wns:testProbeData"/>
-				<to variable="probeInput" part="probeData"/>
-			</copy>
-		</assign>
-		<assign>
-			<copy>
-				<from>
-					<literal><![CDATA[loop on pick until message includes requestEnd = yes]]></literal>
-				</from>
-				<to variable="probeInput" part="probeName"/>
-			</copy>
-		</assign>
-		<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
-		<while>
-			<condition>$request.requestMessageData/requestEnd = 'no'</condition>
-			<pick name="testPick">
-				<onMessage partnerLink="request" portType="wns:TestDynamicPickPT" operation="continue1" variable="request">
-					<correlations>
-						<correlation set="testCorr1"/>
-					</correlations>
-					<sequence>
-						<assign>
-							<copy>
-								<from>
-									<literal><![CDATA[pick branch one invoked]]></literal>
-								</from>
-								<to variable="probeInput" part="probeName"/>
-							</copy>
-						</assign>
-						<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
-					</sequence>
-				</onMessage>
-				<onMessage partnerLink="request" portType="wns:TestDynamicPickPT" operation="continue2" variable="request">
-					<correlations>
-						<correlation set="testCorr2"/>
-					</correlations>
-					<sequence>
-						<assign>
-							<copy>
-								<from>
-									<literal><![CDATA[pick branch two invoked]]></literal>
-								</from>
-								<to variable="probeInput" part="probeName"/>
-							</copy>
-						</assign>
-						<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
-					</sequence>
-				</onMessage>
-			</pick>
-		</while>
-		<assign>
-			<copy>
-				<from>
-					<literal><![CDATA[process complete]]></literal>
-				</from>
-				<to variable="probeInput" part="probeName"/>
-			</copy>
-		</assign>
-		<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
-		<assign name="assign2">
-			<copy>
-				<from variable="probeInput" part="probeName"/>
-				<to variable="reply" part="replyID"/>
-			</copy>
-			<copy>
-				<from variable="probeInput" part="probeData"/>
-				<to variable="reply" part="replyText"/>
-			</copy>
-		</assign>
-		<reply name="reply" partnerLink="request" portType="wns:TestDynamicPickPT" operation="request" variable="reply"> </reply>
-	</sequence>
+<!--
+  ~ 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 xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+ xsi:schemaLocation="http://schemas.xmlsoap.org/ws/2004/03/business-process/ ../../../../../../../bpel-schemas/src/main/resources/wsbpel_main-draft-Apr-29-2006.xsd"
+	targetNamespace="http://ode/bpel/unit-test/TestDynamicPick"
+	xmlns:tns="http://ode/bpel/unit-test/TestDynamicPick"
+	xmlns:wns="http://ode/bpel/unit-test/TestDynamicPick.wsdl"
+	xmlns:prb="http://ode/bpel/unit-test/ProbeService.wsdl"
+	xmlns="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
+	name="TestDynamicPick"
+	queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
+	expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
+	suppressJoinFailure="yes">
+	
+	<!-- test pick with blocking dynamic key -->
+	
+	<import location="TestDynamicPick.wsdl"
+		namespace="http://ode/bpel/unit-test/TestDynamicPick.wsdl"
+		importType="http://schemas.xmlsoap.org/wsdl/" />
+	<import location="../ProbeService/probeService.wsdl"
+		namespace="http://ode/bpel/unit-test/ProbeService.wsdl"
+		importType="http://schemas.xmlsoap.org/wsdl/"/>
+	
+	
+	<partnerLinks>
+		<partnerLink name="request" partnerLinkType="wns:TestDynamicPickRequest" myRole="TestDynamicPickService"/>
+		<partnerLink name="probe" partnerLinkType="wns:probeRequest" partnerRole="probeService"  initializePartnerRole="yes"/>
+	</partnerLinks>
+	<variables>
+		<variable name="request" messageType="wns:requestMessage"/>
+		<variable name="probeInput" messageType="prb:probeMessage"/>
+		<variable name="reply" messageType="wns:replyMessage"/>
+	</variables>
+	<correlationSets>
+		<correlationSet name="testCorr1" properties="wns:testProbeID wns:testProbeKey1"/>
+		<correlationSet name="testCorr2" properties="wns:testProbeID wns:testProbeKey2"/>
+	</correlationSets>
+	<sequence>
+		<receive name="receive1" partnerLink="request" portType="wns:TestDynamicPickPT" operation="request" variable="request" createInstance="yes">
+			<correlations>
+				<correlation set="testCorr1" initiate="yes"/>
+				<correlation set="testCorr2" initiate="yes"/>
+			</correlations>
+		</receive>
+		<assign name="assign1">
+			<copy>
+				<from variable="request" property="wns:testProbeID"/>
+				<to variable="probeInput" part="probeName"/>
+			</copy>
+			<copy>
+				<from variable="request" property="wns:testProbeData"/>
+				<to variable="probeInput" part="probeData"/>
+			</copy>
+		</assign>
+		<assign>
+			<copy>
+				<from>
+					<literal><![CDATA[loop on pick until message includes requestEnd = yes]]></literal>
+				</from>
+				<to variable="probeInput" part="probeName"/>
+			</copy>
+		</assign>
+		<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
+		<while>
+			<condition>$request.requestMessageData/requestEnd = 'no'</condition>
+			<pick name="testPick">
+				<onMessage partnerLink="request" portType="wns:TestDynamicPickPT" operation="continue1" variable="request">
+					<correlations>
+						<correlation set="testCorr1"/>
+					</correlations>
+					<sequence>
+						<assign>
+							<copy>
+								<from>
+									<literal><![CDATA[pick branch one invoked]]></literal>
+								</from>
+								<to variable="probeInput" part="probeName"/>
+							</copy>
+						</assign>
+						<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
+					</sequence>
+				</onMessage>
+				<onMessage partnerLink="request" portType="wns:TestDynamicPickPT" operation="continue2" variable="request">
+					<correlations>
+						<correlation set="testCorr2"/>
+					</correlations>
+					<sequence>
+						<assign>
+							<copy>
+								<from>
+									<literal><![CDATA[pick branch two invoked]]></literal>
+								</from>
+								<to variable="probeInput" part="probeName"/>
+							</copy>
+						</assign>
+						<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
+					</sequence>
+				</onMessage>
+			</pick>
+		</while>
+		<assign>
+			<copy>
+				<from>
+					<literal><![CDATA[process complete]]></literal>
+				</from>
+				<to variable="probeInput" part="probeName"/>
+			</copy>
+		</assign>
+		<invoke name="probe" partnerLink="probe" portType="prb:probeMessagePT" operation="probe" inputVariable="probeInput" outputVariable="probeInput"> </invoke>
+		<assign name="assign2">
+			<copy>
+				<from variable="probeInput" part="probeName"/>
+				<to variable="reply" part="replyID"/>
+			</copy>
+			<copy>
+				<from variable="probeInput" part="probeData"/>
+				<to variable="reply" part="replyText"/>
+			</copy>
+		</assign>
+		<reply name="reply" partnerLink="request" portType="wns:TestDynamicPickPT" operation="request" variable="reply"> </reply>
+	</sequence>
 </process>

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.wsdl
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.wsdl?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.wsdl (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/TestDynamicPick.wsdl Tue Apr  3 08:47:00 2007
@@ -92,31 +92,31 @@
    </plnk:partnerLinkType>
    
   <bpws:property name="testProbeKey1" type="xsd:string"/>
-  <bpws:propertyAlias propertyName="tns:testProbeKey1" messageType="tns:requestMessage" part="requestMessageData">
+  <bpws:propertyAlias propertyName="tns:testProbeKey1" messageType="tns:requestMessage" part="requestMessageData">
     <bpws:query queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
       testMessage/requestKey1
-    </bpws:query>   
+    </bpws:query>   
   </bpws:propertyAlias>
   
   <bpws:property name="testProbeKey2" type="xsd:string"/>
-  <bpws:propertyAlias propertyName="tns:testProbeKey2" messageType="tns:requestMessage" part="requestMessageData">
+  <bpws:propertyAlias propertyName="tns:testProbeKey2" messageType="tns:requestMessage" part="requestMessageData">
     <bpws:query queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
       testMessage/requestKey2
-    </bpws:query>    
+    </bpws:query>    
   </bpws:propertyAlias>
   
   <bpws:property name="testProbeID" type="xsd:string"/>
-  <bpws:propertyAlias propertyName="tns:testProbeID" messageType="tns:requestMessage" part="requestMessageData">
+  <bpws:propertyAlias propertyName="tns:testProbeID" messageType="tns:requestMessage" part="requestMessageData">
     <bpws:query queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
       testMessage/requestID
-    </bpws:query> 
+    </bpws:query> 
   </bpws:propertyAlias>
   
   <bpws:property name="testProbeData" type="xsd:string"/>
-  <bpws:propertyAlias propertyName="tns:testProbeData" messageType="tns:requestMessage" part="requestMessageData">
+  <bpws:propertyAlias propertyName="tns:testProbeData" messageType="tns:requestMessage" part="requestMessageData">
     <bpws:query queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
       testMessage/requestText
-    </bpws:query> 
+    </bpws:query> 
   </bpws:propertyAlias>
   
 

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test1.properties
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test1.properties?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test1.properties (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test1.properties Tue Apr  3 08:47:00 2007
@@ -2,4 +2,4 @@
 service=TestDynamicPickService
 operation=request
 request1=<message><requestMessageData><testMessage><requestID>Start Test Dynamic Pick</requestID><requestKey1>Test Dynamic Pick Key 1</requestKey1><requestKey2>Test Dynamic Pick Key 2</requestKey2><requestText>Event Test Dynamic Pick Start</requestText><requestEnd>no</requestEnd></testMessage></requestMessageData></message>
-response1=null
+response1=.*Event Test Dynamic Pick Start -&gt; loop on pick until message includes requestEnd = yes -&gt; pick branch one invoked -&gt; pick branch two invoked -&gt; process complete.*

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test3.properties
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test3.properties?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test3.properties (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestDynamicPick/test3.properties Tue Apr  3 08:47:00 2007
@@ -2,4 +2,4 @@
 service=TestDynamicPickService
 operation=continue2
 request1=<message><requestMessageData><testMessage><requestID>Start Test Dynamic Pick</requestID><requestKey1>Test Dynamic Pick Key 1</requestKey1><requestKey2>Test Dynamic Pick Key 2</requestKey2><requestText>Event Test Dynamic Pick Continue2</requestText><requestEnd>yes</requestEnd></testMessage></requestMessageData></message>
-response1=.*Event Test Dynamic Pick Start -&gt; loop on pick until message includes requestEnd = yes -&gt; pick branch one invoked -&gt; pick branch two invoked -&gt; process complete.*
+response1=ASYNC

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/TestStaticOnMessage.bpel
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/TestStaticOnMessage.bpel?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/TestStaticOnMessage.bpel (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/TestStaticOnMessage.bpel Tue Apr  3 08:47:00 2007
@@ -1,237 +1,234 @@
-<!--
-	~ 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 xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
- xsi:schemaLocation="http://schemas.xmlsoap.org/ws/2004/03/business-process/ ../../../../../../../bpel-schemas/src/main/resources/wsbpel_main-draft-Apr-29-2006.xsd"
-	xmlns:tns="http://ode/bpel/unit-test/TestStaticOnMessage"
-	xmlns:wns="http://ode/bpel/unit-test/TestStaticOnMessage.wsdl"
-	xmlns:prb="http://ode/bpel/unit-test/ProbeService.wsdl"
-	xmlns="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
- name="TestStaticOnMessageProcess"
-	targetNamespace="http://ode/bpel/unit-test/TestStaticOnMessage"
-	queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
-	expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
- suppressJoinFailure="yes">
-
-<!-- test onMessage with static correlation key -->
-
-	<import location="TestStaticOnMessage.wsdl"
-		namespace="http://ode/bpel/unit-test/TestStaticOnMessage.wsdl"
-		importType="http://schemas.xmlsoap.org/wsdl/" />
-	<import location="../ProbeService/probeService.wsdl"
-		namespace="http://ode/bpel/unit-test/ProbeService.wsdl"
-		importType="http://schemas.xmlsoap.org/wsdl/"/>
-	
-
-  <partnerLinks>
-  	<partnerLink name="request1" partnerLinkType="wns:TestStaticOnMessage1Request" myRole="TestStaticOnMessage1Service"/>
-  	<partnerLink name="probe" partnerLinkType="wns:probeRequest" partnerRole="probeService" initializePartnerRole="yes"/>
-  </partnerLinks>
-
-  <variables>
-    <variable name="request" 
-               messageType="wns:requestMessage"/>
-    <variable name="probeInput" 
-               messageType="prb:probeMessage"/>
-    <variable name="reply" 
-               messageType="wns:replyMessage"/>
-  </variables>
-
-  <correlationSets>
-	<correlationSet name="testCorr1" properties="wns:testProbeID"/>
-  </correlationSets>
-
-  <sequence>
-  	
-  	<receive name="receive1" partnerLink="request1"
-  		portType="wns:TestStaticOnMessage1PT" 
-  		operation="request" variable="request"
-  		createInstance="yes">
-  		<correlations>
-  			<correlation set="testCorr1" initiate="yes"/>
-  		</correlations>
-  	</receive>
-  	
-  <scope name="scopeOne">
-  	<eventHandlers>
-
-  		<onEvent partnerLink="request1" 
-  			    messageType="wns:requestMessage"
-				portType="wns:TestStaticOnMessage1PT" 
-				operation="event1" 
-				variable="request">
-
-  			<correlations>
-  				<correlation set="testCorr1"/>
-  			</correlations>
-
-			<scope>
-				<sequence>
-	  	  			<assign>
-	      				<copy>
-	      					<from>
-	      						<literal><![CDATA[received event on TestStaticOnMessage3PT]]></literal>
-	      					</from>
-	        				<to variable="probeInput" part="probeName"/>
-	      				</copy>
-	  				</assign> 
-
-       				<invoke name="probe" partnerLink="probe"
-	            			portType="prb:probeMessagePT" 
-	            			operation="probe"
-	            			inputVariable="probeInput"  
-	            			outputVariable="probeInput">
-       				</invoke>
-				</sequence>
-			  </scope>
-			</onEvent>
-			<onEvent partnerLink="request1" messageType="wns:requestMessage"
-				portType="wns:TestStaticOnMessage1PT" operation="event2" variable="request">
-
-				<correlations>
-					<correlation set="testCorr1"/>
-				</correlations>
-
-			  <scope>
-				<sequence>
-	  	  			<assign>
-	      				<copy>
-	      					<from>
-	      						<literal><![CDATA[received event on TestStaticOnMessage4PT]]></literal>
-	      					</from>
-	        				<to variable="probeInput" part="probeName"/>
-	      				</copy>
-	  				</assign> 
-
-       				<invoke name="probe" partnerLink="probe"
-	            			portType="prb:probeMessagePT" 
-	            			operation="probe"
-	            			inputVariable="probeInput"  
-	            			outputVariable="probeInput">
-       				</invoke>
-				</sequence>
-			   </scope>
-			</onEvent>
-
-
-  	</eventHandlers>
-
-  <sequence>
-	    
-
-	
-		<!-- Copy input variables to internal accumulators -->
-	 
-	    <assign name="assign1">
-	      <copy>
-	        <from variable="request" property="wns:testProbeID"/>
-	        <to variable="probeInput" part="probeName"/>
-	      </copy>
-	      <copy>
-	        <from variable="request" property="wns:testProbeData"/>
-	        <to variable="probeInput" part="probeData"/>
-	      </copy>
-	    </assign>   
-	
-
-	  <assign>
-	  		<copy>
-	  			<from>
-	  				<literal><![CDATA[block for next message]]></literal>
-	  			</from>
-	   				<to variable="probeInput" part="probeName"/>
-	  		</copy>
-	  </assign> 
-
-       <invoke name="probe" partnerLink="probe"
-	            portType="prb:probeMessagePT" 
-	            operation="probe"
-	            inputVariable="probeInput"  
-	            outputVariable="probeInput">
-       </invoke>
-       
-  	<!-- block the process here while test messages are sent to the eventHandlers -->
-       
-	    <receive name="receive2" partnerLink="request1"
-	             portType="wns:TestStaticOnMessage1PT" 
-	             operation="continue1" variable="request">
-		<correlations>
-			<correlation set="testCorr1"/>
-		</correlations>
-	    </receive>
-
-	   </sequence>
-	</scope>
-
-	  <assign>
-	  		<copy>
-	  			<from>
-	  				<literal><![CDATA[block for final message]]></literal>
-	  			</from>
-   				<to variable="probeInput" part="probeName"/>
-	  		</copy>
-	  </assign> 
-
-       <invoke name="probe" partnerLink="probe"
-	            portType="prb:probeMessagePT" 
-	            operation="probe"
-	            inputVariable="probeInput"  
-	            outputVariable="probeInput">
-       </invoke>
-
-	    <receive name="receive3" partnerLink="request1"
-	             portType="wns:TestStaticOnMessage1PT" 
-	             operation="continue2" variable="request">
-		<correlations>
-			<correlation set="testCorr1"/>
-		</correlations>
-	    </receive>
-
-	  	<assign>
-	     	<copy>
-	     		<from>
-	     			<literal><![CDATA[process complete]]></literal>
-	     		</from>
-	      		<to variable="probeInput" part="probeName"/>
-	    	</copy>
-	  	</assign> 
-
-       <invoke name="probe" partnerLink="probe"
-	            portType="prb:probeMessagePT" 
-	            operation="probe"
-	            inputVariable="probeInput"  
-	            outputVariable="probeInput">
-       </invoke>
-	  <assign name="assign2">
-	      <copy>
-	        <from variable="probeInput" part="probeName"/>
-	        <to variable="reply" part="replyID"/>
-	      </copy>
-	      <copy>
-	        <from variable="probeInput" part="probeData"/>
-	        <to variable="reply" part="replyText"/>
-	      </copy>
-	  </assign> 
-	    
-	  <reply name="reply" partnerLink="request1" portType="wns:TestStaticOnMessage1PT" 
-	           operation="continue2" variable="reply"> 
-	  </reply>
-  
-  </sequence>
+<!--
+	~ 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 xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://schemas.xmlsoap.org/ws/2004/03/business-process/ ../../../../../../../bpel-schemas/src/main/resources/wsbpel_main-draft-Apr-29-2006.xsd"
+         xmlns:tns="http://ode/bpel/unit-test/TestStaticOnMessage"
+         xmlns:wns="http://ode/bpel/unit-test/TestStaticOnMessage.wsdl"
+         xmlns:prb="http://ode/bpel/unit-test/ProbeService.wsdl"
+         xmlns="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
+         name="TestStaticOnMessageProcess"
+         targetNamespace="http://ode/bpel/unit-test/TestStaticOnMessage"
+         queryLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
+         expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0"
+         suppressJoinFailure="yes">
+
+    <!-- test onMessage with static correlation key -->
+
+    <import location="TestStaticOnMessage.wsdl"
+            namespace="http://ode/bpel/unit-test/TestStaticOnMessage.wsdl"
+            importType="http://schemas.xmlsoap.org/wsdl/" />
+    <import location="../ProbeService/probeService.wsdl"
+            namespace="http://ode/bpel/unit-test/ProbeService.wsdl"
+            importType="http://schemas.xmlsoap.org/wsdl/"/>
+
+
+    <partnerLinks>
+        <partnerLink name="request1" partnerLinkType="wns:TestStaticOnMessage1Request" myRole="TestStaticOnMessage1Service"/>
+        <partnerLink name="probe" partnerLinkType="wns:probeRequest" partnerRole="probeService" initializePartnerRole="yes"/>
+    </partnerLinks>
+
+    <variables>
+        <variable name="request"
+                  messageType="wns:requestMessage"/>
+        <variable name="probeInput"
+                  messageType="prb:probeMessage"/>
+        <variable name="reply"
+                  messageType="wns:replyMessage"/>
+    </variables>
+
+    <correlationSets>
+        <correlationSet name="testCorr1" properties="wns:testProbeID"/>
+    </correlationSets>
+
+    <sequence>
+
+        <receive name="receive1" partnerLink="request1"
+                 portType="wns:TestStaticOnMessage1PT"
+                 operation="request" variable="request"
+                 createInstance="yes">
+            <correlations>
+                <correlation set="testCorr1" initiate="yes"/>
+            </correlations>
+        </receive>
+
+        <scope name="scopeOne">
+            <eventHandlers>
+
+                <onEvent partnerLink="request1"  messageType="wns:requestMessage"
+                         portType="wns:TestStaticOnMessage1PT" operation="event1" variable="request">
+
+                    <correlations>
+                        <correlation set="testCorr1"/>
+                    </correlations>
+
+                    <scope>
+                        <sequence>
+                            <assign>
+                                <copy>
+                                    <from>
+                                        <literal><![CDATA[received event on TestStaticOnMessage3PT]]></literal>
+                                    </from>
+                                    <to variable="probeInput" part="probeName"/>
+                                </copy>
+                            </assign>
+
+                            <invoke name="probe" partnerLink="probe"
+                                    portType="prb:probeMessagePT"
+                                    operation="probe"
+                                    inputVariable="probeInput"
+                                    outputVariable="probeInput">
+                            </invoke>
+                        </sequence>
+                    </scope>
+                </onEvent>
+                <onEvent partnerLink="request1" messageType="wns:requestMessage"
+                         portType="wns:TestStaticOnMessage1PT" operation="event2" variable="request">
+
+                    <correlations>
+                        <correlation set="testCorr1"/>
+                    </correlations>
+
+                    <scope>
+                        <sequence>
+                            <assign>
+                                <copy>
+                                    <from>
+                                        <literal><![CDATA[received event on TestStaticOnMessage4PT]]></literal>
+                                    </from>
+                                    <to variable="probeInput" part="probeName"/>
+                                </copy>
+                            </assign>
+
+                            <invoke name="probe" partnerLink="probe"
+                                    portType="prb:probeMessagePT"
+                                    operation="probe"
+                                    inputVariable="probeInput"
+                                    outputVariable="probeInput">
+                            </invoke>
+                        </sequence>
+                    </scope>
+                </onEvent>
+
+
+            </eventHandlers>
+
+            <sequence>
+
+
+
+                <!-- Copy input variables to internal accumulators -->
+
+                <assign name="assign1">
+                    <copy>
+                        <from variable="request" property="wns:testProbeID"/>
+                        <to variable="probeInput" part="probeName"/>
+                    </copy>
+                    <copy>
+                        <from variable="request" property="wns:testProbeData"/>
+                        <to variable="probeInput" part="probeData"/>
+                    </copy>
+                </assign>
+
+
+                <assign>
+                    <copy>
+                        <from>
+                            <literal><![CDATA[block for next message]]></literal>
+                        </from>
+                        <to variable="probeInput" part="probeName"/>
+                    </copy>
+                </assign>
+
+                <invoke name="probe" partnerLink="probe"
+                        portType="prb:probeMessagePT"
+                        operation="probe"
+                        inputVariable="probeInput"
+                        outputVariable="probeInput">
+                </invoke>
+
+                <!-- block the process here while test messages are sent to the eventHandlers -->
+
+                <receive name="receive2" partnerLink="request1"
+                         portType="wns:TestStaticOnMessage1PT"
+                         operation="continue1" variable="request">
+                    <correlations>
+                        <correlation set="testCorr1"/>
+                    </correlations>
+                </receive>
+
+            </sequence>
+        </scope>
+
+        <assign>
+            <copy>
+                <from>
+                    <literal><![CDATA[block for final message]]></literal>
+                </from>
+                <to variable="probeInput" part="probeName"/>
+            </copy>
+        </assign>
+
+        <invoke name="probe" partnerLink="probe"
+                portType="prb:probeMessagePT"
+                operation="probe"
+                inputVariable="probeInput"
+                outputVariable="probeInput">
+        </invoke>
+
+        <receive name="receive3" partnerLink="request1"
+                 portType="wns:TestStaticOnMessage1PT"
+                 operation="continue2" variable="request">
+            <correlations>
+                <correlation set="testCorr1"/>
+            </correlations>
+        </receive>
+
+        <assign>
+            <copy>
+                <from>
+                    <literal><![CDATA[process complete]]></literal>
+                </from>
+                <to variable="probeInput" part="probeName"/>
+            </copy>
+        </assign>
+
+        <invoke name="probe" partnerLink="probe"
+                portType="prb:probeMessagePT"
+                operation="probe"
+                inputVariable="probeInput"
+                outputVariable="probeInput">
+        </invoke>
+        <assign name="assign2">
+            <copy>
+                <from variable="probeInput" part="probeName"/>
+                <to variable="reply" part="replyID"/>
+            </copy>
+            <copy>
+                <from variable="probeInput" part="probeData"/>
+                <to variable="reply" part="replyText"/>
+            </copy>
+        </assign>
+
+        <reply name="reply" partnerLink="request1" portType="wns:TestStaticOnMessage1PT"
+               operation="continue2" variable="reply">
+        </reply>
+
+    </sequence>
 </process>

Modified: incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/test5.properties
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/test5.properties?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/test5.properties (original)
+++ incubator/ode/trunk/bpel-test/src/test/resources/bpel/2.0/TestStaticOnMessage/test5.properties Tue Apr  3 08:47:00 2007
@@ -2,4 +2,4 @@
 service=TestStaticOnMessage1Service
 operation=continue2
 request1=<message><requestMessageData><testMessage><requestID>Test Static OnMessage</requestID><requestText>Event Continue PT2</requestText></testMessage></requestMessageData></message>
-response1=.*Event Start Test Static OnMessage -&gt; block for next message -&gt; received event on TestStaticOnMessage3PT -&gt; received event on TestStaticOnMessage4PT -&gt; block for final message -&gt; process complete.*
+response1=.*Event Start Test Static OnMessage -&gt; block for next message -&gt; (received event on TestStaticOnMessage(3|4)PT -&gt; )?(received event on TestStaticOnMessage(3|4)PT -&gt; )?block for final message -&gt; process complete.*

Modified: incubator/ode/trunk/dao-hibernate/src/test/java/org/apache/ode/daohib/bpel/ListProcessTest.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/dao-hibernate/src/test/java/org/apache/ode/daohib/bpel/ListProcessTest.java?view=diff&rev=525181&r1=525180&r2=525181
==============================================================================
--- incubator/ode/trunk/dao-hibernate/src/test/java/org/apache/ode/daohib/bpel/ListProcessTest.java (original)
+++ incubator/ode/trunk/dao-hibernate/src/test/java/org/apache/ode/daohib/bpel/ListProcessTest.java Tue Apr  3 08:47:00 2007
@@ -23,8 +23,6 @@
 import java.util.List;
 import java.util.Map;
 
-import org.apache.ode.bpel.common.ProcessFilter;
-
 /**
  * Testing BpelDAOConnectionImpl.listAllProcesses. We're just producing a lot
  * of different filter combinations and test if they execute ok. To really