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

svn commit: r948937 [29/33] - in /ode/trunk: ./ agents/src/main/java/org/apache/ode/agents/memory/ axis2-war/ axis2-war/src/main/assembly/ axis2-war/src/main/webapp/ axis2-war/src/main/webapp/WEB-INF/ axis2-war/src/main/webapp/WEB-INF/classes/ axis2-wa...

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/BindingContextImpl.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/BindingContextImpl.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/BindingContextImpl.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/BindingContextImpl.java Thu May 27 18:09:53 2010
@@ -35,15 +35,15 @@ import org.apache.ode.bpel.iapi.PartnerR
 /**
  * JBI Implementation of ODE's {@link org.apache.ode.bpel.iapi.BindingContext}
  * interface.
- * 
+ *
  * @author Maciej Szefler - m s z e f l e r @ g m a i l . c o m
- * 
+ *
  */
 class BindingContextImpl implements BindingContext {
     private static final Log __log = LogFactory.getLog(BindingContextImpl.class);
 
     private final OdeContext _ode;
-    
+
     BindingContextImpl(OdeContext ode) {
         _ode = ode;
     }
@@ -77,15 +77,15 @@ class BindingContextImpl implements Bind
         }
     }
 
-    
+
     private class PartnerRoleChannelImpl implements PartnerRoleChannel {
-        
+
         private final JbiEndpointReference _initialEPR;
 
         PartnerRoleChannelImpl(JbiEndpointReference epr) {
             _initialEPR = epr;
         }
-        
+
         PartnerRoleChannelImpl() {
             _initialEPR = null;
         }
@@ -97,7 +97,7 @@ class BindingContextImpl implements Bind
         public void close() {
             ; // noop
         }
-        
+
     }
 
 

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/DynamicMessageExchangeProcessor.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/DynamicMessageExchangeProcessor.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/DynamicMessageExchangeProcessor.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/DynamicMessageExchangeProcessor.java Thu May 27 18:09:53 2010
@@ -36,7 +36,7 @@ import org.apache.ode.il.OMUtils;
 public class DynamicMessageExchangeProcessor<T> extends BaseMessageExchangeProcessor {
 
     T _service;
-    
+
     public DynamicMessageExchangeProcessor(T service, DeliveryChannel channel) {
         super(channel);
         _service = service;

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiEndpointReference.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiEndpointReference.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiEndpointReference.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiEndpointReference.java Thu May 27 18:09:53 2010
@@ -33,8 +33,8 @@ import org.apache.ode.utils.DOMUtils;
 
 /**
  * JBI-based implementation of the ODE {@link org.apache.ode.bpel.iapi.EndpointReference}
- * interface. This is basically a wrapper around the 
- * {@link javax.jbi.servicedesc.ServiceEndpoint} interface. 
+ * interface. This is basically a wrapper around the
+ * {@link javax.jbi.servicedesc.ServiceEndpoint} interface.
  */
 class JbiEndpointReference implements EndpointReference {
 
@@ -42,19 +42,19 @@ class JbiEndpointReference implements En
   private Endpoint _initialPartnerEndpoint;
   private ServiceEndpoint _se;
   private QName _type;
-  
+
   JbiEndpointReference(Endpoint initialPartnerEndpoint, OdeContext ode) {
     _initialPartnerEndpoint = initialPartnerEndpoint;
     _ode = ode;
   }
-  
+
 
   JbiEndpointReference(ServiceEndpoint se) {
     if (se == null)
       throw new NullPointerException("Null ServiceEndpoint");
     _se = se;
   }
-  
+
   public JbiEndpointReference(ServiceEndpoint se, QName eprType) {
       this(se);
       _type = eprType;
@@ -79,11 +79,11 @@ public Document toXML() {
       return getServiceEndpoint().getServiceName().equals(((JbiEndpointReference)other).getServiceEndpoint().getServiceName());
     return false;
   }
-  
+
   public int hashCode() {
     return getServiceEndpoint().getServiceName().hashCode();
   }
-  
+
   public String toString() {
       if (_se != null) {
           return "JbiEndpointReference[" + _se.getServiceName() + ":" + _se.getEndpointName() + "]";

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeEventRouter.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeEventRouter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeEventRouter.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeEventRouter.java Thu May 27 18:09:53 2010
@@ -57,7 +57,7 @@ class JbiMessageExchangeEventRouter impl
                 _ode._instanceManagementProcessor.onJbiMessageExchange(mex);
                 return;
             }
-            
+
             Endpoint endpoint = new Endpoint(mex.getEndpoint().getServiceName(), mex.getEndpoint().getEndpointName());
             OdeService svc = _ode.getService(endpoint);
             if (svc == null) {

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeProcessor.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeProcessor.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeProcessor.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/JbiMessageExchangeProcessor.java Thu May 27 18:09:53 2010
@@ -24,6 +24,6 @@ import javax.jbi.messaging.MessagingExce
 
 public interface JbiMessageExchangeProcessor {
 
-  public void onJbiMessageExchange(MessageExchange mex) 
+  public void onJbiMessageExchange(MessageExchange mex)
     throws MessagingException;
 }

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MessageExchangeContextImpl.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MessageExchangeContextImpl.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MessageExchangeContextImpl.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MessageExchangeContextImpl.java Thu May 27 18:09:53 2010
@@ -33,7 +33,7 @@ import org.apache.ode.bpel.iapi.PartnerR
  * Implementation of the ODE {@link org.apache.ode.bpel.iapi.MessageExchangeContext}
  * interface. This class is used by the ODE engine to make invocation on JBI
  * services provided by other engines (i.e. the BPEL engine is acting as
- * client/consumer of services). 
+ * client/consumer of services).
  */
 public class MessageExchangeContextImpl implements MessageExchangeContext {
 

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MyEndpointReference.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MyEndpointReference.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MyEndpointReference.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/MyEndpointReference.java Thu May 27 18:09:53 2010
@@ -32,12 +32,12 @@ import org.apache.ode.utils.DOMUtils;
  */
 class MyEndpointReference implements EndpointReference {
   private OdeService _service;
- 
+
   MyEndpointReference(OdeService service) {
     _service = service;
-    
+
   }
-  
+
   @Override
   public boolean equals(Object obj) {
     if (obj instanceof MyEndpointReference)
@@ -54,17 +54,17 @@ class MyEndpointReference implements End
 
   public Document toXML() {
     Document xml = DOMUtils.newDocument();
-    
+
     // Prefer to use the external endpoint as our EPR,
     // but if we dont find one, use the internal endpoint.
     ServiceEndpoint se = _service.getExternalServiceEndpoint();
     if (se == null)
       se = _service.getInternalServiceEndpoint();
-    
+
     Element root = xml.createElementNS(EndpointReference.SERVICE_REF_QNAME.getNamespaceURI(),
         EndpointReference.SERVICE_REF_QNAME.getLocalPart());
     xml.appendChild(root);
-    
+
     // TODO: handle the operation name problem.
     DocumentFragment fragment = se.getAsReference(null);
     root.appendChild(xml.importNode(fragment,true));

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeBootstrap.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeBootstrap.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeBootstrap.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeBootstrap.java Thu May 27 18:09:53 2010
@@ -28,10 +28,10 @@ import javax.management.ObjectName;
 /**
  * ODE Implementation of the JBI {@link  javax.jbi.component.Bootstrap}
  * interface. This is just a place-holder, nothing gets done in the
- * bootstrap at this point. 
+ * bootstrap at this point.
  */
 public class OdeBootstrap implements Bootstrap {
-  
+
   @SuppressWarnings("unused")
   private InstallationContext _installContext;
 
@@ -91,7 +91,7 @@ public class OdeBootstrap implements Boo
      *           terminated.
      */
     public void onUninstall() throws JBIException {
-    
+
     }
 
 }

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeComponent.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeComponent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeComponent.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeComponent.java Thu May 27 18:09:53 2010
@@ -34,12 +34,12 @@ public class OdeComponent implements Com
     private OdeLifeCycle _lifeCycle;
 
     public OdeComponent() {
-        this(new OdeLifeCycle());        
+        this(new OdeLifeCycle());
     }
 
     public OdeComponent(OdeLifeCycle lifeCycle) {
         _lifeCycle = lifeCycle;
-    }   
+    }
 
     public ComponentLifeCycle getLifeCycle() {
         return _lifeCycle;
@@ -50,9 +50,9 @@ public class OdeComponent implements Com
     }
 
     /**
-     * 
+     *
      * @param ref ServiceEndpoint object
-     * 
+     *
      * @return Descriptor Object implementing
      *         {@link javax.jbi.servicedesc.Descriptor} interface.
      */
@@ -72,7 +72,7 @@ public class OdeComponent implements Com
      * Note that JBI assures matches on capability names only; it is the
      * responsibility of this method to examine capability values to ensure a
      * match with the consumer.
-     * 
+     *
      * @param endpoint
      *          the endpoint to be used by the consumer
      * @param exchange
@@ -96,7 +96,7 @@ public class OdeComponent implements Com
      * Note that JBI assures matches on capability names only; it is the
      * responsibility of this method to examine capability values to ensure a
      * match with the provider.
-     * 
+     *
      * @param exchange
      *          the proposed message exchange to be performed
      * @return true if this consumer component can interact with the described
@@ -110,7 +110,7 @@ public class OdeComponent implements Com
      * Resolve the given endpoint reference, given the capabilities of the given
      * consumer. This is called by JBI when it is attempting to resolve the given
      * endpoint reference on behalf of a component.
-     * 
+     *
      * @param epr
      *          the endpoint reference, in some XML dialect understood by the
      *          appropriate component (usually a Binding Component).

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConfigProperties.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConfigProperties.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConfigProperties.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConfigProperties.java Thu May 27 18:09:53 2010
@@ -32,7 +32,7 @@ public class OdeConfigProperties extends
     private static final String PROP_NAMESPACE = "pidNamespace";
 
     private static final String PROP_ALLOW_INCOMPLETE_DEPLOYMENT = "allowIncompleteDeployment";
-   
+
     private static final String PROP_MSGMAPPER = "messageMapper";
 
     public OdeConfigProperties(File cfgFile) {
@@ -47,7 +47,7 @@ public class OdeConfigProperties extends
     /**
      * Get the namespace that should be used to generate process identifiers
      * (PIDs). The local part of the PID will be the service unit id.
-     * 
+     *
      * @return
      */
     public String getPidNamespace() {
@@ -60,7 +60,7 @@ public class OdeConfigProperties extends
 
     /**
      * Get the mapper to use for converting message to/from NMS format.
-     * 
+     *
      * @return
      */
     public String[] getMessageMappers() {

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumer.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumer.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumer.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumer.java Thu May 27 18:09:53 2010
@@ -39,7 +39,7 @@ import org.apache.commons.logging.LogFac
 
 /**
  * Bridge between ODE (consumers) and JBI (providers). An single object of this type handles all communications initiated by ODE
- * that is destined for other JBI providers. 
+ * that is destined for other JBI providers.
  */
 abstract class OdeConsumer extends ServiceBridge implements JbiMessageExchangeProcessor {
     private static final Log __log = LogFactory.getLog(OdeConsumer.class);

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerAsync.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerAsync.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerAsync.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerAsync.java Thu May 27 18:09:53 2010
@@ -42,17 +42,17 @@ import org.apache.ode.bpel.iapi.MessageE
 class OdeConsumerAsync extends OdeConsumer {
     private static final Log __log = LogFactory.getLog(OdeConsumerAsync.class);
 
-    /** 
+    /**
      * We create an executor to handle all the asynchronous invocations/timeouts. Note, we don't need a lot of threads
      * here, the operations are all async, using single-thread executor avoids any possible problems in concurrent
      * use of delivery channel.
-     * 
-     * WARNING:  Canceling tasks does not immediately release them, so we don't use the schedule-cancel pattern here.  
+     *
+     * WARNING:  Canceling tasks does not immediately release them, so we don't use the schedule-cancel pattern here.
      */
     private ScheduledExecutorService _executor;
 
     private Map<String, Long> _mexTimeouts = new ConcurrentHashMap<String, Long>();
-    
+
     OdeConsumerAsync(OdeContext ode) {
         super(ode);
        _executor = Executors.newSingleThreadScheduledExecutor();

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerSync.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerSync.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerSync.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeConsumerSync.java Thu May 27 18:09:53 2010
@@ -29,19 +29,19 @@ import org.apache.ode.bpel.iapi.PartnerR
 
 /**
  * Completes {@link OdeConsumer} implementation using the synchronous invocation style (sendSync).
- * 
+ *
  * @author Maciej Szefler
  *
  */
 class OdeConsumerSync extends OdeConsumer {
     private static final Log __log = LogFactory.getLog(OdeConsumerSync.class);
-    
+
 
     OdeConsumerSync(OdeContext ode) {
         super(ode);
     }
 
-    
+
     protected void doSendTwoWay(final PartnerRoleMessageExchange odeMex, final InOut inout) {
         _ode._executorService.submit(new Runnable() {
             public void run() {

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeContext.java Thu May 27 18:09:53 2010
@@ -70,7 +70,7 @@ final public class OdeContext {
 
     public static final QName IM_SERVICE_NAME = new QName("http://www.apache.org/ode/pmapi", "InstanceManagementService");
     public static final String IM_PORT_NAME = "InstanceManagementPort";
-    
+
     /** static singleton */
     private static OdeContext __self;
 
@@ -106,10 +106,10 @@ final public class OdeContext {
 
     ProcessStoreImpl _store;
 
-    ServiceEndpoint _processManagementEndpoint;    
+    ServiceEndpoint _processManagementEndpoint;
     ServiceEndpoint _instanceManagementEndpoint;
 
-    JbiMessageExchangeProcessor _processManagementProcessor;    
+    JbiMessageExchangeProcessor _processManagementProcessor;
     JbiMessageExchangeProcessor _instanceManagementProcessor;
 
     ProcessManagement _processManagement;
@@ -179,7 +179,7 @@ final public class OdeContext {
             __log.debug("Activate endpoint: " + endpoint);
         }
 
-        
+
         OdeService service=_activeOdeServices.get(endpoint);
         if(service == null)
             service = new OdeService(this, endpoint);
@@ -191,7 +191,7 @@ final public class OdeContext {
                 Serializer ofh = new Serializer(is);
                 compiledProcess = ofh.readOProcess();
             } finally {
-                is.close();            	
+                is.close();
             }
             QName portType = null;
             for (Map.Entry<String, Endpoint> provide : pc.getProvideEndpoints().entrySet()) {
@@ -231,7 +231,7 @@ final public class OdeContext {
 
         if (svc != null) {
             _serviceEprMap.remove(svc);
-            svc.deactivate();        
+            svc.deactivate();
             if(svc.getCount() < 1 ) {
             _activeOdeServices.remove(endpoint);
             }
@@ -288,7 +288,7 @@ final public class OdeContext {
     public Mapper getDefaultMapper() {
         return _mappers.get(0);
     }
-    
+
     void activatePMAPIs() throws JBIException {
         ProcessAndInstanceManagementImpl pm = new ProcessAndInstanceManagementImpl(_server, _store);
         _processManagement = pm;
@@ -315,7 +315,7 @@ final public class OdeContext {
             }
         }
     }
-    
+
     public long calculateSizeOfService(EndpointReference epr) {
         if (epr != null) {
             for (OdeService odeService : _serviceEprMap.keySet()) {

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeLifeCycle.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeLifeCycle.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeLifeCycle.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeLifeCycle.java Thu May 27 18:09:53 2010
@@ -78,7 +78,7 @@ public class OdeLifeCycle implements Com
     private OdeConfigProperties _config;
 
     public OdeLifeCycle() {
-        
+
     }
 
     public OdeLifeCycle(OdeConfigProperties config) {
@@ -194,7 +194,7 @@ public class OdeLifeCycle implements Com
 
         _ode._dataSource = _db.getDataSource();
     }
-    
+
     /**
      * Load the "ode-jbi.properties" file from the install directory.
      *

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeSUManager.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeSUManager.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeSUManager.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeSUManager.java Thu May 27 18:09:53 2010
@@ -41,7 +41,7 @@ public class OdeSUManager implements Ser
   private static final Messages __msgs = Messages.getMessages(Messages.class);
 
   private static final String XMLNS_JBI_MGMT = "http://java.sun.com/xml/ns/jbi/management-message";
-  
+
   private OdeContext _ode;
 
   /** All the service units that have been "init"ed. */

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeService.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeService.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeService.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeService.java Thu May 27 18:09:53 2010
@@ -63,7 +63,7 @@ public class OdeService extends ServiceB
     private Element _serviceref;
 
     private Endpoint _endpoint;
-    
+
     private int count;
 
     public OdeService(OdeContext odeContext, Endpoint endpoint) throws Exception {
@@ -76,7 +76,7 @@ public class OdeService extends ServiceB
     }
     /**
      * Do the JBI endpoint activation.
-     * 
+     *
      * @throws JBIException
      */
     public void activate() throws JBIException {
@@ -101,7 +101,7 @@ public class OdeService extends ServiceB
      */
     public void deactivate() throws JBIException {
         count--;
-        if(count != 0) 
+        if(count != 0)
             return;
         _ode.getContext().deactivateEndpoint(_internal);
         __log.debug("Dectivated endpoint " + _endpoint);
@@ -167,14 +167,14 @@ public class OdeService extends ServiceB
                 __log.error("Unexpected error invoking ODE.", t);
                 err = new RuntimeException(t);
             } finally {
-                // If we got an error that wasn't sent.  
+                // If we got an error that wasn't sent.
                 if (jbiMex.getStatus() == ExchangeStatus.ACTIVE && !success) {
                     if (err != null && jbiMex.getError() == null)  {
                         jbiMex.setError(err);
                     }
-                    jbiMex.setStatus(ExchangeStatus.ERROR);     
-                    _ode.getChannel().send(jbiMex);         
-                }       
+                    jbiMex.setStatus(ExchangeStatus.ERROR);
+                    _ode.getChannel().send(jbiMex);
+                }
             }
         } else {
             __log.error("JBI MessageExchange " + jbiMex.getExchangeId() + " is of an unsupported pattern "
@@ -188,7 +188,7 @@ public class OdeService extends ServiceB
     /**
      * Called from
      * {@link MessageExchangeContextImpl#onAsyncReply(MyRoleMessageExchange)}
-     * 
+     *
      * @param mex
      *            message exchange
      */
@@ -216,7 +216,7 @@ public class OdeService extends ServiceB
         default:
             __log.warn("Received ODE message exchange in unexpected state: " + mex.getStatus() + " mexId: " + mexId + " clientId: " + clientId);
         }
-        
+
         mex.release(mex.getStatus() == MessageExchange.Status.RESPONSE);
         _ode._scheduler.registerSynchronizer(new Synchronizer() {
             public void afterCompletion(boolean success) {
@@ -242,7 +242,7 @@ public class OdeService extends ServiceB
 
     /**
      * Forward a JBI input message to ODE.
-     * 
+     *
      * @param jbiMex
      */
     private void invokeOde(javax.jbi.messaging.MessageExchange jbiMex, NormalizedMessage request) throws Exception {
@@ -371,7 +371,7 @@ public class OdeService extends ServiceB
             setError(jbiMex, mte);
         }
     }
-    
+
     private void setError(javax.jbi.messaging.MessageExchange jbiMex, Exception error) throws MessagingException {
         jbiMex.setError(error);
         jbiMex.setStatus(ExchangeStatus.ERROR);

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/OdeServiceUnit.java Thu May 27 18:09:53 2010
@@ -53,9 +53,9 @@ class OdeServiceUnit {
     private String _serviceUnitID;
 
     private Collection<QName> _registered = new ArrayList<QName>();
-    
+
     private static final String LIB_DIR = "lib";
-    
+
     /** Ctor. */
     OdeServiceUnit(OdeContext ode, String serviceUnitID, String serviceUnitRootPath) {
         _ode = ode;
@@ -67,10 +67,10 @@ class OdeServiceUnit {
         ClassLoader cl = Thread.currentThread().getContextClassLoader();
         try {
             Thread.currentThread().setContextClassLoader(getConfigurationClassLoader());
-            // JBI ServiceUnits don't use autoincrement version, 
+            // 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 
+            // 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);
@@ -147,11 +147,11 @@ class OdeServiceUnit {
             }
         }
     }
-    
+
     public ClassLoader getConfigurationClassLoader() throws DeploymentException {
         return new URLClassLoader(getDefaultLocations(), getClass().getClassLoader());
     }
-    
+
     protected URL[] getDefaultLocations() throws DeploymentException {
         try {
             File[] jars = new File(_serviceUnitRootPath, LIB_DIR).listFiles(new FilenameFilter() {

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/Receiver.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/Receiver.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/Receiver.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/Receiver.java Thu May 27 18:09:53 2010
@@ -62,7 +62,7 @@ public class Receiver implements Runnabl
 
     /**
      * Constructor for creating instance of this class.
-     * 
+     *
      * @param context
      *            for receiving environment parameters.
      */

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/ServiceBridge.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/ServiceBridge.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/ServiceBridge.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/ServiceBridge.java Thu May 27 18:09:53 2010
@@ -29,18 +29,18 @@ import org.apache.ode.bpel.iapi.MyRoleMe
 import org.apache.ode.bpel.iapi.PartnerRoleMessageExchange;
 
 /**
- * Base-class for classes providing JBI-ODE translation services. 
- * 
+ * Base-class for classes providing JBI-ODE translation services.
+ *
  * @author Maciej Szefler - m s z e f l e r @ g m a i l . c o m
  *
  */
 public class ServiceBridge {
-    
+
     private static final Log __log = LogFactory.getLog(ServiceBridge.class);
 
     /**
      * Transfer message properties from the ODE message exchange to the JBI message exchange object.
-     * 
+     *
      * @param jbiMex destination JBI message-exchange
      * @param odeMex source ODE message-exchange
      */
@@ -58,10 +58,10 @@ public class ServiceBridge {
         in.setProperty(MessageExchange.PROPERTY_SEP_MYROLE_SESSIONID, odeMex.getProperty(MessageExchange.PROPERTY_SEP_PARTNERROLE_SESSIONID));
         in.setProperty(MessageExchange.PROPERTY_SEP_PARTNERROLE_SESSIONID, odeMex.getProperty(MessageExchange.PROPERTY_SEP_MYROLE_SESSIONID));
     }
-    
+
     /**
      * Transfer message properties from the JBI message exchange to the ODE message exchange object.
-     * 
+     *
      * @param odeMex destination ODE message-exchange
      * @param jbiMex source JBI message-exchange
      */

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/DocLitMapper.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/DocLitMapper.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/DocLitMapper.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/DocLitMapper.java Thu May 27 18:09:53 2010
@@ -77,7 +77,7 @@ public class DocLitMapper extends BaseXm
   public void toNMS(NormalizedMessage nmsMsg,
       org.apache.ode.bpel.iapi.Message odeMsg, Message msgdef, QName fault)
       throws MessagingException, MessageTranslationException {
-      
+
     // If this is an unkown fault, just return an empty element
     // built with the fault name
     if (msgdef == null && fault != null) {
@@ -102,14 +102,14 @@ public class DocLitMapper extends BaseXm
         __log.debug(errmsg);
         throw new MessageTranslationException(errmsg);
     }
-    
+
     Element part = DOMUtils.findChildByName(odeMsg.getMessage(),new QName(null, partdef.getName()));
     if (part == null) {
       String errmsg = "ODE message did not contain expected part: " +  partdef.getName();
       __log.debug(errmsg);
       throw new MessageTranslationException(errmsg);
     }
-    
+
     Element content = DOMUtils.findChildByName(part, partdef.getElementName());
     if (content == null) {
       String errmsg = "ODE message did not contain element " + partdef.getElementName() + " in part: " +  partdef.getName();
@@ -128,14 +128,14 @@ public class DocLitMapper extends BaseXm
     assert msgdef.getParts().size() == 1 : "multi part!";
     Part partdef = (Part) msgdef.getParts().values().iterator().next();
     assert partdef.getElementName() != null : "non-element part!";
-    
+
     Element el = parse(nmsMsg.getContent());
     if (!DOMUtils.getNodeQName(el).equals(partdef.getElementName())) {
       String errmsg = "NMS message did not contain element "  + partdef.getElementName();
       __log.debug(errmsg);
       throw new MessageTranslationException(errmsg);
     }
-    
+
 
     Document doc = newDocument();
     Element msgel = doc.createElement("message");
@@ -144,7 +144,7 @@ public class DocLitMapper extends BaseXm
     msgel.appendChild(pel);
     pel.appendChild(doc.importNode(el,true));
     odeMsg.setMessage(msgel);
-    
+
   }
 
 
@@ -160,7 +160,7 @@ public class DocLitMapper extends BaseXm
           if (pdef.getElementName().equals(elQname))
               return f;
       }
-      
+
       return null;
   }
 
@@ -168,7 +168,7 @@ public class DocLitMapper extends BaseXm
    * Check if a message definition is compatible with doc-lit mapping. For
    * WSDL1.1 this means that the message definition needs to have exactly one
    * element part.
-   * 
+   *
    * @param msg
    *          message definition to check
    * @return true if compatible, false otherwise
@@ -177,17 +177,17 @@ public class DocLitMapper extends BaseXm
     // Null messages are acceptable.
     if (msg == null)
       return true;
-  
+
     // If we are non-empty, we need to have exactly one part.
     if (msg.getParts().size() != 1)
       return false;
-  
+
     // The single part must also be an "element" typed part.
     if (((Part) msg.getParts().values().iterator().next()).getElementName() == null)
       return false;
-  
+
     return true;
-  
+
   }
 
 }

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapper.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapper.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapper.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapper.java Thu May 27 18:09:53 2010
@@ -67,7 +67,7 @@ public class JbiWsdl11WrapperMapper exte
     }
 
     /**
-     * 
+     *
      * Convert ODE normalized message to JBI normalized "WSDL 1.1 Wrapper"
      * format.
      */
@@ -158,12 +158,12 @@ public class JbiWsdl11WrapperMapper exte
         if (__log.isTraceEnabled())
             __log.trace("toFaultType(jbiFlt=" + jbiFlt + ")");
 
-        
+
         final QName partElName = new QName(URI_WSDL11_WRAPPER, "part");
         List<QName> eltypes = new LinkedList<QName>();
-        
+
         // Figure out what we have in the message we just got.
-        Element srcel = parse(jbiFlt.getContent()); 
+        Element srcel = parse(jbiFlt.getContent());
         Node n = srcel.getFirstChild();
         while (n != null) {
             if (n.getNodeType() == Node.ELEMENT_NODE) {
@@ -186,10 +186,10 @@ public class JbiWsdl11WrapperMapper exte
         fltiter:for (Fault f : faults) {
             if (f.getMessage() == null && eltypes.isEmpty())
                 return f;
-            
+
             if (f.getMessage().getParts().size() != eltypes.size())
                 continue;
-            
+
             List<Part> expectedParts = f.getMessage().getOrderedParts(null);
 
             int i = 0;
@@ -197,22 +197,22 @@ public class JbiWsdl11WrapperMapper exte
                 if (eltypes.size() <= i)
                     continue fltiter;
                 QName etype = eltypes.get(i++);
-                
+
                 if ((p.getElementName() == null) ^ (etype == null))
                     continue fltiter;
-                
+
                 if (etype == null && p.getElementName() == null)
                     continue;
 
                 if (!etype.equals(p.getElementName()))
                     continue fltiter;
             }
-            
+
             return f;
-            
+
         }
-        
-        // None of the faults has been recognized. 
+
+        // None of the faults has been recognized.
         return null;
     }
 

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/Mapper.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/Mapper.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/Mapper.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/Mapper.java Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@ public interface Mapper {
 
     /**
      * Determine if this mapper recognizes the format of the NMS message.
-     * 
+     *
      * @param nmsMsg
      * @return
      */
@@ -47,7 +47,7 @@ public interface Mapper {
      * Convert a ODE message to NMS format. This call must only be called if
      * {@link #isRecognized(NormalizedMessage, Operation)} returned,
      * <code>true</code>.
-     * 
+     *
      * @param nmsMsg
      * @param odeMsg
      * @param msgdef
@@ -61,7 +61,7 @@ public interface Mapper {
      * Convert an NMS message to ODE format. This call must only be called if
      * {@link #isRecognized(NormalizedMessage, Operation)} returned,
      * <code>true</code>.
-     * 
+     *
      * @param odeMsg
      * @param nmsMsg
      * @param msgdef
@@ -69,18 +69,18 @@ public interface Mapper {
      */
     void toODE(Message odeMsg, NormalizedMessage nmsMsg, javax.wsdl.Message msgdef) throws MessageTranslationException;
 
-    /** 
+    /**
      * Infer the fault type based on the message.
      * @param jbiFlt JBI fault message
      * @param faults collection of possible faults
      * @return matching fault, or null if no match
-     * @throws MessageTranslationException 
+     * @throws MessageTranslationException
      */
     Fault toFaultType(javax.jbi.messaging.Fault jbiFlt, Collection<Fault> faults) throws MessageTranslationException;
-    
+
     enum Recognized {
         TRUE, FALSE, UNSURE
     }
 
-   
+
 }

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/ServiceMixMapper.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/ServiceMixMapper.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/ServiceMixMapper.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/msgmap/ServiceMixMapper.java Thu May 27 18:09:53 2010
@@ -99,13 +99,13 @@ public class ServiceMixMapper extends Ba
         __log.debug("Recognizing RPC style content");
         for (String pname : ((Set<String>) op.getInput().getMessage().getParts().keySet())) {
             Part part = op.getInput().getMessage().getPart(pname);
-            
+
             if (part.getElementName() != null) {
                 //RPC style invocation doesn't allow element parts, so we don't accept it
                 __log.debug("Part " + part.getName() + " has element content " + part.getElementName() + ". It's not allowed for RPC style.");
                 return Recognized.FALSE;
             }
-            
+
             // with RPC semantic the body is wrapped by a partName which is same as bodyElementName
             Element pdata = DOMUtils.findChildByName(msg, new QName(null, part.getName()));
             if (pdata == null) {
@@ -121,20 +121,20 @@ public class ServiceMixMapper extends Ba
             MessageTranslationException {
         if (msgdef == null)
             throw new NullPointerException("msdef must not be null.");
-        
+
         Map<String, Node> headers = odeMsg.getHeaderParts();
         if (headers != null) {
             for (String header : headers.keySet()) {
                 if (__log.isDebugEnabled()) {
                     __log.debug("toNMS() header " + header + " := " + DOMUtils.domToString(headers.get(header)) );
                 }
-                
+
                 Map<QName, DocumentFragment> headers2 = (Map<QName, DocumentFragment>) nmsMsg.getProperty("org.apache.servicemix.soap.headers");
                 if (headers2 == null) {
                     headers2 = new HashMap<QName, DocumentFragment>();
                     nmsMsg.setProperty("org.apache.servicemix.soap.headers", headers2);
                 }
-                
+
                 Node v = headers.get(header);
                 DocumentFragment f = v.getOwnerDocument().createDocumentFragment();
                 f.appendChild(v);
@@ -142,8 +142,8 @@ public class ServiceMixMapper extends Ba
             }
         }
 
-        
-        
+
+
         Element ode = odeMsg == null ? null : odeMsg.getMessage();
         Element part = ode == null ? null : DOMUtils.getFirstChildElement(ode);
         Element firstPartEl = part == null ? null : DOMUtils.getFirstChildElement(part);
@@ -210,7 +210,7 @@ public class ServiceMixMapper extends Ba
             }
             return;
         }
-        
+
         if (__log.isDebugEnabled()) {
             __log.debug("toODE() normalized message:\n" + prettyPrint(nms));
         }
@@ -247,7 +247,7 @@ public class ServiceMixMapper extends Ba
             }
             odeMsg.setMessage(nms);
         }
-        
+
         Map<QName, DocumentFragment> headers = (Map<QName, DocumentFragment>) nmsMsg.getProperty("org.apache.servicemix.soap.headers");
         if (headers != null) {
             for (QName header : headers.keySet()) {

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/Schema.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/Schema.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/Schema.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/Schema.java Thu May 27 18:09:53 2010
@@ -24,7 +24,7 @@ import org.w3c.dom.Element;
 
 /**
  * Contains informations related to a schema.
- *  
+ *
  * @author gnodet
  */
 public class Schema {
@@ -33,7 +33,7 @@ public class Schema {
     private String namespace;
     private List imports;
     private URI sourceUri;
-    
+
     /**
      * Add a reference to an imported namespace.
      * @param namespace the namespace to reference
@@ -44,7 +44,7 @@ public class Schema {
         }
         imports.add(namespace);
     }
-    
+
     /**
      * @return Returns the imports.
      */

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/SchemaCollection.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/SchemaCollection.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/SchemaCollection.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/SchemaCollection.java Thu May 27 18:09:53 2010
@@ -38,20 +38,20 @@ import org.xml.sax.InputSource;
 
 /**
  * Collection of schemas.
- *  
+ *
  * @author gnodet
  */
 public class SchemaCollection {
 
     private static Log log = LogFactory.getLog(SchemaCollection.class);
-    
+
     private Map schemas;
     private URI baseUri;
-    
+
     public SchemaCollection() {
         this(null);
     }
-    
+
     public SchemaCollection(URI baseUri) {
         if (log.isDebugEnabled()) {
             log.debug("Initializing schema collection with baseUri: " + baseUri);
@@ -59,11 +59,11 @@ public class SchemaCollection {
         this.baseUri = baseUri;
         this.schemas = new HashMap();
     }
-    
+
     public Schema getSchema(String namespaceURI) {
         return (Schema) schemas.get(namespaceURI);
     }
-    
+
     public void read(Element elem, URI sourceUri) throws Exception {
         Schema schema = new Schema();
         schema.setSourceUri(sourceUri);
@@ -72,7 +72,7 @@ public class SchemaCollection {
         schemas.put(schema.getNamespace(), schema);
         handleImports(schema);
     }
-    
+
     public void read(String location, URI baseUri) throws Exception {
         if (log.isDebugEnabled()) {
             log.debug("Reading schema at '" + location + "' with baseUri '" + baseUri + "'");
@@ -97,16 +97,16 @@ public class SchemaCollection {
         inputSource.setSystemId(loc.toString());
         read(inputSource);
     }
-    
+
     public void read(InputSource inputSource) throws Exception {
-        DocumentBuilderFactory docFac = XMLParserUtils.getDocumentBuilderFactory(); // don't trust system provided parser! 
+        DocumentBuilderFactory docFac = XMLParserUtils.getDocumentBuilderFactory(); // don't trust system provided parser!
         docFac.setNamespaceAware(true);
         DocumentBuilder builder = docFac.newDocumentBuilder();
         Document doc = builder.parse(inputSource);
-        read(doc.getDocumentElement(), 
+        read(doc.getDocumentElement(),
              inputSource.getSystemId() != null ? new URI(inputSource.getSystemId()) : null);
     }
-    
+
     protected void handleImports(Schema schema) throws Exception {
         NodeList children = schema.getRoot().getChildNodes();
         List imports = new ArrayList();
@@ -133,7 +133,7 @@ public class SchemaCollection {
             schema.getRoot().removeChild(ce);
         }
     }
-    
+
     protected static URI resolve(URI base, String location) {
         if ("jar".equals(base.getScheme())) {
             String str = base.toString();
@@ -151,7 +151,7 @@ public class SchemaCollection {
            return 0;
         }
      }
-     
+
      public Collection getSchemas() {
         if (schemas != null) {
            return schemas.values();

Modified: ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/WSDLFlattener.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/WSDLFlattener.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/WSDLFlattener.java (original)
+++ ode/trunk/jbi/src/main/java/org/apache/ode/jbi/util/WSDLFlattener.java Thu May 27 18:09:53 2010
@@ -46,17 +46,17 @@ import com.ibm.wsdl.extensions.schema.Sc
 public class WSDLFlattener {
 
     private static Log __log = LogFactory.getLog(WSDLFlattener.class);
-    
+
     private Definition _definition;
     private SchemaCollection _schemas;
     private Map<QName, Definition> _flattened;
     private boolean _initialized;
-    
+
 
     public WSDLFlattener(Definition definition) {
         this(definition, null);
     }
-        
+
     public WSDLFlattener(Definition definition, SchemaCollection schemas) {
         if (definition == null)
             throw new NullPointerException("Null definition!");
@@ -64,7 +64,7 @@ public class WSDLFlattener {
         this._flattened = new ConcurrentHashMap<QName, Definition>();
         this._schemas = schemas;
     }
-    
+
     /**
      * Parse the schemas referenced by the definition.
      * @throws Exception if an error occurs
@@ -78,7 +78,7 @@ public class WSDLFlattener {
             _initialized = true;
         }
     }
-    
+
     /**
      * Retrieve a flattened definition for a given port type name.
      * @param portType the port type to create a flat definition for
@@ -121,7 +121,7 @@ public class WSDLFlattener {
     public void setSchemas(SchemaCollection schemas) {
         this._schemas = schemas;
     }
-    
+
     private Definition flattenDefinition(QName name) throws Exception {
         // Check that schemas have been loaded
         initialize();
@@ -174,7 +174,7 @@ public class WSDLFlattener {
             }
             flatPort.addOperation(flatOper);
         }
-        
+
         // Import schemas in definition
         if (_schemas.getSize() > 0) {
            Types types = flat.createTypes();
@@ -186,11 +186,11 @@ public class WSDLFlattener {
            }
            flat.setTypes(types);
         }
-        
+
         flat.addPortType(flatPort);
         return flat;
     }
-    
+
     private void parseSchemas(Definition def) throws Exception {
         if (def.getTypes() != null && def.getTypes().getExtensibilityElements() != null) {
             for (Iterator iter = def.getTypes().getExtensibilityElements().iterator(); iter.hasNext();) {
@@ -235,7 +235,7 @@ public class WSDLFlattener {
             flat.addNamespace(key, val);
         }
     }
-    
+
     private Message copyMessage(Message defMessage, Definition flat) {
         Message flatMsg = flat.createMessage();
         flatMsg.setUndefined(false);

Modified: ode/trunk/jbi/src/test/java/org/apache/ode/jbi/ExtVarJbiTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/java/org/apache/ode/jbi/ExtVarJbiTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/java/org/apache/ode/jbi/ExtVarJbiTest.java (original)
+++ ode/trunk/jbi/src/test/java/org/apache/ode/jbi/ExtVarJbiTest.java Thu May 27 18:09:53 2010
@@ -41,7 +41,7 @@ public class ExtVarJbiTest extends JbiTe
         s.close();
         tm.commit();
     }
-    
+
     private static void dropTable(Connection c, String name) {
         try {
             Statement s = c.createStatement();
@@ -51,7 +51,7 @@ public class ExtVarJbiTest extends JbiTe
             // ignore
         }
     }
-    
+
     public void testExtVar() throws Exception {
         initDb();
         go();

Modified: ode/trunk/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java (original)
+++ ode/trunk/jbi/src/test/java/org/apache/ode/jbi/JbiTestBase.java Thu May 27 18:09:53 2010
@@ -57,10 +57,10 @@ public class JbiTestBase extends SpringT
 
     protected OdeComponent odeComponent;
     protected JBIContainer jbiContainer;
-    
+
     protected Properties testProperties;
     protected DefaultServiceMixClient smxClient;
-    
+
     @Override
     protected AbstractXmlApplicationContext createBeanFactory() {
         return new ClassPathXmlApplicationContext(new String[] {
@@ -68,7 +68,7 @@ public class JbiTestBase extends SpringT
             "/" + getTestName() + "/smx.xml"
         });
     }
-    
+
     private void initOdeDb() throws Exception {
         TransactionManager tm = (TransactionManager) getBean("transactionManager");
         tm.begin();
@@ -78,13 +78,13 @@ public class JbiTestBase extends SpringT
         s.close();
         tm.commit();
     }
-    
+
     @Override
     protected void setUp() throws Exception {
         super.setUp();
 
         initOdeDb();
-        
+
         jbiContainer = ((JBIContainer) getBean("jbi"));
         odeComponent = new OdeComponent();
 
@@ -93,17 +93,17 @@ public class JbiTestBase extends SpringT
         activationSpec.setComponent(odeComponent);
         activationSpec.setComponentName("ODE");
         jbiContainer.activateComponent(new File("target/test/smx/ode").getAbsoluteFile(), odeComponent, "", cc, activationSpec,  true, false, false, null);
-        
+
         testProperties = new Properties();
         testProperties.load(getClass().getResourceAsStream("/" + getTestName() + "/test.properties"));
-        
+
         smxClient = new DefaultServiceMixClient(jbiContainer);
     }
-    
+
     protected String getTestName() {
         return getClass().getSimpleName();
     }
-    
+
     protected void enableProcess(String resource, boolean enable) throws Exception {
         resource = "target/test/resources/" + resource;
         String process = resource.substring(resource.lastIndexOf('/') + 1);
@@ -127,7 +127,7 @@ public class JbiTestBase extends SpringT
 
     protected void go() throws Exception {
         boolean manualDeploy = Boolean.parseBoolean("" + testProperties.getProperty("manualDeploy"));
-        if (!manualDeploy) 
+        if (!manualDeploy)
             enableProcess(getTestName(), true);
 
         try {
@@ -136,7 +136,7 @@ public class JbiTestBase extends SpringT
             do {
                 String prefix = i == 0 ? "" : "" + i;
                 loop = i == 0;
-    
+
                 {
                     String deploy = testProperties.getProperty(prefix + "deploy");
                     if (deploy != null) {
@@ -151,7 +151,7 @@ public class JbiTestBase extends SpringT
                         enableProcess(getTestName() + "/" + undeploy, false);
                     }
                 }
-                
+
                 String request = testProperties.getProperty(prefix + "request");
                 if (request != null && request.startsWith("@")) {
                     request = inputStreamToString(getClass().getResourceAsStream("/" + getTestName() + "/" + request.substring(1)));
@@ -182,7 +182,7 @@ public class JbiTestBase extends SpringT
                         wt.close();
                         // Read the response.
                         String result = inputStreamToString(connection.getInputStream());
-                        
+
                         log.debug(getTestName() + " have result: " + result);
                         matchResponse(expectedResponse, result, true);
                     }
@@ -205,7 +205,7 @@ public class JbiTestBase extends SpringT
                         }
                 }
                 }
-                
+
                 i++;
             } while (loop);
 
@@ -214,7 +214,7 @@ public class JbiTestBase extends SpringT
                 enableProcess(getTestName(), false);
         }
     }
-    
+
     protected void matchResponse(String expectedResponse, String result, boolean succeeded) {
         if (succeeded) {
             assertTrue("Response doesn't match expected regex.\nExpected: " + expectedResponse + "\nReceived: " + result, Pattern.compile(expectedResponse, Pattern.DOTALL).matcher(result).matches());
@@ -222,7 +222,7 @@ public class JbiTestBase extends SpringT
             assertTrue("Expected success, but got fault", expectedResponse.equals("FAULT"));
         }
     }
-    
+
     private String inputStreamToString(InputStream is) throws IOException {
         ByteArrayOutputStream baos = new ByteArrayOutputStream();
         FileUtil.copyInputStream(is, baos);

Modified: ode/trunk/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java (original)
+++ ode/trunk/jbi/src/test/java/org/apache/ode/jbi/OdeJbiComponentLifeCycleTest.java Thu May 27 18:09:53 2010
@@ -59,7 +59,7 @@ public class OdeJbiComponentLifeCycleTes
         container.start();
 
         component = new OdeComponent();
-        
+
     }
 
     protected void tearDown() throws Exception {

Modified: ode/trunk/jbi/src/test/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapperTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapperTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapperTest.java (original)
+++ ode/trunk/jbi/src/test/java/org/apache/ode/jbi/msgmap/JbiWsdl11WrapperMapperTest.java Thu May 27 18:09:53 2010
@@ -36,18 +36,18 @@ import org.apache.ode.utils.DOMUtils;
 
 public class JbiWsdl11WrapperMapperTest extends junit.framework.TestCase {
     private static Log __log = LogFactory.getLog(JbiWsdl11WrapperMapperTest.class);
-    
+
     public static class MockJbiFault implements javax.jbi.messaging.Fault {
         private String resourceName;
-        
+
         public MockJbiFault(String resourceName) {
             this.resourceName = resourceName;
         }
-        
+
         public void addAttachment(String id, DataHandler content) throws MessagingException {
             // TODO Auto-generated method stub
             __log.debug("addAttachment");
-            
+
         }
 
         public DataHandler getAttachment(String id) {
@@ -91,29 +91,29 @@ public class JbiWsdl11WrapperMapperTest 
         public void removeAttachment(String id) throws MessagingException {
             // TODO Auto-generated method stub
             __log.debug("removeAttachment");
-            
+
         }
 
         public void setContent(Source content) throws MessagingException {
             // TODO Auto-generated method stub
             __log.debug("setContent");
-            
+
         }
 
         public void setProperty(String name, Object value) {
             // TODO Auto-generated method stub
             __log.debug("setProperty");
-            
+
         }
 
         public void setSecuritySubject(Subject subject) {
             // TODO Auto-generated method stub
             __log.debug("setSecuritySubject");
-            
+
         }
-        
-    }; 
-    
+
+    };
+
     public void testFault() throws Exception {
         JbiWsdl11WrapperMapper m = new JbiWsdl11WrapperMapper();
         Definition w = javax.wsdl.factory.WSDLFactory.newInstance().newWSDLReader().readWSDL(getClass().getResource("/test.wsdl").getFile());

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest.bpel Thu May 27 18:09:53 2010
@@ -34,7 +34,7 @@
   </bpws:correlationSets>
   <bpws:sequence name="main">
     <bpws:receive createInstance="yes" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input"/>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>
@@ -43,22 +43,22 @@
   <wsa:EndpointReference xmlns:wsa="http://www.w3.org/2005/08/addressing">
     <wsa:Address>http://localhost:8198/EPRTest2/?http.soap=true&amp;http.soapVersion=1.1</wsa:Address>
   </wsa:EndpointReference>
-</sref:service-ref> 
+</sref:service-ref>
             </bpws:literal>
          </bpws:from>
          <bpws:to partnerLink="client"/>
-      </bpws:copy> 
+      </bpws:copy>
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opInOut" inputVariable="input" outputVariable="output"/>
-    
+
     <bpws:assign>
         <bpws:copy>
             <bpws:from>$output</bpws:from>
             <bpws:to>$output2</bpws:to>
         </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>
@@ -67,7 +67,7 @@
 <jbi:end-point-reference jbi:end-point-name="default"
       jbi:service-name="bpel:EPRTest2"
       xmlns:jbi="http://java.sun.com/jbi/end-point-reference" xmlns:bpel="http://sample.bpel.org/bpel/sample"/>
-</sref:service-ref> 
+</sref:service-ref>
             </bpws:literal>
          </bpws:from>
          <bpws:to partnerLink="client"/>
@@ -77,7 +77,7 @@
             <bpws:to>$input.data</bpws:to>
         </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:invoke partnerLink="client" operation="opInOut" inputVariable="input" outputVariable="output"/>
     <bpws:assign>
         <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest2.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest2.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest2.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/EPRTest2.bpel Thu May 27 18:09:53 2010
@@ -35,7 +35,7 @@
 
     <bpws:receive createInstance="yes" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.payload</bpws:from>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation000.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation000.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation000.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation000.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation001.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation001.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation001.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation001.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation010.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation010.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation010.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation010.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation011.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation011.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation011.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation011.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation100.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation100.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation100.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation100.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation101.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation101.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation101.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation101.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation110.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation110.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation110.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation110.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation111.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation111.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation111.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelation111.bpel Thu May 27 18:09:53 2010
@@ -37,7 +37,7 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($input.payload, '-b')</bpws:from>
@@ -50,7 +50,7 @@
     </bpws:assign>
 
     <bpws:invoke partnerLink="client" operation="opIn" inputVariable="input"/>
-    
+
 
     <bpws:assign>
       <bpws:copy>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationArtifacts.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationArtifacts.wsdl?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationArtifacts.wsdl (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationArtifacts.wsdl Thu May 27 18:09:53 2010
@@ -17,14 +17,14 @@
   ~ 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" 
+<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"/>

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB000.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB000.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB000.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB000.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB001.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB001.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB001.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB001.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB010.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB010.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB010.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB010.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB011.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB011.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB011.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB011.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB100.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB100.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB100.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB100.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB101.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB101.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB101.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB101.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB110.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB110.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB110.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB110.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB111.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB111.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB111.bpel (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/OnEventCorrelationB111.bpel Thu May 27 18:09:53 2010
@@ -38,29 +38,29 @@
         <bpws:correlation initiate="yes" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>$input.data</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
-    
+
     <bpws:receive createInstance="no" operation="opIn" partnerLink="client" portType="tns:OnEventCorrelation" variable="input">
       <bpws:correlations>
         <bpws:correlation initiate="no" set="CorrelationSet"/>
       </bpws:correlations>
     </bpws:receive>
-    
+
     <bpws:assign>
       <bpws:copy>
         <bpws:from>concat($s, $input.data)</bpws:from>
         <bpws:to>$s</bpws:to>
       </bpws:copy>
     </bpws:assign>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex1">
@@ -85,7 +85,7 @@
       </bpws:copy>
     </bpws:assign>
     <bpws:reply operation="opInOut" partnerLink="client" variable="output" messageExchange="mex1"/>
-    
+
     <bpws:wait><bpws:for>'PT1S'</bpws:for></bpws:wait>
 
     <bpws:receive createInstance="no" operation="opInOut" partnerLink="client" portType="tns:OnEventCorrelation" variable="input" messageExchange="mex2">

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/deploy.xml
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/deploy.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/deploy.xml (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/deploy.xml Thu May 27 18:09:53 2010
@@ -165,7 +165,7 @@
             <dd:service name="bpel:EPRTest" port="default" />
         </dd:provide>
     </dd:process>
-    
+
     <dd:process name="bpel:EPRTest2" fileName="EPRTest2.bpel">
         <dd:provide partnerLink="client">
             <dd:service name="bpel:EPRTest2" port="default" />

Modified: ode/trunk/jbi/src/test/resources/CommunicationJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/CommunicationJbiTest/smx.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/CommunicationJbiTest/smx.xml (original)
+++ ode/trunk/jbi/src/test/resources/CommunicationJbiTest/smx.xml Thu May 27 18:09:53 2010
@@ -23,7 +23,7 @@
        xmlns:util="http://www.springframework.org/schema/util"
        xmlns:jencks="http://jencks.org/2.0"
        xmlns:mws="http://ode/bpel/unit-test.wsdl"
-       xmlns:ws="http://playmobile.pl/process/mnpm/portIn" 
+       xmlns:ws="http://playmobile.pl/process/mnpm/portIn"
        xmlns:sem="http://playmobile.pl/service/mnpm"
        xmlns:bpel="http://sample.bpel.org/bpel/sample"
        >
@@ -32,9 +32,9 @@
         <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
     </util:map>
 
-    <sm:container 
-        id="jbi" 
-        embedded="true" 
+    <sm:container
+        id="jbi"
+        embedded="true"
         rootDir="target/test/smx"
         transactionManager="#transactionManager"
         depends-on="jndi"
@@ -93,10 +93,10 @@
                 <sm:component>
                     <http:component>
                         <http:endpoints>
-                            <http:endpoint 
+                            <http:endpoint
                                 service="bpel:EPRTest2"
-                                endpoint="http" 
-                                role="consumer" 
+                                endpoint="http"
+                                role="consumer"
                                 locationURI="http://localhost:8198/EPRTest2/"
                                 defaultMep="http://www.w3.org/2004/08/wsdl/in-out"
                                 defaultOperation="opInOut"

Modified: ode/trunk/jbi/src/test/resources/DigestJbiTest/smx.xml
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/DigestJbiTest/smx.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/DigestJbiTest/smx.xml (original)
+++ ode/trunk/jbi/src/test/resources/DigestJbiTest/smx.xml Thu May 27 18:09:53 2010
@@ -29,9 +29,9 @@
         <entry key="java:comp/env/jdbc/ode" value-ref="odeDS"/>
     </util:map>
 
-    <sm:container 
-        id="jbi" 
-        embedded="true" 
+    <sm:container
+        id="jbi"
+        embedded="true"
         rootDir="target/test/smx"
         transactionManager="#transactionManager"
         depends-on="jndi"

Modified: ode/trunk/jbi/src/test/resources/DigestJbiTest/v1-1/OnEventCorrelation.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/jbi/src/test/resources/DigestJbiTest/v1-1/OnEventCorrelation.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/jbi/src/test/resources/DigestJbiTest/v1-1/OnEventCorrelation.bpel (original)
+++ ode/trunk/jbi/src/test/resources/DigestJbiTest/v1-1/OnEventCorrelation.bpel Thu May 27 18:09:53 2010
@@ -47,8 +47,8 @@
           </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"/>