You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ode.apache.org by rr...@apache.org on 2009/11/30 13:52:58 UTC

svn commit: r885404 [1/2] - in /ode/branches/APACHE_ODE_1.X: ./ bpel-runtime/src/main/java/org/apache/ode/bpel/engine/ bpel-store/src/main/java/org/apache/ode/store/ jbi/src/main/java/org/apache/ode/jbi/ jbi/src/test/java/org/apache/ode/jbi/ jbi/src/te...

Author: rr
Date: Mon Nov 30 12:52:56 2009
New Revision: 885404

URL: http://svn.apache.org/viewvc?rev=885404&view=rev
Log:
ODE-567: Improve process versioning in JBI

Added:
    ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OnEventAlarmJbiTest.java   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/RetireJbiTest.java   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.bpel   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.wsdl   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelationArtifacts.wsdl   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/deploy.xml   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/smx.xml   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/test.properties   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/smx.xml   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/test.properties   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.bpel   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.wsdl   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelationArtifacts.wsdl   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/deploy.xml   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.bpel   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.wsdl   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelationArtifacts.wsdl   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/deploy.xml   (with props)
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/smx-base.xml   (with props)
Modified:
    ode/branches/APACHE_ODE_1.X/Rakefile
    ode/branches/APACHE_ODE_1.X/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelEngineImpl.java
    ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/DeploymentUnitDir.java
    ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/ProcessStoreImpl.java
    ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java
    ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeService.java
    ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java
    ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java
    ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java
    ode/branches/APACHE_ODE_1.X/jbi/src/test/jbi/ode-jbi.properties
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/CommunicationJbiTest/smx.xml
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/EmptyRespJbiTest/smx.xml
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ExtVarJbiTest/smx.xml
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/HelloWorldJbiTest/smx.xml
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionExternalJbiTest/smx.xml
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionJbiTest/smx.xml
    ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ReplayerJbiTest/smx.xml

Modified: ode/branches/APACHE_ODE_1.X/Rakefile
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/Rakefile?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/Rakefile (original)
+++ ode/branches/APACHE_ODE_1.X/Rakefile Mon Nov 30 12:52:56 2009
@@ -126,6 +126,7 @@
                         "commons-beanutils:commons-beanutils:jar:1.7.0",
                         "tranql:tranql-connector-derby-common:jar:1.1"
                         ]
+SLF4J = group(%w{ slf4j-api slf4j-log4j12 jcl104-over-slf4j }, :under=>"org.slf4j", :version=>"1.4.3")                        
 SPRING              = ["org.springframework:spring:jar:2.5.6"]
 TRANQL              = [ "tranql:tranql-connector:jar:1.1", COMMONS.primitives ]
 WOODSTOX            = "woodstox:wstx-asl:jar:3.2.1"
@@ -529,6 +530,7 @@
       GERONIMO.transaction, JAVAX.connector, JAVAX.ejb, JAVAX.persistence, JAVAX.stream,
       JAVAX.transaction, JAXEN, JBI, OPENJPA, SAXON, SERVICEMIX, SPRING, TRANQL,
       XALAN, XBEAN, XMLBEANS, 
+      SLF4J,
       LOG4J,
       DOM4J,
       HIBERNATE

Modified: ode/branches/APACHE_ODE_1.X/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelEngineImpl.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelEngineImpl.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelEngineImpl.java (original)
+++ ode/branches/APACHE_ODE_1.X/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelEngineImpl.java Mon Nov 30 12:52:56 2009
@@ -313,8 +313,18 @@
                 BpelProcess cachedVersion = processesIter.next();
                 __log.debug("cached version " + cachedVersion.getPID() + " vs registering version " + process.getPID());
                 if (cachedVersion.getProcessType().equals(process.getProcessType())) {
-                    processesIter.remove();
-                    cachedVersion.deactivate();
+                    //Check for versions to retain newer one
+                    if (cachedVersion.getVersion() > process.getVersion()) {
+                	    __log.debug("removing current version");
+                        process.activate(this);
+                        process.deactivate();
+                        return;
+                    } else {
+                	    __log.debug("removing cached older version");
+                        processesIter.remove();
+                		cachedVersion.deactivate();
+                    }
+
                 }
             }
             processes.add(process);

Modified: ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/DeploymentUnitDir.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/DeploymentUnitDir.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/DeploymentUnitDir.java (original)
+++ ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/DeploymentUnitDir.java Mon Nov 30 12:52:56 2009
@@ -139,7 +139,14 @@
         if (bpels.size() == 0)
             throw new IllegalArgumentException("Directory " + _duDirectory.getName() + " does not contain any process!");
         for (File bpel : bpels) {
-            compile(bpel);
+        	String b = bpel.getAbsolutePath();
+        	File cbp = new File(b.substring(0,b.lastIndexOf(".bpel")) + ".cbp"); 
+        	if (!cbp.exists()) {
+        		__log.debug("compiling " + bpel);
+        		compile(bpel);
+        	} else {
+        		__log.debug("skipping compilation of " + bpel + " cbp found: " + cbp);
+        	}
         }
     }
 
@@ -376,6 +383,17 @@
     public long getVersion() {
         return _version;
     }
+    
+    /**
+     * @return Static DU version number generated from DU name. -1 when package doesn't use versioning.
+     */
+    public long getStaticVersion() {
+        try {
+            return Integer.parseInt(getName().substring(getName().lastIndexOf("-") + 1));
+        } catch (Throwable t) {
+            return -1;
+        }
+    }
 
     public void setVersion(long version) {
         _version = version;

Modified: ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/ProcessStoreImpl.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/ProcessStoreImpl.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/ProcessStoreImpl.java (original)
+++ ode/branches/APACHE_ODE_1.X/bpel-store/src/main/java/org/apache/ode/store/ProcessStoreImpl.java Mon Nov 30 12:52:56 2009
@@ -165,14 +165,18 @@
     /**
      * Deploys a process.
      */
+    public Collection<QName> deploy(final File deploymentUnitDirectory, boolean autoincrementVersion) {
+    	return deploy(deploymentUnitDirectory, true, null, autoincrementVersion);
+    }
+
     public Collection<QName> deploy(final File deploymentUnitDirectory) {
-    	return deploy(deploymentUnitDirectory, true, null);
+        return deploy(deploymentUnitDirectory, true, null, true);
     }
 
     /**
      * Deploys a process.
      */
-    public Collection<QName> deploy(final File deploymentUnitDirectory, boolean activate, String duName) {
+    public Collection<QName> deploy(final File deploymentUnitDirectory, boolean activate, String duName, boolean autoincrementVersion) {
         __log.info(__msgs.msgDeployStarting(deploymentUnitDirectory));
 
         final Date deployDate = new Date();
@@ -197,12 +201,18 @@
         Collection<QName> deployed;
 
         _rw.writeLock().lock();
-        // Process and DU use a monotonically increased single version number.
-        long version = exec(new Callable<Long>() {
-            public Long call(ConfStoreConnection conn) {
-                return conn.getNextVersion();
-            }
-        });
+        long version;
+        if (autoincrementVersion || du.getStaticVersion() == -1) {
+            // Process and DU use a monotonically increased single version number by default.
+            version = exec(new Callable<Long>() {
+                public Long call(ConfStoreConnection conn) {
+                    return conn.getNextVersion();
+                }
+            });
+        } else {
+            version = du.getStaticVersion();
+        }
+        du.setVersion(version);
 
         try {
             if (_deploymentUnits.containsKey(du.getName())) {
@@ -216,11 +226,6 @@
             for (TDeployment.Process processDD : dd.getDeploy().getProcessList()) {
                 QName pid = toPid(processDD.getName(), version);
 
-                // Retires older version if we can find one
-                DeploymentUnitDir oldDU = findOldDU(du.getName());
-                if (oldDU != null)
-                    setRetiredPackage(oldDU.getName(), true);
-
                 if (_processes.containsKey(pid)) {
                     String errmsg = __msgs.msgDeployFailDuplicatePID(processDD.getName(), du.getName());
                     __log.error(errmsg);
@@ -297,6 +302,16 @@
 
         });
 
+        try {
+            _rw.writeLock().lock();
+	        for (TDeployment.Process processDD : dd.getDeploy().getProcessList()) {
+	            // Retires older version if we can find one
+	            retireOldDUs(du.getName(), (int) version);
+	        }
+	    } finally {
+	        _rw.writeLock().unlock();
+	    }
+        
         // We want the events to be fired outside of the bounds of the writelock.
         try {
             for (ProcessConfImpl process : processes) {
@@ -822,21 +837,34 @@
         return new QName(processType.getNamespaceURI(), processType.getLocalPart() + "-" + version);
     }
 
-    private DeploymentUnitDir findOldDU(String newName) {
-        DeploymentUnitDir old = null;
+    private void retireOldDUs(String newName, int version) {
         int dashIdx = newName.lastIndexOf("-");
+        String radical;
         if (dashIdx > 0 && dashIdx + 1 < newName.length()) {
-            String radical = newName.substring(0, dashIdx);
-            int newVersion = -1;
-            try {
-                newVersion = Integer.parseInt(newName.substring(newName.lastIndexOf("-") + 1));
-            } catch (NumberFormatException e) {
-                // Swallowing, if we can't parse then we just can't find an old version
-            }
-            while (old == null && newVersion >= 0)
-                old = _deploymentUnits.get(radical + "-" + (newVersion--));
+            radical = newName.substring(0, dashIdx);
+        } else {
+        	radical = newName;
+        }
+
+        SortedSet<Integer> versions = new TreeSet<Integer>();
+        for (String name : _deploymentUnits.keySet()) {
+        	if (name.startsWith(radical + "-")) {
+        		try {
+        			int v = Integer.parseInt(name.substring(radical.length() + 1));
+        			versions.add(v);
+        		} catch (NumberFormatException e) {
+        		}
+        	}
+        }
+        
+        if (versions.size() > 1) {
+	        SortedSet<Integer> retireVersions = versions.headSet(versions.last());
+	        for (Integer version2 : retireVersions) {
+	        	String name = radical + "-" + version2;
+	        	__log.debug("Set retired package " + name);
+	        	setRetiredPackage(name, true);
+	        }
         }
-        return old;
     }
 
     private class SimpleThreadFactory implements ThreadFactory {

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java Mon Nov 30 12:52:56 2009
@@ -174,12 +174,15 @@
         return (TransactionManager) getContext().getTransactionManager();
     }
 
-    public MyEndpointReference activateEndpoint(QName pid, Endpoint endpoint) throws Exception {
+    public synchronized MyEndpointReference activateEndpoint(QName pid, Endpoint endpoint) throws Exception {
         if (__log.isDebugEnabled()) {
             __log.debug("Activate endpoint: " + endpoint);
         }
 
-        OdeService service = new OdeService(this, endpoint);
+        
+        OdeService service=_activeOdeServices.get(endpoint);
+        if(service == null)
+        	service = new OdeService(this, endpoint);
         try {
             ProcessConf pc = _store.getProcessConfiguration(pid);
             InputStream is = pc.getCBPInputStream();
@@ -223,12 +226,15 @@
 
     }
 
-    public void deactivateEndpoint(Endpoint endpoint) throws Exception {
-        OdeService svc = _activeOdeServices.remove(endpoint);
+    public synchronized void  deactivateEndpoint(Endpoint endpoint) throws Exception {
+        OdeService svc = _activeOdeServices.get(endpoint);
 
         if (svc != null) {
             _serviceEprMap.remove(svc);
-            svc.deactivate();
+            svc.deactivate();        
+            if(svc.getCount() < 1 ) {
+        	_activeOdeServices.remove(endpoint);
+            }
         }
     }
 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeService.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeService.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeService.java (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeService.java Mon Nov 30 12:52:56 2009
@@ -63,18 +63,26 @@
     private Element _serviceref;
 
     private Endpoint _endpoint;
+    
+    private int count;
 
     public OdeService(OdeContext odeContext, Endpoint endpoint) throws Exception {
         _ode = odeContext;
         _endpoint = endpoint;
     }
 
+    public int getCount() {
+    	return count;
+    }
     /**
      * Do the JBI endpoint activation.
      * 
      * @throws JBIException
      */
     public void activate() throws JBIException {
+    	count++;
+    	if(count != 1)
+    		return;
         if (_serviceref == null) {
             ServiceEndpoint[] candidates = _ode.getContext().getExternalEndpointsForService(_endpoint.serviceName);
             if (candidates.length != 0) {
@@ -92,6 +100,9 @@
      * Deactivate endpoints in JBI.
      */
     public void deactivate() throws JBIException {
+    	count--;
+    	if(count != 0) 
+    		return;
         _ode.getContext().deactivateEndpoint(_internal);
         __log.debug("Dectivated endpoint " + _endpoint);
     }

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java Mon Nov 30 12:52:56 2009
@@ -64,16 +64,20 @@
     }
 
     public void deploy() throws DeploymentException {
-    	ClassLoader cl = Thread.currentThread().getContextClassLoader();
-    	try {
-    		Thread.currentThread().setContextClassLoader(getConfigurationClassLoader());
-            _ode._store.deploy(_serviceUnitRootPath);
+        ClassLoader cl = Thread.currentThread().getContextClassLoader();
+        try {
+            Thread.currentThread().setContextClassLoader(getConfigurationClassLoader());
+            // JBI ServiceUnits don't use autoincrement version, 
+            // because in ServiceMix redeploying component yields to redeploying dependent
+            // ServiceUnits, and we don't want to create new processes versions 
+            // on such redeployments 
+            _ode._store.deploy(_serviceUnitRootPath, false);
         } catch (Exception ex) {
             String errmsg = __msgs.msgOdeProcessDeploymentFailed(_serviceUnitRootPath, _serviceUnitID);
             __log.error(errmsg, ex);
             throw new DeploymentException(errmsg, ex);
         } finally {
-        	Thread.currentThread().setContextClassLoader(cl);
+            Thread.currentThread().setContextClassLoader(cl);
         }
     }
 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java Mon Nov 30 12:52:56 2009
@@ -25,11 +25,15 @@
 import java.io.PrintWriter;
 import java.net.URL;
 import java.net.URLConnection;
+import java.sql.Connection;
+import java.sql.Statement;
 import java.util.Properties;
 import java.util.regex.Pattern;
 
 import javax.jbi.messaging.ExchangeStatus;
 import javax.jbi.messaging.InOut;
+import javax.sql.DataSource;
+import javax.transaction.TransactionManager;
 import javax.xml.namespace.QName;
 import javax.xml.transform.stream.StreamSource;
 
@@ -55,16 +59,32 @@
     protected JBIContainer jbiContainer;
     
     protected Properties testProperties;
+    protected DefaultServiceMixClient smxClient;
     
     @Override
     protected AbstractXmlApplicationContext createBeanFactory() {
-        return new ClassPathXmlApplicationContext("/" + getTestName() + "/smx.xml");
+        return new ClassPathXmlApplicationContext(new String[] {
+            "/smx-base.xml",
+            "/" + getTestName() + "/smx.xml"
+        });
+    }
+    
+    private void initOdeDb() throws Exception {
+        TransactionManager tm = (TransactionManager) getBean("transactionManager");
+        tm.begin();
+        Connection conn = ((DataSource) getBean("odeDS")).getConnection();
+        Statement s = conn.createStatement();
+        s.execute("delete from bpel_process");
+        s.close();
+        tm.commit();
     }
     
     @Override
     protected void setUp() throws Exception {
         super.setUp();
 
+        initOdeDb();
+        
         jbiContainer = ((JBIContainer) getBean("jbi"));
         odeComponent = new OdeComponent();
 
@@ -76,6 +96,8 @@
         
         testProperties = new Properties();
         testProperties.load(getClass().getResourceAsStream("/" + getTestName() + "/test.properties"));
+        
+        smxClient = new DefaultServiceMixClient(jbiContainer);
     }
     
     protected String getTestName() {
@@ -102,26 +124,49 @@
 
 
     protected void go() throws Exception {
-        enableProcess(getTestName(), true);
+        boolean manualDeploy = Boolean.parseBoolean("" + testProperties.getProperty("manualDeploy"));
+        if (!manualDeploy) 
+            enableProcess(getTestName(), true);
 
         int i = 0;
-        while (true) {
+        boolean loop;
+        do {
             String prefix = i == 0 ? "" : "" + i;
+            loop = i == 0;
+
+            {
+                String deploy = testProperties.getProperty(prefix + "deploy");
+                if (deploy != null) {
+                    loop = true;
+                    enableProcess(getTestName() + "/" + deploy, true);
+                }
+            }
+            {
+                String undeploy = testProperties.getProperty(prefix + "undeploy");
+                if (undeploy != null) {
+                    loop = true;
+                    enableProcess(getTestName() + "/" + undeploy, false);
+                }
+            }
             
             String request = testProperties.getProperty(prefix + "request");
-            if (request == null) {
-                if (i == 0) {
-                    i++;
-                    continue;
-                } else break;
-            }
-            if (request.startsWith("@")) {
+            if (request != null && request.startsWith("@")) {
                 request = inputStreamToString(getClass().getResourceAsStream("/" + getTestName() + "/" + request.substring(1)));
             }
             String expectedResponse = testProperties.getProperty(prefix + "response");
             {
+                String delay = testProperties.getProperty(prefix + "delay");
+                if (delay != null) {
+                    loop = true;
+                    long d = Long.parseLong(delay);
+                    log.debug("Sleeping " + d + " ms");
+                    Thread.sleep(d);
+                }
+            }
+            {
     	        String httpUrl = testProperties.getProperty(prefix + "http.url");
-    	        if (httpUrl != null) {
+    	        if (httpUrl != null && request != null) {
+                    loop = true;
     	            log.debug(getTestName() + " sending http request to " + httpUrl + " request: " + request);
     	            URLConnection connection = new URL(httpUrl).openConnection();
     	            connection.setDoOutput(true);
@@ -140,25 +185,26 @@
     	        }
             }
             {
-    	        if (testProperties.getProperty(prefix + "nmr.service") != null) {
-    	            DefaultServiceMixClient client = new DefaultServiceMixClient(jbiContainer);
-    	            InOut io = client.createInOutExchange();
+    	        if (testProperties.getProperty(prefix + "nmr.service") != null && request != null) {
+                    loop = true;
+    	            InOut io = smxClient.createInOutExchange();
     	            io.setService(QName.valueOf(testProperties.getProperty(prefix + "nmr.service")));
     	            io.setOperation(QName.valueOf(testProperties.getProperty(prefix + "nmr.operation")));
     	            io.getInMessage().setContent(new StreamSource(new ByteArrayInputStream(request.getBytes())));
-    	            client.sendSync(io,20000);
+    	            smxClient.sendSync(io,20000);
     	            assertEquals(ExchangeStatus.ACTIVE,io.getStatus());
     	            assertNotNull(io.getOutMessage());
     	            String result = new SourceTransformer().contentToString(io.getOutMessage());
     	            matchResponse(expectedResponse, result);
-    	            client.done(io);
+    	            smxClient.done(io);
     	        }
             }
             
             i++;
-        }
+        } while (loop);
         
-        enableProcess(getTestName(), false);
+        if (!manualDeploy)
+            enableProcess(getTestName(), false);
     }
     
     protected void matchResponse(String expectedResponse, String result) {

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java Mon Nov 30 12:52:56 2009
@@ -25,6 +25,7 @@
 import org.apache.servicemix.jbi.container.JBIContainer;
 import org.apache.servicemix.jbi.framework.ComponentContextImpl;
 import org.apache.servicemix.jbi.framework.ComponentNameSpace;
+import org.junit.Ignore;
 
 import javax.jbi.messaging.ExchangeStatus;
 import javax.jbi.messaging.InOut;
@@ -33,6 +34,7 @@
 import javax.xml.transform.stream.StreamSource;
 import java.io.File;
 
+@Ignore
 public class OdeJbiComponentLifeCycleTest extends TestCase {
 
     JBIContainer container;

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OnEventAlarmJbiTest.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OnEventAlarmJbiTest.java?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OnEventAlarmJbiTest.java (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OnEventAlarmJbiTest.java Mon Nov 30 12:52:56 2009
@@ -0,0 +1,25 @@
+/*
+ * 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.jbi;
+
+public class OnEventAlarmJbiTest extends JbiTestBase {
+    public void testOnEventAlarm() throws Exception {
+        go();
+    }
+}

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/OnEventAlarmJbiTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/RetireJbiTest.java
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/RetireJbiTest.java?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/RetireJbiTest.java (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/RetireJbiTest.java Mon Nov 30 12:52:56 2009
@@ -0,0 +1,7 @@
+package org.apache.ode.jbi;
+
+public class RetireJbiTest extends JbiTestBase {
+    public void testRetire() throws Exception {
+        go();
+    }
+}

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/java/org/apache/ode/jbi/RetireJbiTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/jbi/ode-jbi.properties
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/jbi/ode-jbi.properties?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/jbi/ode-jbi.properties (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/jbi/ode-jbi.properties Mon Nov 30 12:52:56 2009
@@ -42,7 +42,7 @@
 #                  be set.
 #   * "INTERNAL" - ODE will create its own connection pool for a user-
 #                  specified JDBC URL and driver.
-ode-jbi.db.mode=EMBEDDED
+ode-jbi.db.mode=EXTERNAL
 
 # External Database [JNDI Name]
 # JNDI Name of the DataSource for the ODE database. This is only
@@ -62,7 +62,7 @@
 
 # DAO Connection Factory class.
 # uncomment the following for hibernate.
-#ode-jbi.dao.factory=org.apache.ode.daohib.bpel.BpelDAOConnectionFactoryImpl
+ode-jbi.dao.factory=org.apache.ode.daohib.bpel.BpelDAOConnectionFactoryImpl
 
 # Class name of the message mapper that should be used to convert message
 # between ODE / NMS.

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/CommunicationJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/CommunicationJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/CommunicationJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/CommunicationJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -28,60 +28,9 @@
        xmlns:bpel="http://sample.bpel.org/bpel/sample"
        >
 
-    <bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-  <jencks:connectionTracker id="connectionTracker" geronimoTransactionManager="#transactionManager" />
-    
-  <jencks:workManager
-            id="workManager"
-            threadPoolSize="200"
-            transactionManager="#transactionManager" />
-  
-  <jencks:bootstrapContext
-            id="bootstrapContext"
-            workManager="#workManager"
-            transactionManager="#transactionManager" />
-  
-  <jencks:poolingSupport 
-            id="poolingSupport" 
-            connectionMaxIdleMinutes="5"
-            poolMaxSize="20"
-            />
-  
-  <jencks:connectionManager
-            id="connectionManager"
-            containerManagedSecurity="false"
-            transaction="xa"
-            transactionManager="#transactionManager"
-            poolingSupport="#poolingSupport"
-            connectionTracker="#connectionTracker" 
-            />
-
-    <bean id="localDerbyMCF" class="org.tranql.connector.derby.EmbeddedXAMCF">
-        <property name="databaseName" value="target/test/testdb"/>
-        <property name="createDatabase" value="true"/>
-        <property name="userName" value = "sa"/>
-        <property name="password" value = ""/>
-    </bean>
-    <bean id="localDerbyDataSource" class="org.springframework.jca.support.LocalConnectionFactoryBean">
-        <property name="managedConnectionFactory" ref="localDerbyMCF"/>
-        <property name="connectionManager" ref="connectionManager"/>
-    </bean>
-    
-    <bean id="jndi"
-          class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-          factory-method="makeInitialContext"
-          singleton="true"
-          depends-on="bootstrapContext"
-          >
-      <property name="entries" ref="jndiEntries" />
-    </bean>
-
     <util:map id="jndiEntries">
-        <entry key="testds" value-ref="localDerbyDataSource"/>
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
     </util:map>
-    
-
 
     <sm:container 
         id="jbi" 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/EmptyRespJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/EmptyRespJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/EmptyRespJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/EmptyRespJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -25,18 +25,9 @@
        xmlns:util="http://www.springframework.org/schema/util"
        >
 
-    <bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-    <bean id="jndi"
-          class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-          factory-method="makeInitialContext"
-          singleton="true"
-          >
-      <property name="entries" ref="jndiEntries" />
-    </bean>
-
     <util:map id="jndiEntries">
-    </util:map>
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
+	</util:map>
     
     <sm:container 
         id="jbi" 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ExtVarJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ExtVarJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ExtVarJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ExtVarJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -23,58 +23,34 @@
        xmlns:util="http://www.springframework.org/schema/util"
        xmlns:jencks="http://jencks.org/2.0"
 	   >
-
-	<bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-  <jencks:connectionTracker id="connectionTracker" geronimoTransactionManager="#transactionManager" />
-    
-  <jencks:workManager
-            id="workManager"
-            threadPoolSize="200"
-            transactionManager="#transactionManager" />
-  
-  <jencks:bootstrapContext
-            id="bootstrapContext"
-            workManager="#workManager"
-            transactionManager="#transactionManager" />
-  
   <jencks:poolingSupport 
-            id="poolingSupport" 
+            id="poolingSupport2" 
             connectionMaxIdleMinutes="5"
             poolMaxSize="20"
             />
   
   <jencks:connectionManager
-            id="connectionManager"
+            id="connectionManager2"
             containerManagedSecurity="false"
-            transaction="xa"
+            transaction="local"
             transactionManager="#transactionManager"
-            poolingSupport="#poolingSupport"
+            poolingSupport="#poolingSupport2"
             connectionTracker="#connectionTracker" 
             />
-
-    <bean id="localDerbyMCF" class="org.tranql.connector.derby.EmbeddedXAMCF">
+    <bean id="localDerbyMCF" class="org.tranql.connector.derby.EmbeddedLocalMCF">
 	    <property name="databaseName" value="target/test/testdb"/>
 	    <property name="createDatabase" value="true"/>
 		<property name="userName" value = "sa"/>
         <property name="password" value = ""/>
 	</bean>
-	<bean id="localDerbyDataSource" class="org.springframework.jca.support.LocalConnectionFactoryBean">
+	<bean id="localDerbyDataSource" class="org.jencks.factory.ConnectionFactoryFactoryBean">
 	    <property name="managedConnectionFactory" ref="localDerbyMCF"/>
-	    <property name="connectionManager" ref="connectionManager"/>
+	    <property name="connectionManager" ref="connectionManager2"/>
 	</bean>
 	
-	<bean id="jndi"
-	      class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-	      factory-method="makeInitialContext"
-	      singleton="true"
-	      depends-on="bootstrapContext"
-	      >
-	  <property name="entries" ref="jndiEntries" />
-	</bean>
-
     <util:map id="jndiEntries">
-	    <entry key="testds" value-ref="localDerbyDataSource"/>
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
+        <entry key="testds" value-ref="localDerbyDataSource"/>
 	</util:map>
 	
 	<sm:container 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/HelloWorldJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/HelloWorldJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/HelloWorldJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/HelloWorldJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -24,17 +24,8 @@
        xmlns:util="http://www.springframework.org/schema/util"
        >
 
-    <bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-    <bean id="jndi"
-          class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-          factory-method="makeInitialContext"
-          singleton="true"
-          >
-      <property name="entries" ref="jndiEntries" />
-    </bean>
-
     <util:map id="jndiEntries">
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
     </util:map>
     
     <sm:container 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionExternalJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionExternalJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionExternalJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionExternalJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -25,60 +25,9 @@
        xmlns:mws="http://ode/bpel/unit-test.wsdl"
        >
 
-    <bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-  <jencks:connectionTracker id="connectionTracker" geronimoTransactionManager="#transactionManager" />
-    
-  <jencks:workManager
-            id="workManager"
-            threadPoolSize="200"
-            transactionManager="#transactionManager" />
-  
-  <jencks:bootstrapContext
-            id="bootstrapContext"
-            workManager="#workManager"
-            transactionManager="#transactionManager" />
-  
-  <jencks:poolingSupport 
-            id="poolingSupport" 
-            connectionMaxIdleMinutes="5"
-            poolMaxSize="20"
-            />
-  
-  <jencks:connectionManager
-            id="connectionManager"
-            containerManagedSecurity="false"
-            transaction="xa"
-            transactionManager="#transactionManager"
-            poolingSupport="#poolingSupport"
-            connectionTracker="#connectionTracker" 
-            />
-
-    <bean id="localDerbyMCF" class="org.tranql.connector.derby.EmbeddedXAMCF">
-        <property name="databaseName" value="target/test/testdb"/>
-        <property name="createDatabase" value="true"/>
-        <property name="userName" value = "sa"/>
-        <property name="password" value = ""/>
-    </bean>
-    <bean id="localDerbyDataSource" class="org.springframework.jca.support.LocalConnectionFactoryBean">
-        <property name="managedConnectionFactory" ref="localDerbyMCF"/>
-        <property name="connectionManager" ref="connectionManager"/>
-    </bean>
-    
-    <bean id="jndi"
-          class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-          factory-method="makeInitialContext"
-          singleton="true"
-          depends-on="bootstrapContext"
-          >
-      <property name="entries" ref="jndiEntries" />
-    </bean>
-
     <util:map id="jndiEntries">
-        <entry key="testds" value-ref="localDerbyDataSource"/>
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
     </util:map>
-    
-
 
     <sm:container 
         id="jbi" 

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/MagicSessionJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -24,58 +24,9 @@
        xmlns:jencks="http://jencks.org/2.0"
 	   >
 
-	<bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-  <jencks:connectionTracker id="connectionTracker" geronimoTransactionManager="#transactionManager" />
-    
-  <jencks:workManager
-            id="workManager"
-            threadPoolSize="200"
-            transactionManager="#transactionManager" />
-  
-  <jencks:bootstrapContext
-            id="bootstrapContext"
-            workManager="#workManager"
-            transactionManager="#transactionManager" />
-  
-  <jencks:poolingSupport 
-            id="poolingSupport" 
-            connectionMaxIdleMinutes="5"
-            poolMaxSize="20"
-            />
-  
-  <jencks:connectionManager
-            id="connectionManager"
-            containerManagedSecurity="false"
-            transaction="xa"
-            transactionManager="#transactionManager"
-            poolingSupport="#poolingSupport"
-            connectionTracker="#connectionTracker" 
-            />
-
-    <bean id="localDerbyMCF" class="org.tranql.connector.derby.EmbeddedXAMCF">
-	    <property name="databaseName" value="target/test/testdb"/>
-	    <property name="createDatabase" value="true"/>
-		<property name="userName" value = "sa"/>
-        <property name="password" value = ""/>
-	</bean>
-	<bean id="localDerbyDataSource" class="org.springframework.jca.support.LocalConnectionFactoryBean">
-	    <property name="managedConnectionFactory" ref="localDerbyMCF"/>
-	    <property name="connectionManager" ref="connectionManager"/>
-	</bean>
-	
-	<bean id="jndi"
-	      class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-	      factory-method="makeInitialContext"
-	      singleton="true"
-	      depends-on="bootstrapContext"
-	      >
-	  <property name="entries" ref="jndiEntries" />
-	</bean>
-
     <util:map id="jndiEntries">
-	    <entry key="testds" value-ref="localDerbyDataSource"/>
-	</util:map>
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
+    </util:map>
 	
 	<sm:container 
 		id="jbi" 

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.bpel
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.bpel?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.bpel (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.bpel Mon Nov 30 12:52:56 2009
@@ -0,0 +1,89 @@
+<?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.
+  -->
+<bpws:process xmlns:bpws="http://docs.oasis-open.org/wsbpel/2.0/process/executable" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:ns="http://sample.bpel.org/bpel/sampleArtifacts" xmlns:tns="http://sample.bpel.org/bpel/sample" exitOnStandardFault="yes" name="OnEventCorrelation" suppressJoinFailure="yes" targetNamespace="http://sample.bpel.org/bpel/sample" expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
+  <bpws:import importType="http://schemas.xmlsoap.org/wsdl/" location="OnEventCorrelation.wsdl" namespace="http://sample.bpel.org/bpel/sample"/>
+  <bpws:import importType="http://schemas.xmlsoap.org/wsdl/" location="OnEventCorrelationArtifacts.wsdl" namespace="http://sample.bpel.org/bpel/sampleArtifacts"/>
+  <bpws:partnerLinks>
+    <bpws:partnerLink myRole="OnEventCorrelationProvider" name="client" partnerLinkType="tns:OnEventCorrelation"/>
+  </bpws:partnerLinks>
+  <bpws:variables>
+    <bpws:variable messageType="tns:OnEventCorrelationMessage" name="input"/>
+    <bpws:variable messageType="tns:OnEventCorrelationMessage" name="output"/>
+  </bpws:variables>
+  <bpws:correlationSets>
+    <bpws:correlationSet name="CorrelationSet" properties="ns:input"/>
+  </bpws:correlationSets>
+  <bpws:sequence name="main">
+    <bpws:scope>
+      <bpws:sequence>
+        <bpws:receive createInstance="yes" operation="initiate" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
+          <bpws:correlations>
+            <bpws:correlation initiate="yes" set="CorrelationSet"/>
+          </bpws:correlations>
+        </bpws:receive>
+        <bpws:assign>
+          <bpws:copy>
+            <bpws:from>'test1'</bpws:from>
+            <bpws:to>$output.payload</bpws:to>
+          </bpws:copy>
+        </bpws:assign>
+        <bpws:reply operation="initiate" partnerLink="client" variable="output"/>
+      </bpws:sequence>
+    </bpws:scope>
+    <bpws:scope>
+      <bpws:eventHandlers>
+        <bpws:onEvent operation="complete" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageType="tns:OnEventCorrelationMessage">
+          <bpws:correlations>
+            <bpws:correlation initiate="no" set="CorrelationSet"/>
+          </bpws:correlations>
+          <bpws:scope>
+            <bpws:sequence>
+              <bpws:assign>
+                <bpws:copy>
+                  <bpws:from>concat('ok2',$output.payload)</bpws:from>
+                  <bpws:to>$output.payload</bpws:to>
+                </bpws:copy>
+              </bpws:assign>
+              <bpws:reply operation="complete" partnerLink="client" variable="output"/>
+            </bpws:sequence>
+          </bpws:scope>
+        </bpws:onEvent>
+        <bpws:onAlarm>
+          <bpws:for>'PT1S'</bpws:for>
+          <bpws:scope>
+            <bpws:sequence>
+              <bpws:assign>
+                <bpws:copy>
+                  <bpws:from>'ok3'</bpws:from>
+                  <bpws:to>$output.payload</bpws:to>
+                </bpws:copy>
+              </bpws:assign>
+            </bpws:sequence>
+          </bpws:scope>
+        </bpws:onAlarm>
+      </bpws:eventHandlers>
+      <bpws:sequence>
+        <bpws:wait>
+          <bpws:for>'PT10000S'</bpws:for>
+        </bpws:wait>
+      </bpws:sequence>
+    </bpws:scope>
+  </bpws:sequence>
+</bpws:process>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.bpel
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.wsdl
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.wsdl?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.wsdl (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.wsdl Mon Nov 30 12:52:56 2009
@@ -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.
+  -->
+<definitions xmlns="http://schemas.xmlsoap.org/wsdl/" xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype" xmlns:tns="http://sample.bpel.org/bpel/sample" xmlns:wsdlsoap="http://schemas.xmlsoap.org/wsdl/soap/" name="OnEventCorrelation" targetNamespace="http://sample.bpel.org/bpel/sample"
+xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+>
+  <message name="OnEventCorrelationMessage">
+    <part type="xsd:string" name="payload"/>
+    <part type="xsd:string" name="payload2"/>
+  </message>
+  <portType name="OnEventCorrelation">
+    <operation name="initiate">
+      <input message="tns:OnEventCorrelationMessage"/>
+      <output message="tns:OnEventCorrelationMessage"/>
+    </operation>
+    <operation name="complete">
+      <input message="tns:OnEventCorrelationMessage"/>
+      <output message="tns:OnEventCorrelationMessage"/>
+    </operation>
+  </portType>
+  <binding name="OnEventCorrelationBinding" type="tns:OnEventCorrelation">
+    <wsdlsoap:binding style="rpc" transport="http://schemas.xmlsoap.org/soap/http"/>
+    <operation name="initiate">
+      <wsdlsoap:operation soapAction="initiate"/>
+      <input>
+        <wsdlsoap:body use="literal"/>
+      </input>
+      <output>
+        <wsdlsoap:body use="literal"/>
+      </output>
+    </operation>
+    <operation name="complete">
+      <wsdlsoap:operation soapAction="complete"/>
+      <input>
+        <wsdlsoap:body use="literal"/>
+      </input>
+      <output>
+        <wsdlsoap:body use="literal"/>
+      </output>
+    </operation>
+  </binding>
+  <service name="OnEventCorrelation">
+    <port binding="tns:OnEventCorrelationBinding" name="OnEventCorrelation">
+      <wsdlsoap:address location="http://localhost:8080/ode/processes/OnEventCorrelation/"/>
+    </port>
+  </service>
+    <plnk:partnerLinkType name="OnEventCorrelation">
+        <plnk:role name="OnEventCorrelationProvider" portType="tns:OnEventCorrelation"/>
+    </plnk:partnerLinkType>
+</definitions>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelation.wsdl
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelationArtifacts.wsdl
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelationArtifacts.wsdl?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelationArtifacts.wsdl (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelationArtifacts.wsdl Mon Nov 30 12:52:56 2009
@@ -0,0 +1,35 @@
+<?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.
+  -->
+<definitions 
+    xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype" 
+    xmlns:tns="http://sample.bpel.org/bpel/sampleArtifacts" 
+    xmlns:vprop="http://docs.oasis-open.org/wsbpel/2.0/varprop" 
+    xmlns:xs="http://www.w3.org/2001/XMLSchema" 
+    xmlns:bpel="http://sample.bpel.org/bpel/sample" 
+    name="OnEventCorrelationArtifacts" 
+    targetNamespace="http://sample.bpel.org/bpel/sampleArtifacts" 
+    xmlns="http://schemas.xmlsoap.org/wsdl/"
+    >
+<vprop:property name="input" type="xs:string"/>
+<vprop:propertyAlias messageType="bpel:OnEventCorrelationMessage" part="payload" propertyName="tns:input">
+<!--vprop:query><![CDATA[bpel:input]]></vprop:query-->
+</vprop:propertyAlias>
+<import location="OnEventCorrelation.wsdl" namespace="http://sample.bpel.org/bpel/sample"/>
+</definitions>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/OnEventCorrelationArtifacts.wsdl
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/deploy.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/deploy.xml?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/deploy.xml (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/deploy.xml Mon Nov 30 12:52:56 2009
@@ -0,0 +1,31 @@
+<?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.
+  -->
+<dd:deploy xmlns:dd="http://www.apache.org/ode/schemas/dd/2007/03"
+    xmlns:bpel="http://sample.bpel.org/bpel/sample"
+    >
+
+    <dd:process
+        name="bpel:OnEventCorrelation" fileName="OnEventCorrelation.bpel">
+        <!--dd:process-events generate="none"/-->
+        <dd:provide partnerLink="client">
+            <dd:service name="bpel:OnEventCorrelation" port="OnEventCorrelation" />
+        </dd:provide>
+    </dd:process>
+</dd:deploy>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/deploy.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/smx.xml?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/smx.xml (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -0,0 +1,60 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+
+-->
+<beans xmlns:sm="http://servicemix.apache.org/config/1.0"
+       xmlns:http="http://servicemix.apache.org/http/1.0"
+       xmlns:eip="http://servicemix.apache.org/eip/1.0"
+       xmlns:util="http://www.springframework.org/schema/util"
+       xmlns:jencks="http://jencks.org/2.0"
+       xmlns:mws="http://ode/bpel/unit-test.wsdl"
+       xmlns:bpel="http://sample.bpel.org/bpel/sample"
+       >
+
+    <util:map id="jndiEntries">
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
+    </util:map>
+
+    <sm:container 
+        id="jbi" 
+        embedded="true" 
+        rootDir="target/test/smx"
+        transactionManager="#transactionManager"
+        depends-on="jndi"
+        >
+        <sm:activationSpecs>
+            <sm:activationSpec id="ms-eip">
+                <sm:component>
+                    <eip:component>
+                        <eip:endpoints>
+			  <eip:content-based-router service="bpel:OnEventCorrelation2Fwd" endpoint="OnEventCorrelation2" forwardOperation="true">
+			    <eip:rules>
+			      <eip:routing-rule>
+				<eip:target>
+				  <eip:exchange-target service="bpel:OnEventCorrelation2"/>
+				</eip:target>
+			      </eip:routing-rule>
+			    </eip:rules>
+			  </eip:content-based-router>
+                        </eip:endpoints>
+                    </eip:component>
+                </sm:component>
+            </sm:activationSpec>
+        </sm:activationSpecs>
+    </sm:container>
+</beans>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/smx.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/test.properties
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/test.properties?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/test.properties (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/test.properties Mon Nov 30 12:52:56 2009
@@ -0,0 +1,26 @@
+#
+#    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.
+#
+
+1nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+1nmr.operation=initiate
+1request=<message><payload>1000</payload><payload2>t</payload2></message>
+1response=.*test1.*
+2delay=2000
+3nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+3nmr.operation=complete
+3request=<message><payload>1000</payload><payload2>t2</payload2></message>
+3response=.*ok2ok3.*

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/OnEventAlarmJbiTest/test.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ReplayerJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ReplayerJbiTest/smx.xml?rev=885404&r1=885403&r2=885404&view=diff
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ReplayerJbiTest/smx.xml (original)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/ReplayerJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -26,60 +26,9 @@
        xmlns:bpel="http://sample.bpel.org/bpel/sample"
        >
 
-    <bean id="transactionManager" class="org.apache.geronimo.transaction.manager.GeronimoTransactionManager"/>
-
-  <jencks:connectionTracker id="connectionTracker" geronimoTransactionManager="#transactionManager" />
-    
-  <jencks:workManager
-            id="workManager"
-            threadPoolSize="200"
-            transactionManager="#transactionManager" />
-  
-  <jencks:bootstrapContext
-            id="bootstrapContext"
-            workManager="#workManager"
-            transactionManager="#transactionManager" />
-  
-  <jencks:poolingSupport 
-            id="poolingSupport" 
-            connectionMaxIdleMinutes="5"
-            poolMaxSize="20"
-            />
-  
-  <jencks:connectionManager
-            id="connectionManager"
-            containerManagedSecurity="false"
-            transaction="xa"
-            transactionManager="#transactionManager"
-            poolingSupport="#poolingSupport"
-            connectionTracker="#connectionTracker" 
-            />
-
-    <bean id="localDerbyMCF" class="org.tranql.connector.derby.EmbeddedXAMCF">
-        <property name="databaseName" value="target/test/testdb"/>
-        <property name="createDatabase" value="true"/>
-        <property name="userName" value = "sa"/>
-        <property name="password" value = ""/>
-    </bean>
-    <bean id="localDerbyDataSource" class="org.springframework.jca.support.LocalConnectionFactoryBean">
-        <property name="managedConnectionFactory" ref="localDerbyMCF"/>
-        <property name="connectionManager" ref="connectionManager"/>
-    </bean>
-    
-    <bean id="jndi"
-          class="org.apache.xbean.spring.jndi.SpringInitialContextFactory" 
-          factory-method="makeInitialContext"
-          singleton="true"
-          depends-on="bootstrapContext"
-          >
-      <property name="entries" ref="jndiEntries" />
-    </bean>
-
     <util:map id="jndiEntries">
-        <entry key="testds" value-ref="localDerbyDataSource"/>
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
     </util:map>
-    
-
 
     <sm:container 
         id="jbi" 

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/smx.xml?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/smx.xml (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/smx.xml Mon Nov 30 12:52:56 2009
@@ -0,0 +1,40 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+
+-->
+<beans xmlns:sm="http://servicemix.apache.org/config/1.0"
+       xmlns:http="http://servicemix.apache.org/http/1.0"
+       xmlns:eip="http://servicemix.apache.org/eip/1.0"
+       xmlns:util="http://www.springframework.org/schema/util"
+       xmlns:jencks="http://jencks.org/2.0"
+       xmlns:mws="http://ode/bpel/unit-test.wsdl"
+       >
+
+    <util:map id="jndiEntries">
+        <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
+    </util:map>
+
+    <sm:container 
+        id="jbi" 
+        embedded="true" 
+        rootDir="target/test/smx"
+        transactionManager="#transactionManager"
+        depends-on="jndi"
+        >
+    </sm:container>
+</beans>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/smx.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/test.properties
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/test.properties?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/test.properties (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/test.properties Mon Nov 30 12:52:56 2009
@@ -0,0 +1,48 @@
+#
+#    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.
+#
+
+manualDeploy=true
+1deploy=v-1
+2nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+2nmr.operation=initiate
+2request=<msg><payload>test</payload><payload2/></msg>
+2response=.*test1.*
+3undeploy=v-1
+4deploy=v-1
+5deploy=v-2
+6nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+6nmr.operation=complete
+6request=<msg><payload>test</payload><payload2/></msg>
+6response=.*test3-old.*
+7nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+7nmr.operation=initiate
+7request=<msg><payload>test</payload><payload2/></msg>
+7response=.*test1.*
+8nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+8nmr.operation=complete
+8request=<msg><payload>test</payload><payload2/></msg>
+8response=.*test3-new.*
+9undeploy=v-1
+10nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+10nmr.operation=initiate
+10request=<msg><payload>test</payload><payload2/></msg>
+10response=.*test1.*
+11nmr.service={http://sample.bpel.org/bpel/sample}OnEventCorrelation
+11nmr.operation=complete
+11request=<msg><payload>test</payload><payload2/></msg>
+11response=.*test3-new.*
+

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/test.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.bpel
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.bpel?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.bpel (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.bpel Mon Nov 30 12:52:56 2009
@@ -0,0 +1,68 @@
+<?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.
+
+-->
+<bpws:process xmlns:bpws="http://docs.oasis-open.org/wsbpel/2.0/process/executable" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:ns="http://sample.bpel.org/bpel/sampleArtifacts" xmlns:tns="http://sample.bpel.org/bpel/sample" exitOnStandardFault="yes" name="OnEventCorrelation" suppressJoinFailure="yes" targetNamespace="http://sample.bpel.org/bpel/sample" expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
+  <bpws:import importType="http://schemas.xmlsoap.org/wsdl/" location="OnEventCorrelation.wsdl" namespace="http://sample.bpel.org/bpel/sample"/>
+  <bpws:import importType="http://schemas.xmlsoap.org/wsdl/" location="OnEventCorrelationArtifacts.wsdl" namespace="http://sample.bpel.org/bpel/sampleArtifacts"/>
+  <bpws:partnerLinks>
+    <bpws:partnerLink myRole="OnEventCorrelationProvider" name="client" partnerLinkType="tns:OnEventCorrelation"/>
+  </bpws:partnerLinks>
+  <bpws:variables>
+    <bpws:variable messageType="tns:OnEventCorrelationMessage" name="input"/>
+    <bpws:variable messageType="tns:OnEventCorrelationMessage" name="output"/>
+    <bpws:variable type="xsd:int" name="i"/>
+    <bpws:variable type="xsd:int" name="j"/>
+  </bpws:variables>
+  <bpws:correlationSets>
+    <bpws:correlationSet name="CorrelationSet" properties="ns:input"/>
+  </bpws:correlationSets>
+  <bpws:sequence name="main">
+    <bpws:scope>
+      <bpws:sequence>
+        <bpws:receive createInstance="yes" operation="initiate" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
+          <bpws:correlations>
+            <bpws:correlation initiate="yes" set="CorrelationSet"/>
+          </bpws:correlations>
+        </bpws:receive>
+        <bpws:assign>
+          <bpws:copy>
+            <bpws:from>'test1'</bpws:from>
+            <bpws:to>$output.payload</bpws:to>
+          </bpws:copy>
+        </bpws:assign>
+        <bpws:reply operation="initiate" partnerLink="client" variable="output"/>
+            
+        
+        <bpws:receive operation="complete" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
+              <bpws:correlations>
+                <bpws:correlation initiate="no" set="CorrelationSet"/>
+              </bpws:correlations>
+            </bpws:receive>
+            <bpws:empty name="e6"/>
+            <bpws:assign>
+              <bpws:copy>
+                <bpws:from>'test3-old'</bpws:from>
+                <bpws:to>$output.payload</bpws:to>
+              </bpws:copy>
+            </bpws:assign>
+            <bpws:reply operation="complete" partnerLink="client" variable="output"/>
+      </bpws:sequence>
+    </bpws:scope>
+  </bpws:sequence>
+</bpws:process>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.bpel
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.wsdl
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.wsdl?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.wsdl (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.wsdl Mon Nov 30 12:52:56 2009
@@ -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.
+
+-->
+<definitions xmlns="http://schemas.xmlsoap.org/wsdl/" xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype" xmlns:tns="http://sample.bpel.org/bpel/sample" xmlns:wsdlsoap="http://schemas.xmlsoap.org/wsdl/soap/" name="OnEventCorrelation" targetNamespace="http://sample.bpel.org/bpel/sample"
+xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+>
+  <message name="OnEventCorrelationMessage">
+    <part type="xsd:string" name="payload"/>
+    <part type="xsd:string" name="payload2"/>
+  </message>
+  <portType name="OnEventCorrelation">
+    <operation name="initiate">
+      <input message="tns:OnEventCorrelationMessage"/>
+      <output message="tns:OnEventCorrelationMessage"/>
+    </operation>
+    <operation name="complete">
+      <input message="tns:OnEventCorrelationMessage"/>
+      <output message="tns:OnEventCorrelationMessage"/>
+    </operation>
+  </portType>
+  <binding name="OnEventCorrelationBinding" type="tns:OnEventCorrelation">
+    <wsdlsoap:binding style="rpc" transport="http://schemas.xmlsoap.org/soap/http"/>
+    <operation name="initiate">
+      <wsdlsoap:operation soapAction="initiate"/>
+      <input>
+        <wsdlsoap:body use="literal"/>
+      </input>
+      <output>
+        <wsdlsoap:body use="literal"/>
+      </output>
+    </operation>
+    <operation name="complete">
+      <wsdlsoap:operation soapAction="complete"/>
+      <input>
+        <wsdlsoap:body use="literal"/>
+      </input>
+      <output>
+        <wsdlsoap:body use="literal"/>
+      </output>
+    </operation>
+  </binding>
+  <service name="OnEventCorrelation">
+    <port binding="tns:OnEventCorrelationBinding" name="OnEventCorrelation">
+      <wsdlsoap:address location="http://localhost:8080/ode/processes/OnEventCorrelation/"/>
+    </port>
+  </service>
+    <plnk:partnerLinkType name="OnEventCorrelation">
+        <plnk:role name="OnEventCorrelationProvider" portType="tns:OnEventCorrelation"/>
+    </plnk:partnerLinkType>
+</definitions>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelation.wsdl
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelationArtifacts.wsdl
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelationArtifacts.wsdl?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelationArtifacts.wsdl (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelationArtifacts.wsdl Mon Nov 30 12:52:56 2009
@@ -0,0 +1,35 @@
+<?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.
+
+-->
+<definitions 
+    xmlns:plnk="http://docs.oasis-open.org/wsbpel/2.0/plnktype" 
+    xmlns:tns="http://sample.bpel.org/bpel/sampleArtifacts" 
+    xmlns:vprop="http://docs.oasis-open.org/wsbpel/2.0/varprop" 
+    xmlns:xs="http://www.w3.org/2001/XMLSchema" 
+    xmlns:bpel="http://sample.bpel.org/bpel/sample" 
+    name="OnEventCorrelationArtifacts" 
+    targetNamespace="http://sample.bpel.org/bpel/sampleArtifacts" 
+    xmlns="http://schemas.xmlsoap.org/wsdl/"
+    >
+<vprop:property name="input" type="xs:string"/>
+<vprop:propertyAlias messageType="bpel:OnEventCorrelationMessage" part="payload" propertyName="tns:input">
+<!--vprop:query><![CDATA[bpel:input]]></vprop:query-->
+</vprop:propertyAlias>
+<import location="OnEventCorrelation.wsdl" namespace="http://sample.bpel.org/bpel/sample"/>
+</definitions>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/OnEventCorrelationArtifacts.wsdl
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/deploy.xml
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/deploy.xml?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/deploy.xml (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/deploy.xml Mon Nov 30 12:52:56 2009
@@ -0,0 +1,31 @@
+<?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.
+
+-->
+<dd:deploy xmlns:dd="http://www.apache.org/ode/schemas/dd/2007/03"
+    xmlns:bpel="http://sample.bpel.org/bpel/sample"
+    >
+
+    <dd:process
+        name="bpel:OnEventCorrelation" fileName="OnEventCorrelation.bpel">
+        <!--dd:process-events generate="none"/-->
+        <dd:provide partnerLink="client">
+            <dd:service name="bpel:OnEventCorrelation" port="OnEventCorrelation" />
+        </dd:provide>
+    </dd:process>
+</dd:deploy>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-1/deploy.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Added: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.bpel
URL: http://svn.apache.org/viewvc/ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.bpel?rev=885404&view=auto
==============================================================================
--- ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.bpel (added)
+++ ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.bpel Mon Nov 30 12:52:56 2009
@@ -0,0 +1,68 @@
+<?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.
+
+-->
+<bpws:process xmlns:bpws="http://docs.oasis-open.org/wsbpel/2.0/process/executable" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:ns="http://sample.bpel.org/bpel/sampleArtifacts" xmlns:tns="http://sample.bpel.org/bpel/sample" exitOnStandardFault="yes" name="OnEventCorrelation" suppressJoinFailure="yes" targetNamespace="http://sample.bpel.org/bpel/sample" expressionLanguage="urn:oasis:names:tc:wsbpel:2.0:sublang:xpath2.0">
+  <bpws:import importType="http://schemas.xmlsoap.org/wsdl/" location="OnEventCorrelation.wsdl" namespace="http://sample.bpel.org/bpel/sample"/>
+  <bpws:import importType="http://schemas.xmlsoap.org/wsdl/" location="OnEventCorrelationArtifacts.wsdl" namespace="http://sample.bpel.org/bpel/sampleArtifacts"/>
+  <bpws:partnerLinks>
+    <bpws:partnerLink myRole="OnEventCorrelationProvider" name="client" partnerLinkType="tns:OnEventCorrelation"/>
+  </bpws:partnerLinks>
+  <bpws:variables>
+    <bpws:variable messageType="tns:OnEventCorrelationMessage" name="input"/>
+    <bpws:variable messageType="tns:OnEventCorrelationMessage" name="output"/>
+    <bpws:variable type="xsd:int" name="i"/>
+    <bpws:variable type="xsd:int" name="j"/>
+  </bpws:variables>
+  <bpws:correlationSets>
+    <bpws:correlationSet name="CorrelationSet" properties="ns:input"/>
+  </bpws:correlationSets>
+  <bpws:sequence name="main">
+    <bpws:scope>
+      <bpws:sequence>
+        <bpws:receive createInstance="yes" operation="initiate" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
+          <bpws:correlations>
+            <bpws:correlation initiate="yes" set="CorrelationSet"/>
+          </bpws:correlations>
+        </bpws:receive>
+        <bpws:assign>
+          <bpws:copy>
+            <bpws:from>'test1'</bpws:from>
+            <bpws:to>$output.payload</bpws:to>
+          </bpws:copy>
+        </bpws:assign>
+        <bpws:reply operation="initiate" partnerLink="client" variable="output"/>
+            
+        
+        <bpws:receive operation="complete" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
+              <bpws:correlations>
+                <bpws:correlation initiate="no" set="CorrelationSet"/>
+              </bpws:correlations>
+            </bpws:receive>
+            <bpws:empty name="e6"/>
+            <bpws:assign>
+              <bpws:copy>
+                <bpws:from>'test3-new'</bpws:from>
+                <bpws:to>$output.payload</bpws:to>
+              </bpws:copy>
+            </bpws:assign>
+            <bpws:reply operation="complete" partnerLink="client" variable="output"/>
+      </bpws:sequence>
+    </bpws:scope>
+  </bpws:sequence>
+</bpws:process>

Propchange: ode/branches/APACHE_ODE_1.X/jbi/src/test/resources/RetireJbiTest/v-2/OnEventCorrelation.bpel
------------------------------------------------------------------------------
    svn:eol-style = native