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 [10/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/axis2-war/src/test/resources/test-log4j.properties
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/resources/test-log4j.properties?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/resources/test-log4j.properties (original)
+++ ode/trunk/axis2-war/src/test/resources/test-log4j.properties Thu May 27 18:09:53 2010
@@ -1,18 +1,18 @@
-# 
+#
 # 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.
 #
@@ -27,11 +27,11 @@ log4j.rootLogger=INFO, file
 log4j.appender.file=org.apache.log4j.FileAppender
 log4j.appender.file.File=target/test/test.log
 log4j.appender.file.layout=org.apache.log4j.PatternLayout
-log4j.appender.file.layout.ConversionPattern=%d{MM-dd@HH:mm:ss} %-5p (%13F:%L) %3x - %m%n 
+log4j.appender.file.layout.ConversionPattern=%d{MM-dd@HH:mm:ss} %-5p (%13F:%L) %3x - %m%n
 
 log4j.appender.stdout=org.apache.log4j.ConsoleAppender
 log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
-log4j.appender.stdout.layout.ConversionPattern=%d{MM-dd@HH:mm:ss} %-5p (%13F:%L) %3x - %m%n 
+log4j.appender.stdout.layout.ConversionPattern=%d{MM-dd@HH:mm:ss} %-5p (%13F:%L) %3x - %m%n
 
 log4j.category.httpclient=INFO
 log4j.category.httpclient.Wire=INFO

Modified: ode/trunk/axis2-war/src/test/webapp/WEB-INF/test-schedules.xml
URL: http://svn.apache.org/viewvc/ode/trunk/axis2-war/src/test/webapp/WEB-INF/test-schedules.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2-war/src/test/webapp/WEB-INF/test-schedules.xml (original)
+++ ode/trunk/axis2-war/src/test/webapp/WEB-INF/test-schedules.xml Thu May 27 18:09:53 2010
@@ -18,7 +18,7 @@
   ~ under the License.
   -->
 
-<sched:schedules 
+<sched:schedules
         xmlns:sched="http://www.apache.org/ode/schemas/schedules/2009/05"
         xmlns:dd="http://www.apache.org/ode/schemas/dd/2007/03">
     <sched:schedule when="* * * * * ?">

Modified: ode/trunk/axis2/pom.xml
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/pom.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/pom.xml (original)
+++ ode/trunk/axis2/pom.xml Thu May 27 18:09:53 2010
@@ -28,11 +28,11 @@
         <artifactId>ode</artifactId>
         <version>1.3.5-SNAPSHOT</version>
     </parent>
-    
+
     <properties>
         <servlet.version>2.4</servlet.version>
     </properties>
-     
+
     <dependencies>
         <dependency>
             <groupId>org.apache.ode</groupId>

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/BindingContextImpl.java Thu May 27 18:09:53 2010
@@ -114,7 +114,7 @@ public class BindingContextImpl implemen
         }
         return 0;
     }
-    
+
     protected ODEService createService(ProcessConf pconf, QName serviceName, String portName) throws AxisFault {
         AxisService axisService = ODEAxisService.createService(_server._axisConfig, pconf, serviceName, portName);
         ODEService odeService = new ODEService(axisService, pconf, serviceName, portName, _server._bpelServer, _server._txMgr);

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEConfigProperties.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEConfigProperties.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEConfigProperties.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEConfigProperties.java Thu May 27 18:09:53 2010
@@ -27,7 +27,7 @@ public class ODEConfigProperties extends
 
     private static final long serialVersionUID = 1L;
     private static final String CONFIG_FILE_NAME = "ode-axis2.properties";
-        
+
 
     public ODEConfigProperties(File installRoot) {
         super(new File(installRoot, ODEConfigProperties.CONFIG_FILE_NAME),"ode-axis2.");

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEServer.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEServer.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEServer.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEServer.java Thu May 27 18:09:53 2010
@@ -113,7 +113,7 @@ public class ODEServer {
     protected ExecutorService _executorService;
 
     protected Scheduler _scheduler;
-    
+
     protected CronScheduler _cronScheduler;
 
     protected Database _db;
@@ -123,12 +123,12 @@ public class ODEServer {
     private BpelServerConnector _connector;
 
     private ManagementService _mgtService;
-    
+
     protected ClusterUrlTransformer _clusterUrlTransformer;
 
     protected MultiThreadedHttpConnectionManager httpConnectionManager;
     protected IdleConnectionTimeoutThread idleConnectionTimeoutThread;
-    
+
     public void init(ServletConfig config, AxisConfiguration axisConf) throws ServletException {
         init(config.getServletContext().getRealPath("/WEB-INF"), axisConf);
     }
@@ -174,7 +174,7 @@ public class ODEServer {
         initDataSource();
         __log.debug("Starting DAO.");
         initDAO();
-        EndpointReferenceContextImpl eprContext = new EndpointReferenceContextImpl(this);            
+        EndpointReferenceContextImpl eprContext = new EndpointReferenceContextImpl(this);
         __log.debug("Initializing BPEL process store.");
         initProcessStore(eprContext);
         __log.debug("Initializing BPEL server.");
@@ -226,7 +226,7 @@ public class ODEServer {
     @SuppressWarnings("unchecked")
     private DeploymentPoller getDeploymentPollerExt() {
         DeploymentPoller poller = null;
-        
+
         InputStream is = null;
         try {
             is = ODEServer.class.getResourceAsStream("/deploy-ext.properties");
@@ -257,7 +257,7 @@ public class ODEServer {
 
         return poller;
     }
-    
+
     private void initDataSource() throws ServletException {
         _db = new Database(_odeConfig);
         _db.setTransactionManager(_txMgr);
@@ -311,7 +311,7 @@ public class ODEServer {
                     __log.debug("Cron scheduler couldn't be shutdown.", ex);
                 }
             }
-            
+
             if (_scheduler != null)
                 try {
                     __log.debug("shutting down scheduler.");
@@ -457,7 +457,7 @@ public class ODEServer {
     }
 
     protected Scheduler createScheduler() {
-        SimpleScheduler scheduler = new SimpleScheduler(new GUID().toString(), 
+        SimpleScheduler scheduler = new SimpleScheduler(new GUID().toString(),
                 new JdbcDelegate(_db.getDataSource()), _odeConfig.getProperties());
         scheduler.setExecutorService(_executorService);
         scheduler.setTransactionManager(_txMgr);
@@ -482,7 +482,7 @@ public class ODEServer {
             _executorService = Executors.newCachedThreadPool(threadFactory);
         else
             _executorService = Executors.newFixedThreadPool(_odeConfig.getThreadPoolMaxSize(), threadFactory);
-        
+
         {
             List<String> targets = new ArrayList<String>();
             Collections.addAll(targets, _odeConfig.getProperty("cluster.localRoute.targets", "").split(","));
@@ -491,12 +491,12 @@ public class ODEServer {
         _bpelServer = new BpelServerImpl();
         _scheduler = createScheduler();
         _scheduler.setJobProcessor(_bpelServer);
-        
+
         BpelServerImpl.PolledRunnableProcessor polledRunnableProcessor = new BpelServerImpl.PolledRunnableProcessor();
         polledRunnableProcessor.setPolledRunnableExecutorService(_executorService);
         polledRunnableProcessor.setContexts(_bpelServer.getContexts());
         _scheduler.setPolledRunnableProcesser(polledRunnableProcessor);
-        
+
         _cronScheduler = new CronScheduler();
         _cronScheduler.setScheduledTaskExec(_executorService);
         _cronScheduler.setContexts(_bpelServer.getContexts());
@@ -582,7 +582,7 @@ public class ODEServer {
     public File getConfigRoot() {
         return _configRoot;
     }
-    
+
     private void registerEventListeners() {
         String listenersStr = _odeConfig.getEventListeners();
         if (listenersStr != null) {
@@ -640,7 +640,7 @@ public class ODEServer {
                 if (pconf != null) {
                     /*
                      * If and only if an old process exists with the same pid, the old process is cleaned up.
-                     * The following line is IMPORTANT and used for the case when the deployment and store 
+                     * The following line is IMPORTANT and used for the case when the deployment and store
                      * do not have the process while the process itself exists in the BPEL_PROCESS table.
                      * Notice that the new process is actually created on the 'ACTIVATED' event.
                      */
@@ -653,21 +653,21 @@ public class ODEServer {
                 if (pconf != null) {
                     _bpelServer.register(pconf);
                 } else {
-                    __log.debug("slighly odd: recevied event " + 
+                    __log.debug("slighly odd: recevied event " +
                             pse + " for process not in store!");
                 }
                 break;
             case RETIRED:
-                // are there are instances of this process running? 
+                // are there are instances of this process running?
                 boolean instantiated = _bpelServer.hasActiveInstances(pse.pid);
                 // remove the process
                 _bpelServer.unregister(pse.pid);
-                // bounce the process if necessary  
+                // bounce the process if necessary
                 if (instantiated) {
                     if (pconf != null) {
                         _bpelServer.register(pconf);
                     } else {
-                        __log.debug("slighly odd: recevied event " + 
+                        __log.debug("slighly odd: recevied event " +
                                 pse + " for process not in store!");
                     }
                 } else {
@@ -688,7 +688,7 @@ public class ODEServer {
             default:
                 __log.debug("Ignoring store event: " + pse);
         }
-        
+
         if( pconf != null ) {
             if( pse.type == ProcessStoreEvent.Type.UNDEPLOYED) {
                 __log.debug("Cancelling all cron scheduled jobs on store event: " + pse);
@@ -702,7 +702,7 @@ public class ODEServer {
             }
         }
     }
-    
+
     // Transactional debugging stuff, to track down all these little annoying bugs.
     private class DebugTxMgr implements TransactionManager {
         private TransactionManager _tm;

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEService.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEService.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEService.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/ODEService.java Thu May 27 18:09:53 2010
@@ -91,11 +91,11 @@ public class ODEService {
         _converter = new SoapMessageConverter(_wsdlDef, serviceName, portName);
 
     }
-    
+
     public String getName() {
         return _axisService.getName();
     }
-    
+
     public void onAxisMessageExchange(MessageContext msgContext, MessageContext outMsgContext, SOAPFactory soapFactory)
             throws AxisFault {
         boolean success = true;
@@ -293,7 +293,7 @@ public class ODEService {
                 odeMex.setProperty(MessageExchange.PROPERTY_SEP_MYROLE_SESSIONID, endpoint.getSessionId());
             }
         }
-        
+
         Object ocse = msgContext.getProperty("callbackSessionEndpoint");
         if (ocse != null) {
             Element serviceEpr = (Element) ocse;
@@ -322,7 +322,7 @@ public class ODEService {
         // endpoint in this case, except that it is updated with session
         // information (if available).
         if (odeMex.getProperty(MessageExchange.PROPERTY_SEP_MYROLE_SESSIONID) != null) {
-            WSAEndpoint sessionAwareEndPoint = new WSAEndpoint(_serviceRef); 
+            WSAEndpoint sessionAwareEndPoint = new WSAEndpoint(_serviceRef);
             sessionAwareEndPoint.setSessionId(odeMex.getProperty(MessageExchange.PROPERTY_SEP_MYROLE_SESSIONID));
             msgContext.setProperty("callbackSessionEndpoint", sessionAwareEndPoint);
         }

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/SoapExternalService.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/SoapExternalService.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/SoapExternalService.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/SoapExternalService.java Thu May 27 18:09:53 2010
@@ -167,8 +167,8 @@ public class SoapExternalService impleme
             }else{
                 if (__log.isDebugEnabled()) __log.debug("Endpoint URL overridden by process. "+endpointUrl+" => "+mexEndpointUrl);
             }
-            
-            
+
+
             axisEPR.setAddress(_clusterUrlTransformer.rewriteOutgoingClusterURL(axisEPR.getAddress()));
 
             if (__log.isDebugEnabled()) {

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/deploy/DeploymentPoller.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/deploy/DeploymentPoller.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/deploy/DeploymentPoller.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/deploy/DeploymentPoller.java Thu May 27 18:09:53 2010
@@ -71,9 +71,9 @@ public class DeploymentPoller {
     protected ODEServer _odeServer;
 
     private boolean _onHold = false;
-    
+
     private SystemSchedulesConfig _systemSchedulesConf;
-    
+
     @SuppressWarnings("unchecked")
     private Map<String, WatchDog> dDWatchDogsByPath = new HashMap<String, WatchDog>();
     @SuppressWarnings("unchecked")
@@ -137,25 +137,25 @@ public class DeploymentPoller {
                 }
 
                 WatchDog ddWatchDog = ensureDeployXmlWatchDog(file, deployXml);
-                
+
                 if (deployedMarker.exists()) {
                     checkDeployXmlWatchDog(ddWatchDog);
                     continue;
                 }
-    
+
                 try {
                     deployedMarker.createNewFile();
                 } catch (IOException e1) {
                     __log.error("Error creating deployed marker file, " + file + " will not be deployed");
                     continue;
                 }
-    
+
                 try {
                     _odeServer.getProcessStore().undeploy(file);
                 } catch (Exception ex) {
                     __log.error("Error undeploying " + file.getName());
                 }
-    
+
                 try {
                     Collection<QName> deployed = _odeServer.getProcessStore().deploy(file);
                     __log.info("Deployment of artifact " + file.getName() + " successful: " + deployed );
@@ -178,7 +178,7 @@ public class DeploymentPoller {
                     __log.info("Successfully undeployed " + pkg);
             }
         }
-        
+
         checkSystemCronConfigWatchDog(_systemCronConfigWatchDog);
     }
 
@@ -189,7 +189,7 @@ public class DeploymentPoller {
             ddWatchDog = WatchDog.watchFile(deployXml, new DDWatchDogObserver(deployFolder.getName()));
             dDWatchDogsByPath.put(deployXml.getAbsolutePath(), ddWatchDog);
         }
-        
+
         return ddWatchDog;
     }
 
@@ -205,17 +205,17 @@ public class DeploymentPoller {
     protected SystemSchedulesConfig createSystemSchedulesConfig(File configRoot) {
         return new SystemSchedulesConfig(configRoot);
     }
-    
+
     @SuppressWarnings("unchecked")
     protected WatchDog createSystemCronConfigWatchDog(final CronScheduler cronScheduler) {
-        return WatchDog.watchFile(_systemSchedulesConf.getSchedulesFile(), 
+        return WatchDog.watchFile(_systemSchedulesConf.getSchedulesFile(),
             new WatchDog.DefaultObserver() {
                 public void init() {
                     cronScheduler.refreshSystemCronJobs(_systemSchedulesConf);
                 }
             });
     }
-    
+
     @SuppressWarnings("unchecked")
     protected void checkSystemCronConfigWatchDog(WatchDog ddWatchDog) {
         ddWatchDog.check();
@@ -230,7 +230,7 @@ public class DeploymentPoller {
         public PollingThread() {
             setName("DeploymentPoller");
         }
-        
+
         /** Stop this poller, and block until it terminates. */
         void kill() {
             synchronized (this) {
@@ -287,11 +287,11 @@ public class DeploymentPoller {
     @SuppressWarnings("unchecked")
     protected class DDWatchDogObserver extends WatchDog.DefaultObserver {
         private String deploymentPakage;
-        
+
         public DDWatchDogObserver(String deploymentPakage) {
             this.deploymentPakage = deploymentPakage;
         }
-        
+
         public void init() {
             _odeServer.getProcessStore().refreshSchedules(deploymentPakage);
         }

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisService.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisService.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisService.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisService.java Thu May 27 18:09:53 2010
@@ -91,7 +91,7 @@ public class ODEAxisService {
             axisService.setWsdlFound(true);
             axisService.setCustomWsdl(true);
             axisService.setClassLoader(axisConfig.getServiceClassLoader());
-        
+
             URL wsdlUrl = null;
             for (File file : pconf.getFiles()) {
                 if (file.getAbsolutePath().indexOf(wsdlDefinition.getDocumentBaseURI()) > 0)
@@ -99,7 +99,7 @@ public class ODEAxisService {
             }
             if (wsdlUrl != null) axisService.setFileName(wsdlUrl);
 
-            // axis2 service configuration  
+            // axis2 service configuration
             URL service_file = pconf.getBaseURI().resolve(wsdlServiceName.getLocalPart()+".axis2").toURL();
             LOG.debug("Looking for Axis2 service configuration file: "+service_file);
             try {
@@ -129,10 +129,10 @@ public class ODEAxisService {
                     operation.setMessageReceiver(msgReceiver);
                 }
             }
-            
+
             // Set the JMS destination name on the Axis Service
             if (isJmsEndpoint(pconf, wsdlServiceName, portName)) {
-                axisService.addParameter(new Parameter(JMSConstants.PARAM_DESTINATION, 
+                axisService.addParameter(new Parameter(JMSConstants.PARAM_DESTINATION,
                         extractJMSDestinationName(axisServiceName, deriveBaseServiceUri(pconf))));
             }
 
@@ -187,7 +187,7 @@ public class ODEAxisService {
         return axisService;
     }
 
-    private static String extractEndpointUri(ProcessConf pconf, QName wsdlServiceName, String portName) 
+    private static String extractEndpointUri(ProcessConf pconf, QName wsdlServiceName, String portName)
             throws AxisFault {
         Definition wsdlDefinition = pconf.getDefinitionForService(wsdlServiceName);
         String url = null;
@@ -207,16 +207,16 @@ public class ODEAxisService {
         if (url == null) {
             throw new OdeFault("Could not extract any soap:address from service WSDL definition " + wsdlServiceName
                     + " (necessary to establish the process target address)!");
-        }       
+        }
         return url;
     }
-    
-    private static boolean isJmsEndpoint(ProcessConf pconf, QName wsdlServiceName, String portName) 
+
+    private static boolean isJmsEndpoint(ProcessConf pconf, QName wsdlServiceName, String portName)
             throws AxisFault {
         String url = extractEndpointUri(pconf, wsdlServiceName, portName);
         return url.startsWith("jms:");
     }
-    
+
     private static String extractServiceName(ProcessConf pconf, QName wsdlServiceName, String portName)
             throws AxisFault {
         String endpointUri = extractEndpointUri(pconf, wsdlServiceName, portName);
@@ -236,7 +236,7 @@ public class ODEAxisService {
     protected static String parseURLForService(String path, String baseUri) {
         // Assume that path is HTTP-based, by default
         String servicePrefix = "/processes/";
-        // Don't assume JMS-based paths start the same way 
+        // Don't assume JMS-based paths start the same way
         if (path.startsWith("jms:/")) {
             servicePrefix = "jms:/";
         }
@@ -316,7 +316,7 @@ public class ODEAxisService {
      * Generates a URI of the following form:
      *     ${deploy_bundleNcName}/${diagram_relativeURL}/${process_relativeURL}
      * When a service name (local part only) is qualified (prefixed) with the above,
-     * it results in a unique identifier that may be used as that service's name.  
+     * it results in a unique identifier that may be used as that service's name.
      */
     public static String deriveBaseServiceUri(ProcessConf pconf) {
         if (pconf != null) {
@@ -330,7 +330,7 @@ public class ODEAxisService {
                         bpelDocumentName = bpelDocumentName.substring(0, bpelDocumentName.indexOf("."));
                     }
                     baseServiceUri.append(bpelDocumentName).append("/");
-                    String processName = pconf.getType() != null 
+                    String processName = pconf.getType() != null
                         ? pconf.getType().getLocalPart() : null;
                     if (processName != null) {
                         baseServiceUri.append(processName);
@@ -338,7 +338,7 @@ public class ODEAxisService {
                     }
                 }
             }
-            
+
         }
         return null;
     }

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisServiceDispatcher.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisServiceDispatcher.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisServiceDispatcher.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/ODEAxisServiceDispatcher.java Thu May 27 18:09:53 2010
@@ -69,7 +69,7 @@ public class ODEAxisServiceDispatcher ex
             // HACK: Redirect legacy endpoints
             String address = toEPR.getAddress();
             if (address != null) address = address.replace("/ode/services/", "/ode/processes/");
-            
+
             // The only thing we understand if a service name that
             // follows /processes/ in the request URL.
             String path = parseRequestURLForService(address);

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/SessionOutHandler.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/SessionOutHandler.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/SessionOutHandler.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/hooks/SessionOutHandler.java Thu May 27 18:09:53 2010
@@ -69,16 +69,16 @@ public class SessionOutHandler extends A
             if (header == null) {
                 header = factory.createSOAPHeader(messageContext.getEnvelope());
             }
-            
+
             if (otargetSession != null && otargetSession instanceof MutableEndpoint) {
 
                 WSAEndpoint targetEpr = EndpointFactory.convertToWSA((MutableEndpoint) otargetSession);
-                
+
                 OMElement to = factory.createSOAPHeaderBlock("To", wsAddrNS);
                 header.addChild(to);
                 to.setText(targetEpr.getUrl());
 
-                String action = messageContext.getSoapAction(); 
+                String action = messageContext.getSoapAction();
                 OMElement wsaAction = factory.createSOAPHeaderBlock("Action", wsAddrNS);
                 header.addChild(wsaAction);
                 wsaAction.setText(action);
@@ -91,13 +91,13 @@ public class SessionOutHandler extends A
                     replyTo.addChild(address);
                     header.addChild(replyTo);
                     address.setText(replyToEpr.getAddress());
-                    
+
                     String messageId = messageContext.getMessageID();
                     OMElement messageIdElem = factory.createSOAPHeaderBlock("MessageID", wsAddrNS);
                     header.addChild(messageIdElem);
-                    messageIdElem.setText(messageId);                
+                    messageIdElem.setText(messageId);
                 }
-                
+
                 if (targetEpr.getSessionId() != null) {
                     OMElement session = factory.createSOAPHeaderBlock("session", odeSessNS);
                     header.addChild(session);

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpExternalService.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpExternalService.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpExternalService.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpExternalService.java Thu May 27 18:09:53 2010
@@ -170,7 +170,7 @@ public class HttpExternalService impleme
             }
 
             baseUrl = clusterUrlTransformer.rewriteOutgoingClusterURL(baseUrl);
-            
+
             // build the http method
             final HttpMethod method = httpMethodConverter.createHttpRequest(odeMex, params, baseUrl);
 

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpHelper.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpHelper.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpHelper.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpHelper.java Thu May 27 18:09:53 2010
@@ -64,8 +64,8 @@ public class HttpHelper {
         */
         client.getParams().setDefaults(params);
 
-        // Here we make sure HttpClient will not handle the default headers. 
-        // Actually HttpClient *appends* default headers while we want them to be ignored if the process assign them 
+        // Here we make sure HttpClient will not handle the default headers.
+        // Actually HttpClient *appends* default headers while we want them to be ignored if the process assign them
         client.getParams().setParameter(HostParams.DEFAULT_HEADERS, Collections.EMPTY_LIST);
 
         // proxy configuration

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpMethodConverter.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpMethodConverter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpMethodConverter.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/HttpMethodConverter.java Thu May 27 18:09:53 2010
@@ -93,7 +93,7 @@ public class HttpMethodConverter {
     public HttpMethod createHttpRequest(PartnerRoleMessageExchange odeMex, HttpParams params) throws UnsupportedEncodingException {
         return createHttpRequest(odeMex, params, ((MutableEndpoint) odeMex.getEndpointReference()).getUrl());
     }
-    
+
     public HttpMethod createHttpRequest(PartnerRoleMessageExchange odeMex, HttpParams params, String baseUrl) throws UnsupportedEncodingException {
         Operation operation = odeMex.getOperation();
         BindingOperation bindingOperation = binding.getBindingOperation(operation.getName(), operation.getInput().getName(), operation.getOutput().getName());
@@ -437,7 +437,7 @@ public class HttpMethodConverter {
             Part part = messageDef.getPart(partName);
             if (StringUtils.isNotEmpty(partName)) {
                 Header responseHeader = method.getResponseHeader(headerName);
-                // if the response header is not set, just skip it. no need to fail. 
+                // if the response header is not set, just skip it. no need to fail.
                 if (responseHeader != null) {
                     odeMessage.setPart(partName, createPartElement(part, responseHeader.getValue()));
                 }

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/Messages.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/Messages.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/Messages.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/Messages.java Thu May 27 18:09:53 2010
@@ -58,7 +58,7 @@ public class Messages extends MessageBun
     public String msgInvalidURIPattern(Binding binding, BindingOperation operation, String locationUri) {
         return format("Invalid URI Pattern : parts must not be mentioned more than once! binding:{0}, operation:{1}, locationUri:{2}", binding.getQName(), operation.getName(), locationUri);
     }
-    
+
     public String msgMimeMultipartRelatedUnsupported(Binding binding, BindingOperation operation) {
         return format("MimeMultipartRelated is not supported! binding:{0}, operation:{1}", binding.getQName(), operation.getName());
     }

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/ProxyConf.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/ProxyConf.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/ProxyConf.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/httpbinding/ProxyConf.java Thu May 27 18:09:53 2010
@@ -77,7 +77,7 @@ public class ProxyConf {
 
     /**
      * @return true if a proxy is set in the params, or in the system property "http.proxyHost"
-     * and the host is not mentionnned in the system property "http.nonProxyHosts"  
+     * and the host is not mentionnned in the system property "http.nonProxyHosts"
      * @see Properties#PROP_HTTP_PROXY_PREFIX
      */
     public static boolean isProxyEnabled(HttpParams params, String targetHost) throws URIException {

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentBrowser.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentBrowser.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentBrowser.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentBrowser.java Thu May 27 18:09:53 2010
@@ -38,7 +38,7 @@ import java.util.ArrayList;
 
 /**
  * handles a set of URLs all starting with /deployment to publish all files in
- * deployed bundles, services and processes. 
+ * deployed bundles, services and processes.
  */
 public class DeploymentBrowser {
 
@@ -58,7 +58,7 @@ public class DeploymentBrowser {
         final String requestURI = request.getRequestURI();
         final int deplUri = requestURI.indexOf("/deployment");
         if (deplUri > 0) {
-            final String root = request.getScheme() + "://" + request.getServerName() + 
+            final String root = request.getScheme() + "://" + request.getServerName() +
                     ":" + request.getServerPort() + requestURI.substring(0, deplUri);
             int offset = requestURI.length() > (deplUri + 11) ? 1 : 0;
             final String[] segments = requestURI.substring(deplUri + 11 + offset).split("/");
@@ -206,7 +206,7 @@ public class DeploymentBrowser {
                                     out.write("<getBundleDocsResponse><name>"+ bundleName +"</name>");
                                     //final List<File> files = _store.getProcessConfiguration(processes.get(0)).getFiles();
                                     //final String pid = _store.getProcessConfiguration(processes.get(0)).getProcessId().toString();
-                            
+
                                     for (final QName process: processes) {
                                         List<File> files = _store.getProcessConfiguration(process).getFiles();
                                         String pid = _store.getProcessConfiguration(process).getProcessId().toString();
@@ -214,20 +214,20 @@ public class DeploymentBrowser {
                                         for (final File file : files) {
                                             if (file.getPath().endsWith(".wsdl")) {
                                                 String relativePath = file.getPath().substring(_store.getDeployDir().getCanonicalPath().length() + 1);
-                                                out.write("<wsdl>"+ relativePath + "</wsdl>");                                      
+                                                out.write("<wsdl>"+ relativePath + "</wsdl>");
                                             }
-                                            if (file.getPath().endsWith(".bpel")) { 
+                                            if (file.getPath().endsWith(".bpel")) {
                                                 String relativePath = file.getPath().substring(_store.getDeployDir().getCanonicalPath().length() + 1);
                                                 out.write("<bpel>"+ relativePath + "</bpel>");
                                             }
-                                            
+
                                         }
                                         out.write("</process>");
-                                    }                                   
+                                    }
                                     out.write("</getBundleDocsResponse>");
                                 }
                             });
-                            
+
                         }
                     }
                 } else if ("getProcessDefinition".equals(segments[0])) {
@@ -240,7 +240,7 @@ public class DeploymentBrowser {
                             }
                         });
                     } else if (segments.length == 2) {
-                        String processName = segments[1]; 
+                        String processName = segments[1];
                         for (QName process :_store.getProcesses()) {
                             String[] nameVer = process.getLocalPart().split("-");
                             if(processName.equals(nameVer[0])) {
@@ -254,7 +254,7 @@ public class DeploymentBrowser {
                                 });
                             }
                         }
-                        
+
                     }
                 }
             }
@@ -276,7 +276,7 @@ public class DeploymentBrowser {
         out.write("</body></html>");
     }
     private void renderXml(HttpServletResponse response, DocBody docBody) throws IOException {
-        response.setContentType("application/xml; charset=utf-8");  
+        response.setContentType("application/xml; charset=utf-8");
         //response.setContentType("application/xml");
         //response.setCharacterEncoding("UTF-8");
 

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentWebService.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentWebService.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentWebService.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/service/DeploymentWebService.java Thu May 27 18:09:53 2010
@@ -78,8 +78,8 @@ public class DeploymentWebService {
     private File _deployPath;
     private DeploymentPoller _poller;
     private ProcessStore _store;
-   
-    
+
+
     public DeploymentWebService() {
         _pmapi = OMAbstractFactory.getOMFactory().createOMNamespace("http://www.apache.org/ode/pmapi","pmapi");
         _deployapi = OMAbstractFactory.getOMFactory().createOMNamespace("http://www.apache.org/ode/deployapi","deployapi");
@@ -148,7 +148,7 @@ public class DeploymentWebService {
                     }
 
                     if (zip == null || packagePart == null)
-                        throw new OdeFault("Your message should contain an element named 'package' with a 'zip' element"); 
+                        throw new OdeFault("Your message should contain an element named 'package' with a 'zip' element");
 
                     String bundleName = namePart.getText().trim();
                     if (!validBundleName(namePart.getText()))

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/ClusterUrlTransformer.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/ClusterUrlTransformer.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/ClusterUrlTransformer.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/ClusterUrlTransformer.java Thu May 27 18:09:53 2010
@@ -29,7 +29,7 @@ public class ClusterUrlTransformer {
 
     private final List<String> targets;
     private final String base;
-    
+
     public ClusterUrlTransformer(List<String> targets, String base) {
         super();
         this.targets = targets;

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/JBossFactory.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/JBossFactory.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/JBossFactory.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/JBossFactory.java Thu May 27 18:09:53 2010
@@ -26,7 +26,7 @@ import javax.transaction.TransactionMana
 public class JBossFactory {
 
     public static final String JNDI_LOOKUP_PATH = "java:/TransactionManager";
-    
+
     /* Public no-arg contructor is required */
     public JBossFactory() {
     }

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/SoapMessageConverter.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/SoapMessageConverter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/SoapMessageConverter.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/SoapMessageConverter.java Thu May 27 18:09:53 2010
@@ -474,12 +474,12 @@ public class SoapMessageConverter {
         return ee.isEmpty() ? null : ee.iterator().next();
 
     }
-    
+
     /**
      * Attempts to extract the WS-Addressing "Action" attribute value from the operation definition.
-     * When WS-Addressing is being used by a service provider, the "Action" is specified in the 
-     * portType->operation instead of the SOAP binding->operation.  
-     * 
+     * When WS-Addressing is being used by a service provider, the "Action" is specified in the
+     * portType->operation instead of the SOAP binding->operation.
+     *
      * @param operation The name of the operation to extract the SOAP Action from
      * @return the SOAPAction value if one is specified, otherwise empty string
      */
@@ -512,7 +512,7 @@ public class SoapMessageConverter {
 
         return "";
     }
-    
+
     public Fault parseSoapFault(Element odeMsgEl, SOAPEnvelope envelope, Operation operation) throws AxisFault {
         SOAPFault flt = envelope.getBody().getFault();
         SOAPFaultDetail detail = flt.getDetail();

Modified: ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/WLSFactory.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/WLSFactory.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/WLSFactory.java (original)
+++ ode/trunk/axis2/src/main/java/org/apache/ode/axis2/util/WLSFactory.java Thu May 27 18:09:53 2010
@@ -16,7 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
- 
+
 package org.apache.ode.axis2.util;
 
 import java.util.Hashtable;

Modified: ode/trunk/axis2/src/main/wsdl/xmlmime.xsd
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/main/wsdl/xmlmime.xsd?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/main/wsdl/xmlmime.xsd (original)
+++ ode/trunk/axis2/src/main/wsdl/xmlmime.xsd Thu May 27 18:09:53 2010
@@ -17,19 +17,19 @@
   ~ specific language governing permissions and limitations
   ~ under the License.
   -->
-<!-- 
+<!--
    W3C XML Schema defined in the Describing Media Content of Binary Data in XML
    specification
      http://www.w3.org/TR/xml-media-types
 
    Copyright © 2005 World Wide Web Consortium,
-  
+
    (Massachusetts Institute of Technology, European Research Consortium for
    Informatics and Mathematics, Keio University). All Rights Reserved. This
    work is distributed under the W3C® Software License [1] in the hope that
    it will be useful, but WITHOUT ANY WARRANTY; without even the implied
    warranty of MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.
-  
+
    [1] http://www.w3.org/Consortium/Legal/2002/copyright-software-20021231
 
    $Id: xmlmime.xsd,v 1.1 2005/04/25 17:08:35 hugo Exp $

Modified: ode/trunk/axis2/src/test/java/org/apache/ode/axis2/SoapMessageConverterTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/test/java/org/apache/ode/axis2/SoapMessageConverterTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/test/java/org/apache/ode/axis2/SoapMessageConverterTest.java (original)
+++ ode/trunk/axis2/src/test/java/org/apache/ode/axis2/SoapMessageConverterTest.java Thu May 27 18:09:53 2010
@@ -133,7 +133,7 @@ public class SoapMessageConverterTest ex
         odeMsg1.setHeaderPart("DocumentumRequestHeader", DOMUtils.findChildByName(req1.getDocumentElement(),
                 new QName("http://documentum.com/ws/2005/services", "DocumentumSecurityToken")));
         portmapper.createSoapRequest(msgCtx, odeMsg1, op1);
-        
+
         SOAPEnvelope env = msgCtx.getEnvelope();
         System.out.println("testParseRequest: " + env);
         Element odeMsgElmt = DOMUtils.stringToDOM("<message/>");

Modified: ode/trunk/axis2/src/test/resources/HelloWorld.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/test/resources/HelloWorld.wsdl?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/test/resources/HelloWorld.wsdl (original)
+++ ode/trunk/axis2/src/test/resources/HelloWorld.wsdl Thu May 27 18:09:53 2010
@@ -18,27 +18,27 @@
   ~ under the License.
   -->
 
-<wsdl:definitions 
+<wsdl:definitions
     targetNamespace="http://ode/bpel/unit-test.wsdl"
     xmlns="http://schemas.xmlsoap.org/wsdl/"
     xmlns:tns="http://ode/bpel/unit-test.wsdl"
-    xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" 
+    xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/"
     xmlns:xsd="http://www.w3.org/2001/XMLSchema"
     xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/"
     xmlns:bpws="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
     xmlns:plnk="http://schemas.xmlsoap.org/ws/2004/03/partner-link/">
-    
+
     <wsdl:message name="HelloMessage">
         <wsdl:part name="TestPart" type="xsd:string"/>
     </wsdl:message>
-    
+
     <wsdl:portType name="HelloPortType">
         <wsdl:operation name="hello">
             <wsdl:input message="tns:HelloMessage" name="TestIn"/>
             <wsdl:output message="tns:HelloMessage" name="TestOut"/>
-        </wsdl:operation>    
+        </wsdl:operation>
     </wsdl:portType>
-    
+
      <wsdl:binding name="HelloSoapBinding" type="tns:HelloPortType">
         <soap:binding style="rpc" transport="http://schemas.xmlsoap.org/soap/http"/>
         <wsdl:operation name="hello">
@@ -50,7 +50,7 @@
             </wsdl:input>
             <wsdl:output>
                 <soap:body
-                    namespace="http://ode/bpel/unit-test.wsdl" 
+                    namespace="http://ode/bpel/unit-test.wsdl"
                     use="literal"/>
             </wsdl:output>
         </wsdl:operation>
@@ -60,7 +60,7 @@
             <soap:address location="http://localhost:8080/ode/processes/helloWorld"/>
         </wsdl:port>
     </wsdl:service>
-    
+
    <plnk:partnerLinkType name="HelloPartnerLinkType">
        <plnk:role name="me" portType="tns:HelloPortType"/>
        <plnk:role name="you" portType="tns:HelloPortType"/>

Modified: ode/trunk/axis2/src/test/resources/http-method-builder.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/test/resources/http-method-builder.wsdl?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/test/resources/http-method-builder.wsdl (original)
+++ ode/trunk/axis2/src/test/resources/http-method-builder.wsdl Thu May 27 18:09:53 2010
@@ -66,7 +66,7 @@
             </wsdl:output>
         </wsdl:operation>
     </wsdl:binding>
-    
+
 
     <wsdl:types>
         <xsd:schema xmlns:ns="http://axis2.ode.apache.org" attributeFormDefault="qualified"

Modified: ode/trunk/axis2/src/test/resources/testRequest1.xml
URL: http://svn.apache.org/viewvc/ode/trunk/axis2/src/test/resources/testRequest1.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/axis2/src/test/resources/testRequest1.xml (original)
+++ ode/trunk/axis2/src/test/resources/testRequest1.xml Thu May 27 18:09:53 2010
@@ -23,7 +23,7 @@
           <barbaz xmlns="" />
       </getObjectId>
    </parameters>
-   
+
     <DocumentumSecurityToken xmlns="http://documentum.com/ws/2005/services">SEKREET</DocumentumSecurityToken>
 
 </message>
\ No newline at end of file

Modified: ode/trunk/bpel-api-jca/src/main/java/org/apache/ode/bpel/jca/clientapi/ProcessManagementConnection.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api-jca/src/main/java/org/apache/ode/bpel/jca/clientapi/ProcessManagementConnection.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api-jca/src/main/java/org/apache/ode/bpel/jca/clientapi/ProcessManagementConnection.java (original)
+++ ode/trunk/bpel-api-jca/src/main/java/org/apache/ode/bpel/jca/clientapi/ProcessManagementConnection.java Thu May 27 18:09:53 2010
@@ -25,11 +25,11 @@ import org.apache.ode.bpel.pmapi.Instanc
 import org.apache.ode.bpel.pmapi.ProcessManagement;
 
 /**
- * JCA {@link javax.resource.cci.Connection} interface combining process and 
+ * JCA {@link javax.resource.cci.Connection} interface combining process and
  * instance management.
  */
-public interface ProcessManagementConnection 
-  extends ProcessManagement, InstanceManagement, Connection 
+public interface ProcessManagementConnection
+  extends ProcessManagement, InstanceManagement, Connection
 {
-  
+
 }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/ActivityBreakpoint.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/ActivityBreakpoint.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/ActivityBreakpoint.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/ActivityBreakpoint.java Thu May 27 18:09:53 2010
@@ -23,11 +23,11 @@ package org.apache.ode.bpel.bdi.breaks;
  * activity completion.
  */
 public interface ActivityBreakpoint extends Breakpoint{
-  
+
   /**
    * Get the name of the activity that has been breakpointed.
    * @return the name of the activity
    */
   public String activityName();
-  
+
 }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/Breakpoint.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/Breakpoint.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/Breakpoint.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/Breakpoint.java Thu May 27 18:09:53 2010
@@ -26,7 +26,7 @@ public interface Breakpoint {
 
   /**
    * Enable or disable the break point.
-   * 
+   *
    * @param enabled
    *          if <code>true</code> enable, otherwise disable
    */
@@ -34,7 +34,7 @@ public interface Breakpoint {
 
   /**
    * Test whether the break point is enabled.
-   * 
+   *
    * @return <code>true</code> if break-point is enabled, <code>false</code>
    *         otherwise
    */

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/VariableModificationBreakpoint.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/VariableModificationBreakpoint.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/VariableModificationBreakpoint.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/bdi/breaks/VariableModificationBreakpoint.java Thu May 27 18:09:53 2010
@@ -22,14 +22,14 @@ package org.apache.ode.bpel.bdi.breaks;
  * A break point that is activated when a variable is modified.
  */
 public interface VariableModificationBreakpoint extends Breakpoint{
-  
-  /** 
-   * Get the name of the declaring scope for the variable. 
+
+  /**
+   * Get the name of the declaring scope for the variable.
    * @return the name of the scope of <code>null</code> if the scope is the process
    * itself.
    */
   public String scopeName();
-  
+
   /**
    * Get the name of the variable for which the break point is set.
    * @return the name of the variable.

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/BpelEventFilter.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/BpelEventFilter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/BpelEventFilter.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/BpelEventFilter.java Thu May 27 18:09:53 2010
@@ -69,7 +69,7 @@ public class BpelEventFilter extends Fil
    * Initializes properly the InstanceFilter attributes by pre-parsing the
    * filter and orderKeys strings and setting the limit. A limit inferior than
    * or equal to 0 is ignored.
-   * 
+   *
    * @param filter
    */
   public BpelEventFilter(String filter, int limit) {

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKey.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKey.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKey.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKey.java Thu May 27 18:09:53 2010
@@ -55,7 +55,7 @@ public class CorrelationKey implements S
 
     /**
      * Constructor.
-     * 
+     *
      * @param csetName
      *            correlation set identifier
      * @param keyValues
@@ -105,10 +105,10 @@ public class CorrelationKey implements S
 
     /**
      * Check if this key matches any member in a set of keys.
-     * 
+     *
      * @param keys
      *            set of keys to match against
-     * 
+     *
      * @return <code>true</code> if one of the keys in the set
      *         <code>equals(..)</code> this key, <code>false</code>
      *         otherwise
@@ -124,17 +124,17 @@ public class CorrelationKey implements S
 
     /**
      * Equals comperator method.
-     * 
+     *
      * @param o
      *            <code>CorrelationKey</code> object to compare with
-     * 
+     *
      * @return <code>true</code> if the given object
      */
     public boolean equals(Object o) {
         if (!(o instanceof CorrelationKey)) {
             return false;
         }
-        
+
         CorrelationKey okey = (CorrelationKey) o;
 
         if (okey == null || !okey._csetName.equals(_csetName) || okey._keyValues.length != _keyValues.length)
@@ -149,7 +149,7 @@ public class CorrelationKey implements S
 
     /**
      * Generate a hash code from the hash codes of the elements.
-     * 
+     *
      * @see HashMap#hashCode
      * @see Object#hashCode
      */

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKeySet.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKeySet.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKeySet.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/CorrelationKeySet.java Thu May 27 18:09:53 2010
@@ -29,51 +29,51 @@ import java.util.TreeSet;
 
 /**
  * This class implements a set of correlation keys.
- * 
+ *
  * The example of canonical forms of correlation key sets are:
- * 
+ *
  *  <ul>
  *  <li>@2</li>
  *  <li>@2[12~a~b]</li>
  *  <li>@2[12~a~b],[25~b~c]</li>
  *  </ul>
- *  
+ *
  *  The first example shows an empty correlation key set. The second shows a set with one correlation key inside.
  *  The third shows a set with two keys inside. The correlation keys are sorted by the correlation set ids.
- *  
+ *
  * @author sean
  *
  */
 public class CorrelationKeySet implements Serializable {
     private static final long serialVersionUID = 1L;
-    
+
     public final static String VERSION_1 = "1";
     public final static String VERSION_2 = "2";
 
     @SuppressWarnings("unused")
     private String version = VERSION_2;
-    
+
     private final Set<CorrelationKey> correlationKeys = new TreeSet<CorrelationKey>(new CorrelationKeyComparator());
-    
+
     /**
      * Default Constructor
      */
     public CorrelationKeySet() {
     }
-    
+
     /**
      * Restores the state by parsing the given canonical form of correlation key set.
-     * 
+     *
      * @param canonicalForm canonical form of correlation key set
      */
     public CorrelationKeySet(String canonicalForm) {
         restore(canonicalForm);
     }
-    
+
     /**
      * Adds a correlation key to this correlation key set. If a correlation key with the same correlation set id
      * already exists, the old one is replaced with the given new one.
-     * 
+     *
      * @param ck a correlation key to add
      * @return returns this correlation key set
      */
@@ -85,14 +85,14 @@ public class CorrelationKeySet implement
             }
         }
         correlationKeys.add(ck);
-        
+
         return this;
     }
-    
+
     /**
-     * Checks if this correlation key set contains the opaque correlation key as the only key 
+     * Checks if this correlation key set contains the opaque correlation key as the only key
      * in this correlation key set.
-     * 
+     *
      * @return returns true if the correlation key set is opaque
      */
     public boolean isOpaque() {
@@ -100,26 +100,26 @@ public class CorrelationKeySet implement
     }
 
     /**
-     * Checks if an incoming message with this correlation key set can be accepted by the given 
+     * Checks if an incoming message with this correlation key set can be accepted by the given
      * correlation key set.
-     * 
+     *
      * @param candidateKeySet a correlation key set stored in a route
      * @param isAllRoute use true if the route="all" is set
      * @return return true if routable
      */
     public boolean isRoutableTo(CorrelationKeySet candidateKeySet, boolean isAllRoute) {
         boolean isRoutable = containsAll(candidateKeySet);
-        
+
         if( isAllRoute ) {
             isRoutable = isRoutable || candidateKeySet.isOpaque() && isEmpty();
         }
-        
+
         return isRoutable;
     }
-    
+
     /**
      * Checks if this correlation key set contains all correlation keys from the given correlation key set.
-     * 
+     *
      * @param c a correlation key set
      * @return return true if this correlation key set is a superset
      */
@@ -130,21 +130,21 @@ public class CorrelationKeySet implement
                 return false;
         return true;
     }
-    
+
     /**
      * Returns true if this correlation key set contains no correlation keys.
-     * 
+     *
      * @return returns true if empty
      */
     public boolean isEmpty() {
         return correlationKeys.isEmpty();
     }
-    
+
     /**
      * Returns true if this correlation key set contains the give correlation key.
-     * 
+     *
      * @param correlationKey a correlation key
-     * @return 
+     * @return
      */
     public boolean contains(CorrelationKey correlationKey) {
         Iterator<CorrelationKey> e = correlationKeys.iterator();
@@ -160,16 +160,16 @@ public class CorrelationKeySet implement
         }
         return false;
     }
-    
+
     /**
      * Returns an iterator on the correlation keys that this correlation key set contains.
-     * 
+     *
      * @return an iterator
      */
     public Iterator<CorrelationKey> iterator() {
         return correlationKeys.iterator();
     }
-    
+
     /**
      * Removes all correlation keys in this correlation keys.
      */
@@ -183,7 +183,7 @@ public class CorrelationKeySet implement
             return false;
         }
         CorrelationKeySet another = (CorrelationKeySet)o;
-        
+
         if( correlationKeys.size() != another.correlationKeys.size() ) {
             return false;
         }
@@ -193,12 +193,12 @@ public class CorrelationKeySet implement
 
     /**
      * Finds all subsets of this correlation key set.
-     * 
+     *
      * @return a list of all subset correlation key sets
      */
     public List<CorrelationKeySet> findSubSets() {
         List<CorrelationKeySet> subSets = new ArrayList<CorrelationKeySet>();
-        
+
         // if the key set contains a opaque key and at least one non-opaque key, take out the opaque key
         CorrelationKey opaqueKey = null;
         boolean containsNonOpaque = false;
@@ -215,10 +215,10 @@ public class CorrelationKeySet implement
         if( opaqueKey != null && containsNonOpaque ) {
             explicitKeySet.correlationKeys.remove(opaqueKey);
         }
-        
+
         // we are generating (2 powered by the number of correlation keys) number of sub-sets
         for( int setIndex = 0; setIndex < Math.pow(2, explicitKeySet.correlationKeys.size()); setIndex++ ) {
-            CorrelationKeySet subKeySet = new CorrelationKeySet(); 
+            CorrelationKeySet subKeySet = new CorrelationKeySet();
             int bitPattern = setIndex; // the bitPattern will be 0b0000, 0b0001, 0b0010 and so on
             Iterator<CorrelationKey> ckeys = explicitKeySet.iterator();
             while( ckeys.hasNext() && bitPattern > 0 ) { // bitPattern > 0 condition saves half of the iterations
@@ -233,38 +233,38 @@ public class CorrelationKeySet implement
                 subSets.add(subKeySet);
             }
         }
-        
+
         if( subSets.isEmpty() ) {
             subSets.add(new CorrelationKeySet());
         }
-        
+
         return subSets;
     }
 
     /**
      * Returns a canonical form of this correlation key set.
-     * 
+     *
      * @return
      */
     public String toCanonicalString() {
         StringBuffer buf = new StringBuffer();
-        
+
         for( CorrelationKey ckey : correlationKeys ) {
             if( buf.length() > 0 ) {
                 buf.append(",");
             }
             buf.append("[").append(escapeRightBracket(ckey.toCanonicalString())).append("]");
         }
-        
+
         return "@" + VERSION_2 + buf.toString();
     }
-    
+
     private static String escapeRightBracket(String str) {
         if (str == null)
             return null;
 
         StringBuffer buf = new StringBuffer();
-        
+
         char[] chars = str.toCharArray();
         for (char achar : chars) {
             if (achar == ']') {
@@ -273,7 +273,7 @@ public class CorrelationKeySet implement
                 buf.append(achar);
             }
         }
-        
+
         return buf.toString();
     }
 
@@ -284,7 +284,7 @@ public class CorrelationKeySet implement
 
     /**
      * Restores the state of this correlation key set from a canonical form.
-     * 
+     *
      * @param canonicalForm a canonical form of correlation key set
      */
     public void restore(String canonicalForm) {
@@ -372,5 +372,5 @@ public class CorrelationKeySet implement
             // used only in sorting the correlation keys in the CorrelationKeySet; does not matter with the values
             return o1.getCorrelationSetName().compareTo(o2.getCorrelationSetName());
         }
-    }    
+    }
 }
\ No newline at end of file

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/Filter.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/Filter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/Filter.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/Filter.java Thu May 27 18:09:53 2010
@@ -37,19 +37,19 @@ import java.util.regex.Pattern;
  */
 public abstract class Filter<FKEY extends Enum> implements Serializable {
   private static final long serialVersionUID = 9999;
-  
-  
+
+
   /** Internationalization. */
   protected static final Messages __msgs = MessageBundle.getMessages(Messages.class);
 
   /**
-   *  Pattern that matches anything like 'abcde <  fgh' or 'ijklm  =nop' using 
+   *  Pattern that matches anything like 'abcde <  fgh' or 'ijklm  =nop' using
    *  supported comparators
    *  <p>
    *  The not-equal op, '<>' works only with pids.
    *  </p>
    */
-  public static final Pattern __comparatorPattern = 
+  public static final Pattern __comparatorPattern =
     Pattern.compile("([^=<> ]*) *(<>|<=|>=|<|>|=) *([^=<> ]*)");
 
   protected Map<FKEY, Restriction<String>> _criteria = new HashMap<FKEY,Restriction<String>>();
@@ -58,7 +58,7 @@ public abstract class Filter<FKEY extend
     public final String originalKey;
     public final String op;
     public final V value;
-    
+
     public Restriction(String originalKey, String op, V value) {
       this.originalKey=originalKey;
       this.op=op;
@@ -80,10 +80,10 @@ public abstract class Filter<FKEY extend
           String errmsg = __msgs.msgUnrecognizedFilterKey(filterKey, getFilterKeysStr());
           throw new IllegalArgumentException(errmsg, ex);
         }
-        
+
         Restriction<String> restriction = new Restriction<String>(filterKey,op,value);
         _criteria.put(keyval, restriction);
-        
+
         process(keyval, restriction);
       }
     }
@@ -110,19 +110,19 @@ public abstract class Filter<FKEY extend
       }
     }
     return null;
- 
+
   }
 
   /**
    * Parse the string representation of a key into an
-   * enumeration value. 
+   * enumeration value.
    * @param keyVal string representation
    * @return enumeration value
    */
   protected abstract FKEY parseKey(String keyVal);
 
   /**
-   * Get the list of known (recognized) filter keys. 
+   * Get the list of known (recognized) filter keys.
    * @return recognized filter keys
    */
   protected abstract FKEY[] getFilterKeys();
@@ -142,7 +142,7 @@ public abstract class Filter<FKEY extend
             return x.name();
           }
         });
-    
+
   }
 }
 

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/InstanceFilter.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/InstanceFilter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/InstanceFilter.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/InstanceFilter.java Thu May 27 18:09:53 2010
@@ -248,7 +248,7 @@ public class InstanceFilter extends Filt
             return ISO8601DateParser.parse(date);
         }
     }
-    
+
     /**
      * Converts the status filter value as given by a filter ('active',
      * 'suspended', ...) to an instance state as defined in the ProcessState
@@ -373,7 +373,7 @@ public class InstanceFilter extends Filt
         buf.append("}");
         return buf.toString();
     }
-    
+
     private static List<String> parse(String pipeDelimited) {
         List<String> list = new ArrayList<String>();
         StringTokenizer tok = new StringTokenizer(pipeDelimited, "|");
@@ -381,5 +381,5 @@ public class InstanceFilter extends Filt
             list.add(tok.nextToken());
         }
         return list;
-    }        
+    }
 }
\ No newline at end of file

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/OptionalCorrelationKey.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/OptionalCorrelationKey.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/OptionalCorrelationKey.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/OptionalCorrelationKey.java Thu May 27 18:09:53 2010
@@ -27,9 +27,9 @@ import org.apache.ode.utils.CollectionUt
 /**
  * An instance of this class represents a correlation key that has a 'join' use case in the process definition.
  * For instance, if a correlation set, 'orderId' is used as initiate="no" in 3 occurrences and initiate="join"
- * in 1 occurrence, any correlation keys that are derived from the correlation set, 'orderId' is an 
+ * in 1 occurrence, any correlation keys that are derived from the correlation set, 'orderId' is an
  * optional correlation key.
- * 
+ *
  * @author sean
  *
  */

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessFilter.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessFilter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessFilter.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessFilter.java Thu May 27 18:09:53 2010
@@ -115,7 +115,7 @@ public class ProcessFilter extends Filte
   /**
    * Initializes properly the ProcessFilter attributes by pre-parsing the filter
    * and orderKeys strings.
-   * 
+   *
    * @param filter
    * @param orderKeys
    */

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessState.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessState.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessState.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/common/ProcessState.java Thu May 27 18:09:53 2010
@@ -22,12 +22,12 @@ package org.apache.ode.bpel.common;
  * Convenience class for working with process states.
  */
 public class ProcessState {
-  
+
     /** <em>NEW</em> state: instance has not been reduced. */
   public static final short STATE_NEW = 0;
 
   /**
-   * <em>READY</em> state: instance is waiting for a <code>&lt;receive&gt;</code> 
+   * <em>READY</em> state: instance is waiting for a <code>&lt;receive&gt;</code>
    * or <code>&lt;pick&gt;</code> with <code>createInstance="true"</code>.
    */
   public static final short STATE_READY = 10;
@@ -43,26 +43,26 @@ public class ProcessState {
    * (normally).
    */
   public static final short STATE_COMPLETED_OK = 30;
-  
+
   /**
    * <em>COMPLETED WITH FAULT</em> state: instance has reached the end of its execution
    * due to an uncaught fault.
    */
   public static final short STATE_COMPLETED_WITH_FAULT = 40;
-  
+
   /**
    * <em>SUSPENDED</em> state: instance was suspended via a breakpoint or user
    * intervention.
    */
   public static final short STATE_SUSPENDED = 50;
-  
+
   /**
    * <em>TERMINATED</em> state: instance was terminated, either via the
    * <code>&lt;terminate&gt;</code> or through manual intervention.
    * @see org.apache.ode.bpel.bdi.InstanceReference#terminate()
    */
   public static final short STATE_TERMINATED = 60;
-  
+
   /**
    * An array containing the possible states.
    */
@@ -75,12 +75,12 @@ public class ProcessState {
     STATE_SUSPENDED,
     STATE_TERMINATED
   };
-  
+
   /*
    * No instance for you.
    */
   private ProcessState(){}
-    
+
   /**
    * Test whether a process state is one where the process can execute, i.e.,
    * not {@link #STATE_SUSPENDED} and not one of the completed or terminated states.
@@ -92,12 +92,12 @@ public class ProcessState {
         ||  state == STATE_ACTIVE
         || state == STATE_NEW;
   }
-  
-  
+
+
   /**
-   * Test whether a process state is one of the completed states, e.g., 
+   * Test whether a process state is one of the completed states, e.g.,
    * {@link #STATE_COMPLETED_OK} or {@link #STATE_COMPLETED_WITH_FAULT}.
-   * 
+   *
    * @param state the state of the process
    * @return <code>true</code> if the process is finished.
    */
@@ -111,7 +111,7 @@ public class ProcessState {
    */
   public static String stateToString(short state) {
     switch (state) {
-    
+
       case STATE_NEW:
         return "New";
 
@@ -123,16 +123,16 @@ public class ProcessState {
 
       case STATE_COMPLETED_OK:
         return "Completed Ok";
-        
+
       case STATE_COMPLETED_WITH_FAULT:
         return "Completed Fault";
-        
+
       case STATE_SUSPENDED:
         return "Suspended";
-  
+
       case STATE_TERMINATED:
         return "Terminated";
-  
+
       default:
         throw new IllegalStateException("unknown state: " + state);
     }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModule.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModule.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModule.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModule.java Thu May 27 18:09:53 2010
@@ -28,90 +28,90 @@ import org.w3c.dom.Node;
 
 /**
  * Representation of an external source for variable data.
- * 
+ *
  * @author Maciej Szefler <mszefler at gmail dot com>
  *
  */
 public interface ExternalVariableModule {
 
     /**
-     * Get the QName of this external variable engine; this method must always return a valid non-null value. 
+     * Get the QName of this external variable engine; this method must always return a valid non-null value.
      * The name of the external variable engine is used to identify it in the external variable declaration.
      * @return
      */
     public QName getName();
 
-    
-    /** 
-     * Start the external variable subsystem. This method is called before the engine is started. 
+
+    /**
+     * Start the external variable subsystem. This method is called before the engine is started.
      *
      */
     public void start();
-    
+
     /**
      * Stop the external variable subsystem. This method is called right after the engine is stopped.
      *
      */
     public void stop();
-    
+
     /**
-     * Shutdown the external variable subsystem. This method is called right after the engine is shutdown. 
+     * Shutdown the external variable subsystem. This method is called right after the engine is shutdown.
      *
      */
     public void shutdown();
-    
-    
+
+
     /**
-     * Report whether this engine is transactional, i.e. do the update/fetch methods use the JTA TX?  
+     * Report whether this engine is transactional, i.e. do the update/fetch methods use the JTA TX?
      * @return <code>true</code> if transactional, <code>false</code> otherwsie.
      */
     public boolean isTransactional();
-    
- 
+
+
     /**
-     * Configure an external variable. 
-     * @param pid process 
+     * Configure an external variable.
+     * @param pid process
      * @param extVarId external variable identifier
      * @param config configuration element
-     * @throws ExternalVariableModuleException 
+     * @throws ExternalVariableModuleException
      */
     public void configure(QName pid, String extVarId, Element config) throws ExternalVariableModuleException;
 
-    
+
     /**
-     * The the value of an external variable. 
+     * The the value of an external variable.
      * @param locator variable locator
      * @param initialize indicates if this is the first time the value is being read
      * @return value of the variable
      */
     public Value readValue(QName varType, Locator locator) throws ExternalVariableModuleException;
-    
+
     /**
      * Update the value of the external variable.
-     * @param newval new variable value 
+     * @param newval new variable value
      * @param initialize indicates if this is a variable initialization
      */
     public Value writeValue(QName varType, Value newval) throws ExternalVariableModuleException;
-    
-    
+
+
     /**
      * Structure used to identify an external variable to the external variable subsystem.
      */
     public class Locator {
-        
+
         private static final long serialVersionUID = 1L;
 
         public final String varId;
-        
+
         /** Instance identifier. */
         public final Long iid;
-        
+
         /** Process identifier. */
         public final QName pid;
-        
+
         /** External-variable module-specific identifying information. */
         public Node reference;
-                
+
         public Locator(String varId, QName pid, Long iid) {
             this(varId, pid, iid, null);
         }
@@ -122,7 +122,7 @@ public interface ExternalVariableModule 
             this.iid = iid;
             this.reference = reference;
         }
-        
+
     }
 
     /**
@@ -131,18 +131,18 @@ public interface ExternalVariableModule 
      */
     public class Value {
         /** Variable locator. See {@link Locator}. */
-        public final Locator locator; 
-        
+        public final Locator locator;
+
         /** Value of the variable. */
         public final Node value;
-        
+
         /** Advisory indicating when the variable becomes stale (or null if non-perishable). */
         public final Date useByDate;
-        
+
         public Value(Locator locator, Node value) {
             this(locator,value, null);
         }
-        
+
         public Value(Locator locator, Node value, Date useByDate) {
             this.locator = locator;
             this.value = value;
@@ -151,6 +151,6 @@ public interface ExternalVariableModule 
     }
 
 
-    
+
 
 }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModuleException.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModuleException.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModuleException.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/ExternalVariableModuleException.java Thu May 27 18:09:53 2010
@@ -21,18 +21,18 @@ package org.apache.ode.bpel.evar;
 
 /**
  * Exception thrown by external variable engines.
- *  
+ *
  * @author Maciej Szefler <mszefler at gmail dot com>
  */
 public class ExternalVariableModuleException extends Exception {
 
     private static final long serialVersionUID = 1L;
 
-    
+
     public ExternalVariableModuleException(String msg, Throwable cause) {
         super(msg, cause);
     }
-    
+
     public ExternalVariableModuleException(String msg) {
         super(msg);
     }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/IncompleteKeyException.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/IncompleteKeyException.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/IncompleteKeyException.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evar/IncompleteKeyException.java Thu May 27 18:09:53 2010
@@ -23,22 +23,22 @@ import java.util.Collection;
 
 /**
  * Exception used to indicate that an attempt was made to access a variable using an incomplete key.
- * 
+ *
  * @author Maciej Szefler <mszefler at gmail dot com>
  *
  */
 public class IncompleteKeyException extends ExternalVariableModuleException {
-    
+
     private static final long serialVersionUID = 1L;
     private Collection<String>_missing;
 
     public IncompleteKeyException(Collection<String> missing) {
         super("Attempt to read external variable with an incomplete compound key. " +
                 "The following components were missing: " + missing);
-        
+
         _missing = missing;
     }
-    
+
     public Collection<String> getMissing() {
         return _missing;
     }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEnabledEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEnabledEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEnabledEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEnabledEvent.java Thu May 27 18:09:53 2010
@@ -24,5 +24,5 @@ package org.apache.ode.bpel.evt;
 public class ActivityEnabledEvent extends ActivityEvent {
 
     private static final long serialVersionUID = 1L;
-  
+
 }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityEvent.java Thu May 27 18:09:53 2010
@@ -25,10 +25,10 @@ package org.apache.ode.bpel.evt;
 public abstract class ActivityEvent extends ScopeEvent {
   private String _activityName;
   private String _activityType;
-  
+
   /** Activity declaration id. */
   private int _declarationId;
-  
+
   /** Activity Id, unique for each activity <em>instance</em>. */
   private long _aid;
 
@@ -38,7 +38,7 @@ public abstract class ActivityEvent exte
 
   /**
    * Gets activity name
-   * 
+   *
    * @return name of activity
    */
   public String getActivityName() {
@@ -72,7 +72,7 @@ public abstract class ActivityEvent exte
   public void setActivityId(long id) {
     _aid = id;
   }
-  
+
   public long getActivityId() {
     return _aid;
   }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityFailureEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityFailureEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityFailureEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityFailureEvent.java Thu May 27 18:09:53 2010
@@ -27,10 +27,10 @@ public class ActivityFailureEvent extend
 
     private String _reason;
 
-    public ActivityFailureEvent() { 
+    public ActivityFailureEvent() {
     }
-    
-    public ActivityFailureEvent(String reason) { 
+
+    public ActivityFailureEvent(String reason) {
       _reason = reason;
     }
 

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityRecoveryEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityRecoveryEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityRecoveryEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/ActivityRecoveryEvent.java Thu May 27 18:09:53 2010
@@ -24,7 +24,7 @@ package org.apache.ode.bpel.evt;
 public class ActivityRecoveryEvent extends ActivityEvent {
 
     private static final long serialVersionUID = 1L;
-  
+
   private String _action;
 
   public ActivityRecoveryEvent () {

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationMatchEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationMatchEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationMatchEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationMatchEvent.java Thu May 27 18:09:53 2010
@@ -48,7 +48,7 @@ public class CorrelationMatchEvent exten
                 _correlationKeySet.add(_correlationKey);
             }
         }
-        
+
         return _correlationKeySet;
     }
 

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationNoMatchEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationNoMatchEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationNoMatchEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationNoMatchEvent.java Thu May 27 18:09:53 2010
@@ -32,7 +32,7 @@ import org.apache.ode.bpel.common.Correl
  */
 public class CorrelationNoMatchEvent extends CorrelationEvent {
     private static final long serialVersionUID = 1L;
-    
+
     // left out for backward-compatibility
     private final Set<CorrelationKey> _keys = new HashSet<CorrelationKey>();
     private CorrelationKeySet _keySet = null;
@@ -54,7 +54,7 @@ public class CorrelationNoMatchEvent ext
                 _keySet.add(aKey);
             }
         }
-        
+
         return _keySet;
     }
 

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetEvent.java Thu May 27 18:09:53 2010
@@ -44,5 +44,5 @@ public abstract class CorrelationSetEven
   public TYPE getType() {
     return TYPE.dataHandling;
   }
-  
+
 }

Modified: ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetWriteEvent.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetWriteEvent.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetWriteEvent.java (original)
+++ ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/CorrelationSetWriteEvent.java Thu May 27 18:09:53 2010
@@ -22,7 +22,7 @@ import org.apache.ode.bpel.common.Correl
 
 /**
  * Correlation was set event.
- * 
+ *
  */
 public class CorrelationSetWriteEvent extends CorrelationSetEvent {
   private static final long serialVersionUID = 1L;
@@ -35,7 +35,7 @@ public class CorrelationSetWriteEvent ex
 
   /**
    * Correlation key.
-   * 
+   *
    * @return Returns the key.
    */
   public CorrelationKey getKey() {