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 [31/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/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/RetriesTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/RetriesTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/RetriesTest.java (original)
+++ ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/RetriesTest.java Thu May 27 18:09:53 2010
@@ -35,7 +35,7 @@ import junit.framework.TestCase;
  */
 public class RetriesTest extends TestCase implements Scheduler.JobProcessor {
     private static final Log __log = LogFactory.getLog(RetriesTest.class);
-    
+
     DelegateSupport _ds;
     SimpleScheduler _scheduler;
     ArrayList<Scheduler.JobInfo> _jobs;
@@ -43,7 +43,7 @@ public class RetriesTest extends TestCas
     TransactionManager _txm;
     int _tried = 0;
     Scheduler.JobInfo _jobInfo = null;
-    
+
     public void setUp() throws Exception {
         _txm = new GeronimoTransactionManager();
         _ds = new GeronimoDelegateSupport(_txm);
@@ -56,7 +56,7 @@ public class RetriesTest extends TestCas
     public void tearDown() throws Exception {
         _scheduler.shutdown();
     }
-    
+
     public void testRetries() throws Exception {
         // speed things up a bit to hit the right code paths
         _scheduler.setNearFutureInterval(5000);
@@ -76,7 +76,7 @@ public class RetriesTest extends TestCas
     public void testExecTransaction() throws Exception {
         final int[] tryCount = new int[1];
         tryCount[0] = 0;
-        
+
         Callable<Void> transaction = new Callable<Void>() {
             public Void call() throws Exception {
                 tryCount[0]++;
@@ -85,7 +85,7 @@ public class RetriesTest extends TestCas
                 } else {
                     return null;
                 }
-            }            
+            }
         };
 
         _scheduler.execTransaction(transaction);
@@ -94,7 +94,7 @@ public class RetriesTest extends TestCas
 
     public void onScheduledJob(Scheduler.JobInfo jobInfo) throws Scheduler.JobProcessorException {
         _jobInfo = jobInfo;
-        
+
         _tried++;
         throw new Scheduler.JobProcessorException(jobInfo.retryCount < 1);
     }

Modified: ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java (original)
+++ ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java Thu May 27 18:09:53 2010
@@ -33,21 +33,21 @@ import org.apache.ode.scheduler.simple.T
 import junit.framework.TestCase;
 
 /**
- * Test of SchedulerThread. 
- * 
- * @author Maciej Szefler  ( m s z e f l e r @ g m a i l . c o m ) 
+ * Test of SchedulerThread.
+ *
+ * @author Maciej Szefler  ( m s z e f l e r @ g m a i l . c o m )
  */
 public class SchedulerThreadTest extends TestCase implements TaskRunner {
 
     static final long SCHED_TOLERANCE = 100;
     SchedulerThread _st;
-    
-    List<TR> _tasks = new ArrayList<TR>(100); 
-    
+
+    List<TR> _tasks = new ArrayList<TR>(100);
+
     public void setUp() throws Exception {
         _st = new SchedulerThread(this);
     }
-    
+
     public void testSchedulingResolution() throws Exception {
         _st.start();
         long schedtime = System.currentTimeMillis() + 300;
@@ -69,7 +69,7 @@ public class SchedulerThreadTest extends
         Thread.sleep(SCHED_TOLERANCE);
         assertEquals(1,_tasks.size());
     }
-    
+
     public void testParallelEnqueue() throws Exception {
         _st.start();
         final long startTime = System.currentTimeMillis() + 100;
@@ -81,16 +81,16 @@ public class SchedulerThreadTest extends
                 _st.enqueue(tsk);
             }
         };
-        
+
         ExecutorService es = Executors.newFixedThreadPool(50);
-        for (int i = 0; i < 300; ++i) 
+        for (int i = 0; i < 300; ++i)
             es.execute(run);
-        
+
         Thread.sleep(300 + 300 * 5);
         assertEquals(300,_tasks.size());
         // Make sure they got scheduled in the right order
 
-        for (int i = 0; i < 299; ++i) 
+        for (int i = 0; i < 299; ++i)
             assertTrue(_tasks.get(i).task.schedDate < _tasks.get(i+1).task.schedDate);
 
         // Check scheduling tolerance
@@ -99,14 +99,14 @@ public class SchedulerThreadTest extends
             assertTrue(tr.time > tr.task.schedDate - SCHED_TOLERANCE / 2);
         }
     }
-    
+
     public void runTask(Task task) {
         synchronized(_tasks) {
             _tasks.add(new TR(System.currentTimeMillis(),task));
         }
     }
-    
-    
+
+
     class TR {
         long time;
         Task task;

Modified: ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java (original)
+++ ode/trunk/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java Thu May 27 18:09:53 2010
@@ -68,7 +68,7 @@ public class SimpleSchedulerTest extends
                 Thread.sleep(100);
                 // we're using transacted jobs which means it will commit at the end
                 // if the job is scheduled, the following assert is not valid @seanahn
-                // assertEquals(jobs, _jobs.size());            
+                // assertEquals(jobs, _jobs.size());
             } finally {
                 _txm.commit();
             }
@@ -80,7 +80,7 @@ public class SimpleSchedulerTest extends
             assertEquals(_jobs.size(), _commit.size());
         }
     }
-    
+
     public void testImmediateScheduling() throws Exception {
         _scheduler.start();
         _txm.begin();
@@ -89,7 +89,7 @@ public class SimpleSchedulerTest extends
             Thread.sleep(100);
             // we're using transacted jobs which means it will commit at the end
             // if the job is scheduled, the following assert is not valid @seanahn
-            // assertEquals(jobs, _jobs.size());        
+            // assertEquals(jobs, _jobs.size());
         } finally {
             _txm.commit();
         }
@@ -212,20 +212,20 @@ public class SimpleSchedulerTest extends
         synchronized (_jobs) {
             _jobs.add(jobInfo);
         }
-        
+
         try {
             _txm.getTransaction().registerSynchronization(new Synchronization() {
 
                 public void afterCompletion(int arg0) {
-                    if (arg0 == Status.STATUS_COMMITTED) 
+                    if (arg0 == Status.STATUS_COMMITTED)
                         _commit.add(jobInfo);
                 }
 
                 public void beforeCompletion() {
                     // TODO Auto-generated method stub
-                    
+
                 }
-                
+
             });
         } catch (IllegalStateException e) {
             // TODO Auto-generated catch block
@@ -252,5 +252,5 @@ public class SimpleSchedulerTest extends
         scheduler.setTransactionManager(_txm);
         return scheduler;
     }
-    
+
 }

Modified: ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel
URL: http://svn.apache.org/viewvc/ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel (original)
+++ ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel Thu May 27 18:09:53 2010
@@ -18,7 +18,7 @@
   -->
 
 <process name="HelloWorld2"
-    targetNamespace="http://ode/bpel/unit-test" 
+    targetNamespace="http://ode/bpel/unit-test"
     xmlns:bpws="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
     xmlns="http://schemas.xmlsoap.org/ws/2004/03/business-process/"
     xmlns:tns="http://ode/bpel/unit-test"
@@ -30,18 +30,18 @@
      importType="http://schemas.xmlsoap.org/wsdl/" />
 
    <partnerLinks>
-      <partnerLink name="helloPartnerLink" 
-         partnerLinkType="test:HelloPartnerLinkType" 
+      <partnerLink name="helloPartnerLink"
+         partnerLinkType="test:HelloPartnerLinkType"
          myRole="me" />
    </partnerLinks>
-    
+
    <variables>
      <variable name="myVar" messageType="test:HelloMessage"/>
      <variable name="tmpVar" type="xsd:string"/>
    </variables>
-        
-   <sequence>   
-       <receive 
+
+   <sequence>
+       <receive
           name="start"
           partnerLink="helloPartnerLink"
           portType="test:HelloPortType"
@@ -59,9 +59,9 @@
              <to variable="myVar" part="TestPart"/>
          </copy>
       </assign>
-       <reply name="end"  
+       <reply name="end"
               partnerLink="helloPartnerLink"
-              portType="test:HelloPortType" 
+              portType="test:HelloPortType"
               operation="hello"
               variable="myVar"/>
    </sequence>

Modified: ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl
URL: http://svn.apache.org/viewvc/ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl (original)
+++ ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.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/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml
URL: http://svn.apache.org/viewvc/ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml (original)
+++ ode/trunk/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml Thu May 27 18:09:53 2010
@@ -17,8 +17,8 @@
   ~ under the License.
   -->
 
-<deploy xmlns="http://ode.fivesight.com/schemas/2006/06/27/dd" 
-    xmlns:pns="http://ode/bpel/unit-test" 
+<deploy xmlns="http://ode.fivesight.com/schemas/2006/06/27/dd"
+    xmlns:pns="http://ode/bpel/unit-test"
     xmlns:wns="http://ode/bpel/unit-test.wsdl">
 
 

Modified: ode/trunk/settings.rb.example
URL: http://svn.apache.org/viewvc/ode/trunk/settings.rb.example?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/settings.rb.example (original)
+++ ode/trunk/settings.rb.example Thu May 27 18:09:53 2010
@@ -26,7 +26,7 @@ def settings
     :autocommit=>"on",
     :dao=>"org.apache.ode.axis2.instancecleanup.HibDaoConnectionFactoryImpl"
   }
-  
+
   local_jpa_mysql = {
     :integr_branch=>"5.2.x",
     :db=>"mysql",

Modified: ode/trunk/tasks/bnd.rake
URL: http://svn.apache.org/viewvc/ode/trunk/tasks/bnd.rake?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tasks/bnd.rake (original)
+++ ode/trunk/tasks/bnd.rake Thu May 27 18:09:53 2010
@@ -15,14 +15,14 @@
 #    limitations under the License.
 #
 
-# This task creates an OSGi bundle package using the bnd tool. 
+# This task creates an OSGi bundle package using the bnd tool.
 #
-# The classpath and path to a bnd configuration file are required. 
+# The classpath and path to a bnd configuration file are required.
 # Additional properties can be specified using the bnd.properties
 # hash. Refer to the bnd documentation (http://www.aqute.biz/Code/Bnd)
-# for details on the supported properties. 
+# for details on the supported properties.
 #
-# The easiest way to use this task is through the Project#package method. 
+# The easiest way to use this task is through the Project#package method.
 # For example:
 #   package(:bundle).tap do |bnd|
 #     bnd.bnd_file = 'conf/foo.bnd'
@@ -41,7 +41,7 @@ class BndTask < Rake::FileTask
 
   # Path to bnd file
   attr_accessor :bnd_file
-  
+
   # Hash of properties passed to bnd
   attr_accessor :properties
 
@@ -52,23 +52,23 @@ class BndTask < Rake::FileTask
     # Make sure bnd tool is available
     Buildr.artifact(BND).invoke
 
-    enhance do 
+    enhance do
       Buildr.ant('bnd') do |project|
-        
+
         # pass properties to bnd as ant properties
         properties.each do |key, value|
           project.property(:name=>key, :value=>value)
         end
-        
+
         project.taskdef :name=>'bnd', :classname=>'aQute.bnd.ant.BndTask', :classpath=>Buildr.artifact(BND)
-        project.bnd(:classpath=>classpath, :sourcepath=>(sourcepath == nil) ? "" : File.expand_path(sourcepath), 
-                    :files=>File.expand_path(bnd_file), :output=>name, 
-                    :eclipse=>false, :failok=>false, :exceptions=>true) 
+        project.bnd(:classpath=>classpath, :sourcepath=>(sourcepath == nil) ? "" : File.expand_path(sourcepath),
+                    :files=>File.expand_path(bnd_file), :output=>name,
+                    :eclipse=>false, :failok=>false, :exceptions=>true)
       end
     end
   end
-  
-  
+
+
 end
 
 
@@ -77,9 +77,9 @@ class Project
   def package_as_bundle(file_name) #:nodoc
     BndTask.define_task(file_name)
   end
-  
+
   def package_as_bundle_spec(spec) #:nodoc
     spec.merge({ :type=>:jar, :classifier=>'bundle' })
   end
-  
+
 end

Modified: ode/trunk/tasks/headers.rake
URL: http://svn.apache.org/viewvc/ode/trunk/tasks/headers.rake?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tasks/headers.rake (original)
+++ ode/trunk/tasks/headers.rake Thu May 27 18:09:53 2010
@@ -79,8 +79,8 @@ EOF
 #    limitations under the License.
 #
 EOF
-    licenses[".bpel"] = licenses[".wsdl"] = licenses[".xsd"] = licenses[".soap"] = 
-    licenses['.usd'] = licenses['.xsl'] = licenses[".deploy"] = licenses[".xml"]  
+    licenses[".bpel"] = licenses[".wsdl"] = licenses[".xsd"] = licenses[".soap"] =
+    licenses['.usd'] = licenses['.xsl'] = licenses[".deploy"] = licenses[".xml"]
     licenses[".rake"] = licenses[".tdef"] = licenses[".properties"]
     # This also tells us which files to look at.
     extensions = licenses.keys.join(",")

Modified: ode/trunk/tasks/jbi.rake
URL: http://svn.apache.org/viewvc/ode/trunk/tasks/jbi.rake?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tasks/jbi.rake (original)
+++ ode/trunk/tasks/jbi.rake Thu May 27 18:09:53 2010
@@ -68,19 +68,19 @@ class JBITask < Buildr::ZipTask
   def initialize(*args)
     super
     prepare { path("lib").include((component.libs + bootstrap.libs).flatten.uniq) }
-      
+
     enhance do
       case jbi_xml
       when String
-        path("META-INF").include jbi_xml.path, :as=>"jbi.xml" 
+        path("META-INF").include jbi_xml.path, :as=>"jbi.xml"
       when nil, true
         # Tempfiles gets deleted on garbage collection, so we're going to hold on to it
         # through instance variable not closure variable.
         Tempfile.open("MANIFEST.MF") { |@jbi_xml_tmp| @jbi_xml_tmp.write descriptor }
-        path("META-INF").include @jbi_xml_tmp.path, :as=>"jbi.xml" 
+        path("META-INF").include @jbi_xml_tmp.path, :as=>"jbi.xml"
       when Proc, Method
         Tempfile.open("MANIFEST.MF") { |@jbi_xml_tmp| @jbi_xml_tmp.write jbi_xml.call.to_s }
-        path("META-INF").include @jbi_xml_tmp.path, :as=>"jbi.xml" 
+        path("META-INF").include @jbi_xml_tmp.path, :as=>"jbi.xml"
       end
     end
   end

Modified: ode/trunk/tasks/nativedb.rake
URL: http://svn.apache.org/viewvc/ode/trunk/tasks/nativedb.rake?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tasks/nativedb.rake (original)
+++ ode/trunk/tasks/nativedb.rake Thu May 27 18:09:53 2010
@@ -32,7 +32,7 @@ module NativeDB
 
         settings().each do |name, dbprops|
           if dbprops[:db] != "derby"
-            buildr.build create_hib_db(name, "#{base}/target/#{name}"=>dbprops) if orm == :hib and dbprops[:dao].downcase.include? "hib" 
+            buildr.build create_hib_db(name, "#{base}/target/#{name}"=>dbprops) if orm == :hib and dbprops[:dao].downcase.include? "hib"
             buildr.build create_jpa_db(base, name, "#{base}/target/#{name}"=>dbprops) if orm == :jpa and !dbprops[:dao].downcase.include? "hib"
           end
         end
@@ -53,7 +53,7 @@ module NativeDB
             ant.get :src=>"http://release.intalio.com/m2repo/ci-resources/ode-schema-5.2.x/package/#{dbprops[:db]}/ode_tables.sql",
                     :dest=> create_tables_sql
             sqls = prepare_sqls(task, ant, [], :hib, dbprops[:db], drop_tables_sql, create_tables_sql)
-            
+
             # Apply the sql scripts to the database
             ant.sql :driver=>dbprops[:driver], :url=>dbprops[:url], :userid=>dbprops[:userid], :password=>dbprops[:password], :autocommit=>dbprops[:autocommit] do
               sqls.each { |sql| ant.transaction :src=>sql }
@@ -76,7 +76,7 @@ module NativeDB
             create_tables_sql = "#{base}/target/#{dbprops[:db]}.sql"
             drop_tables_sql = "#{task.name}/drop-#{dbprops[:db]}.sql"
             sqls = prepare_sqls(task, ant, [], :jpa, dbprops[:db], drop_tables_sql, create_tables_sql)
-                        
+
             # Apply the sql scripts to the database
             ant.sql :driver=>dbprops[:driver], :url=>dbprops[:url], :userid=>dbprops[:userid], :password=>dbprops[:password], :autocommit=>dbprops[:autocommit] do
               sqls.each { |sql| ant.transaction :src=>sql }
@@ -88,7 +88,7 @@ module NativeDB
     end
 
     def prepare_configs(test, base)
-      test.setup task("prepare_configs") do |task| 
+      test.setup task("prepare_configs") do |task|
         if File.exist? SETTINGS
           require SETTINGS
 
@@ -101,7 +101,7 @@ module NativeDB
               dbs <<= (dbs == jpadbs ? "<jpa>" : "<hib>")
             else
               test.with REQUIRES
-  
+
               prepare_config(name, dbprops, "#{base}/target/conf.#{name}", "#{base}/src/test/webapp/WEB-INF/conf.template")
               dbs <<= ", " if dbs.length > 0
               dbs <<= "#{base}/target/conf.#{name}"
@@ -112,11 +112,11 @@ module NativeDB
         end
       end
     end
-    
+
     def prepare_config(name, dbprops, db, template)
       rm_rf db if File.exist?(db)
       Dir.mkdir(db)
-      
+
       Buildr.ant(name) do |ant|
         ant.copy :todir=>db do
           ant.fileset :dir=>template
@@ -127,20 +127,20 @@ module NativeDB
         ant.replace :file=>"#{db}/ode-axis2.properties", :token=>"@url@", :value=>dbprops[:url]
         ant.replace :file=>"#{db}/ode-axis2.properties", :token=>"@userid@", :value=>dbprops[:userid]
         ant.replace :file=>"#{db}/ode-axis2.properties", :token=>"@password@", :value=>dbprops[:password]
-        
+
         puts "Created config directory: #{db}."
       end
     end
-    
+
     def prepare_sqls(task, ant, sql_files, orm, db, drop_tables_sql, create_tables_sql)
       # read the create table sql into a string
       create_tables = ""
-      File.open(create_tables_sql, "r") do |f1|  
+      File.open(create_tables_sql, "r") do |f1|
         while line = f1.gets
           create_tables <<= line
         end
       end
-    
+
       # create the drop table sql file from the create table sql
       if orm == :hib and db == "sqlserver"
         File.open(drop_tables_sql, "w") do |f2|
@@ -161,7 +161,7 @@ module NativeDB
         # add in the drop table sql file
         sql_files |= [drop_tables_sql]
       end
-      
+
       # add in the create table sql file
       if orm == :hib and db != "sqlserver"
         ant.copy :file=>create_tables_sql, :tofile=>"#{task.name}/#{db}.sql"
@@ -170,10 +170,10 @@ module NativeDB
         ant.copy :file=>create_tables_sql, :tofile=>"#{task.name}/#{db}.sql"
         sql_files |= ["#{task.name}/#{db}.sql"]
       end
-      
+
       sql_files
     end
-    
+
   protected
 
     # This will download all the required artifacts before returning a classpath, and we want to do this only once.

Modified: ode/trunk/tasks/ws-security.rake
URL: http://svn.apache.org/viewvc/ode/trunk/tasks/ws-security.rake?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tasks/ws-security.rake (original)
+++ ode/trunk/tasks/ws-security.rake Thu May 27 18:09:53 2010
@@ -2,7 +2,7 @@
 
 module WSSecurity
 
-  class << self 
+  class << self
     def prepare_secure_processes_tests(test_dir, modules)
       task(test_dir.to_sym) do
         mkdir "#{test_dir}/modules" unless File.directory? "#{test_dir}/modules"
@@ -20,14 +20,14 @@ module WSSecurity
       end
     end
     def prepare_secure_services_tests(test_dir, file_pattern, modules)
-      task(test_dir.to_sym) do 
+      task(test_dir.to_sym) do
         # copy the required modules
         mkdir "#{test_dir}/modules" unless File.directory? "#{test_dir}/modules"
         Buildr.artifacts(modules).each(&:invoke)
         cp modules.map {|a| Buildr.repositories.locate(a)} , "#{test_dir}/modules"
         # generate one process per test
         Dir.chdir(test_dir) do
-          Dir[file_pattern].each do |config_file| 
+          Dir[file_pattern].each do |config_file|
             sample_name = File.basename(config_file, "."+config_file.split('.').last)
             # create process directory
             proc_dir = "process-#{sample_name}"
@@ -38,8 +38,8 @@ module WSSecurity
             Dir["process-template/*"].each do |file|
               lines = IO.readlines(file)
               # copy file and replace template values
-              File.open("#{proc_dir}/#{File.basename(file)}", 'w') { |f| 
-                lines.each { |l| 
+              File.open("#{proc_dir}/#{File.basename(file)}", 'w') { |f|
+                lines.each { |l|
                   l.gsub!("{sample.namespace}", "http://#{sample_name.gsub('-','.')}.samples.rampart.apache.org")
                   l.gsub!("{sample.service.name}", sample_name)
                   f<<l

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/ClineCommandContext.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/ClineCommandContext.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/ClineCommandContext.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/ClineCommandContext.java Thu May 27 18:09:53 2010
@@ -23,11 +23,11 @@ import org.apache.commons.logging.Log;
 public class ClineCommandContext implements CommandContext {
 
   private Log _log;
-  
+
   public ClineCommandContext(Log l) {
     _log = l;
   }
-  
+
   public void outln(String s) {
     System.out.println(s);
   }
@@ -35,11 +35,11 @@ public class ClineCommandContext impleme
   public void out(String s) {
     System.out.print(s);
   }
-  
+
   public void errln(String s) {
     System.err.println(s);
   }
-  
+
   public void error(String s) {
     _log.error(s);
   }
@@ -63,11 +63,11 @@ public class ClineCommandContext impleme
   public void debug(String s) {
     _log.debug(s);
   }
-  
+
   public void warn(String s) {
     _log.warn(s);
   }
-  
+
   public void warn(String s, Throwable t) {
     _log.warn(s,t);
   }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/Command.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/Command.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/Command.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/Command.java Thu May 27 18:09:53 2010
@@ -19,6 +19,6 @@
 package org.apache.ode.tools;
 
 public interface Command {
-  
+
   public void execute(CommandContext cc) throws ExecutionException;
 }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContext.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContext.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContext.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContext.java Thu May 27 18:09:53 2010
@@ -44,13 +44,13 @@ public interface CommandContext {
    * @param s the content to send.
    */
   public void out(String s);
-  
+
   /**
    * Send a line of output to the equivalent of standard error.
    * @param s the content to send.
    */
   public void errln(String s);
-  
+
   /**
    * Log an error.
    * @param s a descriptive message.
@@ -103,5 +103,5 @@ public interface CommandContext {
    * @param s a descriptive message.
    */
   public void debug(String s);
-  
+
 }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContextErrorHandler.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContextErrorHandler.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContextErrorHandler.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandContextErrorHandler.java Thu May 27 18:09:53 2010
@@ -25,10 +25,10 @@ import org.xml.sax.SAXParseException;
 public class CommandContextErrorHandler implements ErrorHandler {
 
   private CommandContext _cc;
-  
+
   private boolean _err;
   /**
-   * 
+   *
    */
   public CommandContextErrorHandler(CommandContext cc) {
     _cc = cc;
@@ -38,7 +38,7 @@ public class CommandContextErrorHandler 
   public boolean hadError() {
     return _err;
   }
-  
+
   /* (non-Javadoc)
    * @see org.xml.sax.ErrorHandler#warning(org.xml.sax.SAXParseException)
    */
@@ -51,7 +51,7 @@ public class CommandContextErrorHandler 
    */
   public void error(SAXParseException exception) throws SAXException {
     _err = true;
-    _cc.errln(formatMessage(exception));    
+    _cc.errln(formatMessage(exception));
   }
 
   /* (non-Javadoc)
@@ -62,7 +62,7 @@ public class CommandContextErrorHandler 
     _cc.error(formatMessage(exception),exception);
     throw exception;
   }
-  
+
   private String formatMessage(SAXParseException e) {
     StringBuffer sb = new StringBuffer();
     sb.append('[');
@@ -79,5 +79,5 @@ public class CommandContextErrorHandler 
     sb.append(e.getMessage());
     return sb.toString();
   }
-  
+
 }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandTask.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandTask.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandTask.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/CommandTask.java Thu May 27 18:09:53 2010
@@ -36,7 +36,7 @@ public abstract class CommandTask extend
   public void out(String s) {
     handleOutput(s);
   }
-  
+
   public void errln(String s) {
     handleErrorOutput(s);
   }
@@ -71,5 +71,5 @@ public abstract class CommandTask extend
 
   public void debug(String s) {
     log(s,Project.MSG_VERBOSE);
-  }  
+  }
 }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelCTask.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelCTask.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelCTask.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelCTask.java Thu May 27 18:09:53 2010
@@ -26,13 +26,13 @@ import org.apache.tools.ant.BuildExcepti
 import java.io.File;
 
 public class BpelCTask extends CommandTask {
-  
+
   BpelCompileCommand _bcc = new BpelCompileCommand();
 
   public void setTargetdir(File f) {
     _bcc.setOuputDirectory(f);
   }
-  
+
   public void addConfiguredBpel(BpelSrcElement bse) {
     if (bse.getUrl() == null || bse.getUrl().trim().length() == 0) {
       throw new BuildException("The url attribute is required.");
@@ -43,7 +43,7 @@ public class BpelCTask extends CommandTa
   public void setWsdl(String uri) throws BuildException {
     _bcc.setWsdlImportUri(uri);
   }
-  
+
   /**
    * @see org.apache.tools.ant.Task#execute()
    */

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelSrcElement.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelSrcElement.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelSrcElement.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/BpelSrcElement.java Thu May 27 18:09:53 2010
@@ -19,17 +19,17 @@
 package org.apache.ode.tools.bpelc.ant;
 
 public class BpelSrcElement {
-  
+
   private String _url;
-  
+
   public BpelSrcElement() {
     // This space intentionally left blank.
   }
-  
+
   public void setUrl(String u) {
     _url = u;
   }
-  
+
   public String getUrl() {
     return _url;
   }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/WsdlImportElement.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/WsdlImportElement.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/WsdlImportElement.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/bpelc/ant/WsdlImportElement.java Thu May 27 18:09:53 2010
@@ -19,17 +19,17 @@
 package org.apache.ode.tools.bpelc.ant;
 
 public class WsdlImportElement {
-  
+
   private String _uri;
-  
+
   public WsdlImportElement() {
     // This space intentially left blank.
   }
-  
+
   public String getUri() {
     return _uri;
   }
-  
+
   public void setUri(String s) {
     _uri = s;
   }

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/package.html
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/package.html?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/package.html (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/package.html Thu May 27 18:09:53 2010
@@ -24,7 +24,7 @@
 <ul>
 <li>One or more implementations of the {@link com.fs.jlo.tools.Command} interface
 that perform a given function.</li>
-<li>In the <code>com.fs.jlo.tools.foo.cline</code> subpackage, a class with a 
+<li>In the <code>com.fs.jlo.tools.foo.cline</code> subpackage, a class with a
 <code>main()</code> method that uses the above {@link com.fs.jlo.tools.Command}
 implementation to perform some function, e.g., deploying a ODE system.</li>
 <li>In the <code>com.fs.jlo.tools.foo.ant</code> subpackage, a class that extends

Modified: ode/trunk/tools/src/main/java/org/apache/ode/tools/sendsoap/cline/HttpSoapSender.java
URL: http://svn.apache.org/viewvc/ode/trunk/tools/src/main/java/org/apache/ode/tools/sendsoap/cline/HttpSoapSender.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/tools/src/main/java/org/apache/ode/tools/sendsoap/cline/HttpSoapSender.java (original)
+++ ode/trunk/tools/src/main/java/org/apache/ode/tools/sendsoap/cline/HttpSoapSender.java Thu May 27 18:09:53 2010
@@ -107,7 +107,7 @@ public class HttpSoapSender extends Base
             m.appendReplacement(sb, now + "-" + c++);
         }
         m.appendTail(sb);
-        SimpleHttpConnectionManager mgr = new SimpleHttpConnectionManager();  
+        SimpleHttpConnectionManager mgr = new SimpleHttpConnectionManager();
         mgr.getParams().setConnectionTimeout(60000);
         mgr.getParams().setSoTimeout(60000);
         HttpClient httpClient = new HttpClient(mgr);

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/CronExpression.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/CronExpression.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/CronExpression.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/CronExpression.java Thu May 27 18:09:53 2010
@@ -33,14 +33,14 @@ import java.util.TreeSet;
 
 
 /**
- * Provides a parser and evaluator for unix-like cron expressions. Cron 
+ * Provides a parser and evaluator for unix-like cron expressions. Cron
  * expressions provide the ability to specify complex time combinations such as
- * &quot;At 8:00am every Monday through Friday&quot; or &quot;At 1:30am every 
- * last Friday of the month&quot;. 
+ * &quot;At 8:00am every Monday through Friday&quot; or &quot;At 1:30am every
+ * last Friday of the month&quot;.
  * <P>
  * Cron expressions are comprised of 6 required fields and one optional field
  * separated by white space. The fields respectively are described as follows:
- * 
+ *
  * <table cellspacing="8">
  * <tr>
  * <th align="left">Field Name</th>
@@ -100,7 +100,7 @@ import java.util.TreeSet;
  * </tr>
  * </table>
  * <P>
- * The '*' character is used to specify all values. For example, &quot;*&quot; 
+ * The '*' character is used to specify all values. For example, &quot;*&quot;
  * in the minute field means &quot;every minute&quot;.
  * <P>
  * The '?' character is allowed for the day-of-month and day-of-week fields. It
@@ -115,54 +115,54 @@ import java.util.TreeSet;
  * Wednesday, and Friday&quot;.
  * <P>
  * The '/' character is used to specify increments. For example &quot;0/15&quot;
- * in the seconds field means &quot;the seconds 0, 15, 30, and 45&quot;. And 
+ * in the seconds field means &quot;the seconds 0, 15, 30, and 45&quot;. And
  * &quot;5/15&quot; in the seconds field means &quot;the seconds 5, 20, 35, and
  * 50&quot;.  Specifying '*' before the  '/' is equivalent to specifying 0 is
  * the value to start with. Essentially, for each field in the expression, there
- * is a set of numbers that can be turned on or off. For seconds and minutes, 
+ * is a set of numbers that can be turned on or off. For seconds and minutes,
  * the numbers range from 0 to 59. For hours 0 to 23, for days of the month 0 to
  * 31, and for months 1 to 12. The &quot;/&quot; character simply helps you turn
  * on every &quot;nth&quot; value in the given set. Thus &quot;7/6&quot; in the
- * month field only turns on month &quot;7&quot;, it does NOT mean every 6th 
- * month, please note that subtlety.  
+ * month field only turns on month &quot;7&quot;, it does NOT mean every 6th
+ * month, please note that subtlety.
  * <P>
  * The 'L' character is allowed for the day-of-month and day-of-week fields.
- * This character is short-hand for &quot;last&quot;, but it has different 
- * meaning in each of the two fields. For example, the value &quot;L&quot; in 
- * the day-of-month field means &quot;the last day of the month&quot; - day 31 
- * for January, day 28 for February on non-leap years. If used in the 
- * day-of-week field by itself, it simply means &quot;7&quot; or 
+ * This character is short-hand for &quot;last&quot;, but it has different
+ * meaning in each of the two fields. For example, the value &quot;L&quot; in
+ * the day-of-month field means &quot;the last day of the month&quot; - day 31
+ * for January, day 28 for February on non-leap years. If used in the
+ * day-of-week field by itself, it simply means &quot;7&quot; or
  * &quot;SAT&quot;. But if used in the day-of-week field after another value, it
  * means &quot;the last xxx day of the month&quot; - for example &quot;6L&quot;
  * means &quot;the last friday of the month&quot;. When using the 'L' option, it
- * is important not to specify lists, or ranges of values, as you'll get 
+ * is important not to specify lists, or ranges of values, as you'll get
  * confusing results.
  * <P>
- * The 'W' character is allowed for the day-of-month field.  This character 
- * is used to specify the weekday (Monday-Friday) nearest the given day.  As an 
- * example, if you were to specify &quot;15W&quot; as the value for the 
+ * The 'W' character is allowed for the day-of-month field.  This character
+ * is used to specify the weekday (Monday-Friday) nearest the given day.  As an
+ * example, if you were to specify &quot;15W&quot; as the value for the
  * day-of-month field, the meaning is: &quot;the nearest weekday to the 15th of
- * the month&quot;. So if the 15th is a Saturday, the trigger will fire on 
+ * the month&quot;. So if the 15th is a Saturday, the trigger will fire on
  * Friday the 14th. If the 15th is a Sunday, the trigger will fire on Monday the
- * 16th. If the 15th is a Tuesday, then it will fire on Tuesday the 15th. 
+ * 16th. If the 15th is a Tuesday, then it will fire on Tuesday the 15th.
  * However if you specify &quot;1W&quot; as the value for day-of-month, and the
- * 1st is a Saturday, the trigger will fire on Monday the 3rd, as it will not 
- * 'jump' over the boundary of a month's days.  The 'W' character can only be 
+ * 1st is a Saturday, the trigger will fire on Monday the 3rd, as it will not
+ * 'jump' over the boundary of a month's days.  The 'W' character can only be
  * specified when the day-of-month is a single day, not a range or list of days.
  * <P>
- * The 'L' and 'W' characters can also be combined for the day-of-month 
- * expression to yield 'LW', which translates to &quot;last weekday of the 
+ * The 'L' and 'W' characters can also be combined for the day-of-month
+ * expression to yield 'LW', which translates to &quot;last weekday of the
  * month&quot;.
  * <P>
  * The '#' character is allowed for the day-of-week field. This character is
- * used to specify &quot;the nth&quot; XXX day of the month. For example, the 
- * value of &quot;6#3&quot; in the day-of-week field means the third Friday of 
- * the month (day 6 = Friday and &quot;#3&quot; = the 3rd one in the month). 
- * Other examples: &quot;2#1&quot; = the first Monday of the month and 
+ * used to specify &quot;the nth&quot; XXX day of the month. For example, the
+ * value of &quot;6#3&quot; in the day-of-week field means the third Friday of
+ * the month (day 6 = Friday and &quot;#3&quot; = the 3rd one in the month).
+ * Other examples: &quot;2#1&quot; = the first Monday of the month and
  * &quot;4#5&quot; = the fifth Wednesday of the month. Note that if you specify
  * &quot;#5&quot; and there is not 5 of the given day-of-week in the month, then
  * no firing will occur that month.  If the '#' character is used, there can
- * only be one expression in the day-of-week field (&quot;3#1,6#3&quot; is 
+ * only be one expression in the day-of-week field (&quot;3#1,6#3&quot; is
  * not valid, since there are two expressions).
  * <P>
  * <!--The 'C' character is allowed for the day-of-month and day-of-week fields.
@@ -175,24 +175,24 @@ import java.util.TreeSet;
  * <P>
  * The legal characters and the names of months and days of the week are not
  * case sensitive.
- * 
+ *
  * <p>
  * <b>NOTES:</b>
  * <ul>
  * <li>Support for specifying both a day-of-week and a day-of-month value is
  * not complete (you'll need to use the '?' character in one of these fields).
  * </li>
- * <li>Overflowing ranges is supported - that is, having a larger number on 
- * the left hand side than the right. You might do 22-2 to catch 10 o'clock 
- * at night until 2 o'clock in the morning, or you might have NOV-FEB. It is 
- * very important to note that overuse of overflowing ranges creates ranges 
- * that don't make sense and no effort has been made to determine which 
- * interpretation CronExpression chooses. An example would be 
+ * <li>Overflowing ranges is supported - that is, having a larger number on
+ * the left hand side than the right. You might do 22-2 to catch 10 o'clock
+ * at night until 2 o'clock in the morning, or you might have NOV-FEB. It is
+ * very important to note that overuse of overflowing ranges creates ranges
+ * that don't make sense and no effort has been made to determine which
+ * interpretation CronExpression chooses. An example would be
  * "0 0 14-6 ? * FRI-MON". </li>
  * </ul>
  * </p>
- * 
- * 
+ *
+ *
  * @author Sharada Jambula, James House
  * @author Contributions from Mads Henderson
  * @author Refactoring from CronTrigger to CronExpression by Aaron Craven
@@ -201,7 +201,7 @@ import java.util.TreeSet;
 public class CronExpression implements Serializable, Cloneable {
 
     private static final long serialVersionUID = 12423409423L;
-    
+
     protected static final int SECOND = 0;
     protected static final int MINUTE = 1;
     protected static final int HOUR = 2;
@@ -213,7 +213,7 @@ public class CronExpression implements S
     protected static final int NO_SPEC_INT = 98; // '?'
     protected static final Integer ALL_SPEC = new Integer(ALL_SPEC_INT);
     protected static final Integer NO_SPEC = new Integer(NO_SPEC_INT);
-    
+
     protected static final Map monthMap = new HashMap(20);
     protected static final Map dayMap = new HashMap(60);
     static {
@@ -254,32 +254,32 @@ public class CronExpression implements S
     protected transient boolean lastdayOfMonth = false;
     protected transient boolean nearestWeekday = false;
     protected transient boolean expressionParsed = false;
-    
+
     /**
-     * Constructs a new <CODE>CronExpression</CODE> based on the specified 
+     * Constructs a new <CODE>CronExpression</CODE> based on the specified
      * parameter.
-     * 
+     *
      * @param cronExpression String representation of the cron expression the
      *                       new object should represent
      * @throws java.text.ParseException
-     *         if the string expression cannot be parsed into a valid 
+     *         if the string expression cannot be parsed into a valid
      *         <CODE>CronExpression</CODE>
      */
     public CronExpression(String cronExpression) throws ParseException {
         if (cronExpression == null) {
             throw new IllegalArgumentException("cronExpression cannot be null");
         }
-        
+
         this.cronExpression = cronExpression.toUpperCase(Locale.US);
-        
+
         buildExpression(this.cronExpression);
     }
-    
+
     /**
      * Indicates whether the given date satisfies the cron expression. Note that
      * milliseconds are ignored, so two Dates falling on different milliseconds
      * of the same second will always have the same result here.
-     * 
+     *
      * @param date the date to evaluate
      * @return a boolean indicating whether the given date satisfies the cron
      *         expression
@@ -289,18 +289,18 @@ public class CronExpression implements S
         testDateCal.setTime(date);
         testDateCal.set(Calendar.MILLISECOND, 0);
         Date originalDate = testDateCal.getTime();
-        
+
         testDateCal.add(Calendar.SECOND, -1);
-        
+
         Date timeAfter = getTimeAfter(testDateCal.getTime());
 
         return ((timeAfter != null) && (timeAfter.equals(originalDate)));
     }
-    
+
     /**
      * Returns the next date/time <I>after</I> the given date/time which
      * satisfies the cron expression.
-     * 
+     *
      * @param date the date/time at which to begin the search for the next valid
      *             date/time
      * @return the next valid date/time
@@ -308,46 +308,46 @@ public class CronExpression implements S
     public Date getNextValidTimeAfter(Date date) {
         return getTimeAfter(date);
     }
-    
+
     /**
      * Returns the next date/time <I>after</I> the given date/time which does
      * <I>not</I> satisfy the expression
-     * 
-     * @param date the date/time at which to begin the search for the next 
+     *
+     * @param date the date/time at which to begin the search for the next
      *             invalid date/time
      * @return the next valid date/time
      */
     public Date getNextInvalidTimeAfter(Date date) {
         long difference = 1000;
-        
+
         //move back to the nearest second so differences will be accurate
         Calendar adjustCal = Calendar.getInstance(getTimeZone());
         adjustCal.setTime(date);
         adjustCal.set(Calendar.MILLISECOND, 0);
         Date lastDate = adjustCal.getTime();
-        
+
         Date newDate = null;
-        
+
         //TODO: (QUARTZ-481) IMPROVE THIS! The following is a BAD solution to this problem. Performance will be very bad here, depending on the cron expression. It is, however A solution.
-        
+
         //keep getting the next included time until it's farther than one second
         // apart. At that point, lastDate is the last valid fire time. We return
         // the second immediately following it.
         while (difference == 1000) {
             newDate = getTimeAfter(lastDate);
-            
+
             difference = newDate.getTime() - lastDate.getTime();
-            
+
             if (difference == 1000) {
                 lastDate = newDate;
             }
         }
-        
+
         return new Date(lastDate.getTime() + 1000);
     }
-    
+
     /**
-     * Returns the time zone for which this <code>CronExpression</code> 
+     * Returns the time zone for which this <code>CronExpression</code>
      * will be resolved.
      */
     public TimeZone getTimeZone() {
@@ -359,16 +359,16 @@ public class CronExpression implements S
     }
 
     /**
-     * Sets the time zone for which  this <code>CronExpression</code> 
+     * Sets the time zone for which  this <code>CronExpression</code>
      * will be resolved.
      */
     public void setTimeZone(TimeZone timeZone) {
         this.timeZone = timeZone;
     }
-    
+
     /**
      * Returns the string representation of the <CODE>CronExpression</CODE>
-     * 
+     *
      * @return a string representation of the <CODE>CronExpression</CODE>
      */
     public String toString() {
@@ -376,24 +376,24 @@ public class CronExpression implements S
     }
 
     /**
-     * Indicates whether the specified cron expression can be parsed into a 
+     * Indicates whether the specified cron expression can be parsed into a
      * valid cron expression
-     * 
+     *
      * @param cronExpression the expression to evaluate
      * @return a boolean indicating whether the given expression is a valid cron
      *         expression
      */
     public static boolean isValidExpression(String cronExpression) {
-        
+
         try {
             new CronExpression(cronExpression);
         } catch (ParseException pe) {
             return false;
         }
-        
+
         return true;
     }
-    
+
     ////////////////////////////////////////////////////////////////////////////
     //
     // Expression Parsing Functions
@@ -443,7 +443,7 @@ public class CronExpression implements S
                 if(exprOn == DAY_OF_WEEK && expr.indexOf('L') != -1 && expr.length() > 1  && expr.indexOf(",") >= 0) {
                     throw new ParseException("Support for specifying 'L' with other days of the week is not implemented", -1);
                 }
-                
+
                 StringTokenizer vTok = new StringTokenizer(expr, ",");
                 while (vTok.hasMoreTokens()) {
                     String v = vTok.nextToken();
@@ -469,9 +469,9 @@ public class CronExpression implements S
             boolean dayOfMSpec = !dom.contains(NO_SPEC);
             boolean dayOfWSpec = !dow.contains(NO_SPEC);
 
-            if (dayOfMSpec && !dayOfWSpec) { 
+            if (dayOfMSpec && !dayOfWSpec) {
                 // skip
-            } else if (dayOfWSpec && !dayOfMSpec) { 
+            } else if (dayOfWSpec && !dayOfMSpec) {
                 // skip
             } else {
                 throw new ParseException(
@@ -563,7 +563,7 @@ public class CronExpression implements S
 
         if (c == '?') {
             i++;
-            if ((i + 1) < s.length() 
+            if ((i + 1) < s.length()
                     && (s.charAt(i) != ' ' && s.charAt(i + 1) != '\t')) {
                 throw new ParseException("Illegal character after '?': "
                             + s.charAt(i), i);
@@ -592,7 +592,7 @@ public class CronExpression implements S
                 return i + 1;
             } else if (c == '/'
                     && ((i + 1) >= s.length() || s.charAt(i + 1) == ' ' || s
-                            .charAt(i + 1) == '\t')) { 
+                            .charAt(i + 1) == '\t')) {
                 throw new ParseException("'/' must be followed by an integer.", i);
             } else if (c == '*') {
                 i++;
@@ -612,11 +612,11 @@ public class CronExpression implements S
                 }
                 if (incr > 59 && (type == SECOND || type == MINUTE)) {
                     throw new ParseException("Increment > 60 : " + incr, i);
-                } else if (incr > 23 && (type == HOUR)) { 
+                } else if (incr > 23 && (type == HOUR)) {
                     throw new ParseException("Increment > 24 : " + incr, i);
-                } else if (incr > 31 && (type == DAY_OF_MONTH)) { 
+                } else if (incr > 31 && (type == DAY_OF_MONTH)) {
                     throw new ParseException("Increment > 31 : " + incr, i);
-                } else if (incr > 7 && (type == DAY_OF_WEEK)) { 
+                } else if (incr > 7 && (type == DAY_OF_WEEK)) {
                     throw new ParseException("Increment > 7 : " + incr, i);
                 } else if (incr > 12 && (type == MONTH)) {
                     throw new ParseException("Increment > 12 : " + incr, i);
@@ -667,7 +667,7 @@ public class CronExpression implements S
 
     protected int checkNext(int pos, String s, int val, int type)
         throws ParseException {
-        
+
         int end = -1;
         int i = pos;
 
@@ -689,7 +689,7 @@ public class CronExpression implements S
             i++;
             return i;
         }
-        
+
         if (c == 'W') {
             if (type == DAY_OF_MONTH) {
                 nearestWeekday = true;
@@ -796,7 +796,7 @@ public class CronExpression implements S
     public String getCronExpression() {
         return cronExpression;
     }
-    
+
     public String getExpressionSummary() {
         StringBuffer buf = new StringBuffer();
 
@@ -907,7 +907,7 @@ public class CronExpression implements S
 
     protected void addToSet(int val, int end, int incr, int type)
         throws ParseException {
-        
+
         TreeSet set = getSet(type);
 
         if (type == SECOND || type == MINUTE) {
@@ -922,7 +922,7 @@ public class CronExpression implements S
                         "Hour values must be between 0 and 23", -1);
             }
         } else if (type == DAY_OF_MONTH) {
-            if ((val < 1 || val > 31 || end > 31) && (val != ALL_SPEC_INT) 
+            if ((val < 1 || val > 31 || end > 31) && (val != ALL_SPEC_INT)
                     && (val != NO_SPEC_INT)) {
                 throw new ParseException(
                         "Day of month values must be between 1 and 31", -1);
@@ -946,7 +946,7 @@ public class CronExpression implements S
             } else {
                 set.add(NO_SPEC);
             }
-            
+
             return;
         }
 
@@ -1002,8 +1002,8 @@ public class CronExpression implements S
             }
         }
 
-        // if the end of the range is before the start, then we need to overflow into 
-        // the next day, month etc. This is done by adding the maximum amount for that 
+        // if the end of the range is before the start, then we need to overflow into
+        // the next day, month etc. This is done by adding the maximum amount for that
         // type, and using modulus max to determine the value being added.
         int max = -1;
         if (stopAt < startAt) {
@@ -1071,7 +1071,7 @@ public class CronExpression implements S
             c = s.charAt(i);
         }
         ValueSet val = new ValueSet();
-        
+
         val.pos = (i < s.length()) ? i : i + 1;
         val.value = Integer.parseInt(s1);
         return val;
@@ -1195,7 +1195,7 @@ public class CronExpression implements S
             // 1-based
             t = -1;
             int tmon = mon;
-            
+
             // get day...................................................
             boolean dayOfMSpec = !daysOfMonth.contains(NO_SPEC);
             boolean dayOfWSpec = !daysOfWeek.contains(NO_SPEC);
@@ -1208,7 +1208,7 @@ public class CronExpression implements S
                     } else {
                         t = day;
                         day = getLastDayOfMonth(mon, cl.get(Calendar.YEAR));
-                        
+
                         java.util.Calendar tcal = java.util.Calendar.getInstance(getTimeZone());
                         tcal.set(Calendar.SECOND, 0);
                         tcal.set(Calendar.MINUTE, 0);
@@ -1216,7 +1216,7 @@ public class CronExpression implements S
                         tcal.set(Calendar.DAY_OF_MONTH, day);
                         tcal.set(Calendar.MONTH, mon - 1);
                         tcal.set(Calendar.YEAR, cl.get(Calendar.YEAR));
-                        
+
                         int ldom = getLastDayOfMonth(mon, cl.get(Calendar.YEAR));
                         int dow = tcal.get(Calendar.DAY_OF_WEEK);
 
@@ -1224,12 +1224,12 @@ public class CronExpression implements S
                             day += 2;
                         } else if(dow == Calendar.SATURDAY) {
                             day -= 1;
-                        } else if(dow == Calendar.SUNDAY && day == ldom) { 
+                        } else if(dow == Calendar.SUNDAY && day == ldom) {
                             day -= 2;
-                        } else if(dow == Calendar.SUNDAY) { 
+                        } else if(dow == Calendar.SUNDAY) {
                             day += 1;
                         }
-                    
+
                         tcal.set(Calendar.SECOND, sec);
                         tcal.set(Calendar.MINUTE, min);
                         tcal.set(Calendar.HOUR_OF_DAY, hr);
@@ -1252,7 +1252,7 @@ public class CronExpression implements S
                     tcal.set(Calendar.DAY_OF_MONTH, day);
                     tcal.set(Calendar.MONTH, mon - 1);
                     tcal.set(Calendar.YEAR, cl.get(Calendar.YEAR));
-                    
+
                     int ldom = getLastDayOfMonth(mon, cl.get(Calendar.YEAR));
                     int dow = tcal.get(Calendar.DAY_OF_WEEK);
 
@@ -1260,13 +1260,13 @@ public class CronExpression implements S
                         day += 2;
                     } else if(dow == Calendar.SATURDAY) {
                         day -= 1;
-                    } else if(dow == Calendar.SUNDAY && day == ldom) { 
+                    } else if(dow == Calendar.SUNDAY && day == ldom) {
                         day -= 2;
-                    } else if(dow == Calendar.SUNDAY) { 
+                    } else if(dow == Calendar.SUNDAY) {
                         day += 1;
                     }
-                        
-                
+
+
                     tcal.set(Calendar.SECOND, sec);
                     tcal.set(Calendar.MINUTE, min);
                     tcal.set(Calendar.HOUR_OF_DAY, hr);
@@ -1290,7 +1290,7 @@ public class CronExpression implements S
                     day = ((Integer) daysOfMonth.first()).intValue();
                     mon++;
                 }
-                
+
                 if (day != t || mon != tmon) {
                     cl.set(Calendar.SECOND, 0);
                     cl.set(Calendar.MINUTE, 0);
@@ -1505,7 +1505,7 @@ public class CronExpression implements S
     /**
      * Advance the calendar to the particular hour paying particular attention
      * to daylight saving problems.
-     * 
+     *
      * @param cal
      * @param hour
      */
@@ -1519,21 +1519,21 @@ public class CronExpression implements S
     /**
      * NOT YET IMPLEMENTED: Returns the time before the given time
      * that the <code>CronExpression</code> matches.
-     */ 
-    protected Date getTimeBefore(Date endTime) { 
+     */
+    protected Date getTimeBefore(Date endTime) {
         // TODO: implement QUARTZ-423
         return null;
     }
 
     /**
-     * NOT YET IMPLEMENTED: Returns the final time that the 
+     * NOT YET IMPLEMENTED: Returns the final time that the
      * <code>CronExpression</code> will match.
      */
     public Date getFinalFireTime() {
         // TODO: implement QUARTZ-423
         return null;
     }
-    
+
     protected boolean isLeapYear(int year) {
         return ((year % 4 == 0 && year % 100 != 0) || (year % 400 == 0));
     }
@@ -1570,18 +1570,18 @@ public class CronExpression implements S
                         + monthNum);
         }
     }
-    
+
 
     private void readObject(java.io.ObjectInputStream stream)
         throws java.io.IOException, ClassNotFoundException {
-        
+
         stream.defaultReadObject();
         try {
             buildExpression(cronExpression);
         } catch (Exception ignore) {
         } // never happens
-    }    
-    
+    }
+
     public Object clone() {
         CronExpression copy = null;
         try {
@@ -1591,7 +1591,7 @@ public class CronExpression implements S
             throw new IncompatibleClassChangeError("Not Cloneable.");
         }
         return copy;
-    }        
+    }
 }
 
 class ValueSet {

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/DOMUtils.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/DOMUtils.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/DOMUtils.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/DOMUtils.java Thu May 27 18:09:53 2010
@@ -355,7 +355,7 @@ public class DOMUtils {
                 }
             }
             n = n.getParentNode();
-        } 
+        }
         return pref;
     }
 
@@ -710,7 +710,7 @@ public class DOMUtils {
         }
         return new QName(namespaceUri, localName);
     }
-    
+
     public static QName getNodeQName(String qualifiedName) {
         int index = qualifiedName.indexOf(":");
         if (index >= 0) {
@@ -1053,7 +1053,7 @@ public class DOMUtils {
                 ret.add((Element)c);
         }
 
-        
+
         return ret;
     }
 
@@ -1081,18 +1081,18 @@ public class DOMUtils {
         String prefix = qName.getPrefix(), localPart = qName.getLocalPart();
         return (prefix == null || "".equals(prefix)) ? localPart : (prefix + ":" + localPart);
     }
-    
+
     /**
-     * Deep clone, but don't fry, the given node in the context of the given document. 
-     * For all intents and purposes, the clone is the exact same copy of the node, 
-     * except that it might have a different owner document. 
-     * 
+     * Deep clone, but don't fry, the given node in the context of the given document.
+     * For all intents and purposes, the clone is the exact same copy of the node,
+     * except that it might have a different owner document.
+     *
      * This method is fool-proof, unlike the <code>adoptNode</code> or <code>adoptNode</code> methods,
      * in that it doesn't assume that the given node has a parent or a owner document.
-     * 
+     *
      * @param document
      * @param sourceNode
-     * @return a clone of node 
+     * @return a clone of node
      */
     public static Node cloneNode(Document document, Node sourceNode) {
         Node clonedNode = null;
@@ -1101,12 +1101,12 @@ public class DOMUtils {
         QName sourceQName = getNodeQName(sourceNode);
         String nodeName = sourceQName.getLocalPart();
         String namespaceURI = sourceQName.getNamespaceURI();
-        
+
         // if the node is unqualified, don't assume that it inherits the WS-BPEL target namespace
         if (Namespaces.WSBPEL2_0_FINAL_EXEC.equals(namespaceURI)) {
             namespaceURI = null;
         }
-        
+
         switch (sourceNode.getNodeType()) {
         case Node.ATTRIBUTE_NODE:
             if (namespaceURI == null) {
@@ -1146,7 +1146,7 @@ public class DOMUtils {
             if (namespaceURI == null) {
                 clonedNode = document.createElement(nodeName);
             } else {
-                String prefix = namespaceURI.equals(Namespaces.XMLNS_URI) ? 
+                String prefix = namespaceURI.equals(Namespaces.XMLNS_URI) ?
                         "xmlns" : ((Element) sourceNode).lookupPrefix(namespaceURI);
                 if (prefix != null && !"".equals(prefix)) {
                     nodeName = prefix + ":" + nodeName;
@@ -1185,7 +1185,7 @@ public class DOMUtils {
         default:
             break;
         }
-                
+
         // clone children of element and attribute nodes
         NodeList sourceChildren = sourceNode.getChildNodes();
         if (sourceChildren != null) {
@@ -1194,7 +1194,7 @@ public class DOMUtils {
                 Node clonedChild = cloneNode(document, sourceChild);
                 clonedNode.appendChild(clonedChild);
                 // if the child has a textual value, parse it for any embedded prefixes
-                if (clonedChild.getNodeType() == Node.TEXT_NODE || 
+                if (clonedChild.getNodeType() == Node.TEXT_NODE ||
                         clonedChild.getNodeType() == Node.CDATA_SECTION_NODE) {
                     parseEmbeddedPrefixes(sourceNode, clonedNode, clonedChild);
                 }
@@ -1205,7 +1205,7 @@ public class DOMUtils {
 
     /**
      * Parse the text in the cloneChild for any embedded prefixes, and define it in it's parent element
-     *  
+     *
      * @param sourceNode
      * @param clonedNode
      * @param clonedChild
@@ -1221,14 +1221,14 @@ public class DOMUtils {
             // couldn't find an element to set prefixes on, so bail out
             return;
         }
-        
+
         String text = ((Text) clonedChild).getNodeValue();
         if (text != null && text.indexOf(":") > 0) {
             Name11Checker nameChecker = Name11Checker.getInstance();
             for (int colonIndex = text.indexOf(":"); colonIndex != -1 && colonIndex < text.length(); colonIndex = text.indexOf(":", colonIndex +  1)) {
                 StringBuffer prefixString = new StringBuffer();
-                for (int prefixIndex = colonIndex - 1; 
-                        prefixIndex >= 0 && nameChecker.isNCNameChar(text.charAt(prefixIndex)); 
+                for (int prefixIndex = colonIndex - 1;
+                        prefixIndex >= 0 && nameChecker.isNCNameChar(text.charAt(prefixIndex));
                         prefixIndex--) {
                     prefixString.append(text.charAt(prefixIndex));
                 }

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/DbIsolation.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/DbIsolation.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/DbIsolation.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/DbIsolation.java Thu May 27 18:09:53 2010
@@ -33,7 +33,7 @@ public class DbIsolation {
     private static final Log __log = LogFactory.getLog(DbIsolation.class);
     private static int _isolationLevel;
 
-    // Read Ode-specific isolation level configuration 
+    // Read Ode-specific isolation level configuration
     static {
         try {
             _isolationLevel = Integer.parseInt(System.getProperty("ode.connection.isolation", "2"));
@@ -45,11 +45,11 @@ public class DbIsolation {
     public static int getOdeIsolationLevel() {
         return _isolationLevel;
     }
-    
+
     public static void setOdeIsolationLevel(int isolationLevel) {
         _isolationLevel = isolationLevel;
     }
-    
+
     /**
      * Set Ode-specific isolation level on the connection, if needed.
      */
@@ -60,7 +60,7 @@ public class DbIsolation {
                 c.setTransactionIsolation(_isolationLevel);
             }
         } catch (Exception e) {
-            if (__log.isDebugEnabled()) 
+            if (__log.isDebugEnabled())
                 __log.debug("Error while setting isolation level to "+_isolationLevel, e);
         }
     }

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/GUID.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/GUID.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/GUID.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/GUID.java Thu May 27 18:09:53 2010
@@ -27,13 +27,13 @@ import java.util.Set;
 /**
  * This class is used to generate globally unique IDs. The requirements for
  * global uniqueness are as follows:
- * 
+ *
  * <pre>
  *     1) The time on any machine is never set back.
  *     2) Each machine has a unique IP address.
  *     3) Each process has the 'org.apache.ode.uid.port' property set to the
  *        same non-zero value.
- * 
+ *
  *    byte:    0   1   2   3   4  5  6  7  8  9  10  11   12  13
  *             [ IPADDRESS ]  [   START TIME IN MS     ] [ count]
  *    This format allow more compact string representation.
@@ -56,7 +56,7 @@ public final class GUID implements Clone
     static String PROP_PORT = "org.apache.ode.uid.port";
 
     static int port = Integer.getInteger(PROP_PORT, 33666);
-    
+
     // 32 bits
     private static final byte[] ipadd = {127,0,0,1};
 
@@ -100,10 +100,10 @@ public final class GUID implements Clone
 
     /**
      * Reconstitute a GUID from it's string representation
-     * 
+     *
      * @param str
      *            DOCUMENTME
-     * 
+     *
      * @throws MalformedGuidException
      *             DOCUMENTME
      */
@@ -193,7 +193,7 @@ public final class GUID implements Clone
     /**
      * Convert a GUID to it's string representation. This will return a string
      * of at most 32 bytes.
-     * 
+     *
      * @return DOCUMENTME
      */
     public String toString() {
@@ -251,7 +251,7 @@ public final class GUID implements Clone
             super("Malformed guid: " + guid);
         }
     }
-    
+
     public static String makeGUID(String digest) {
         String val = "0";
         int maxlen = 32;
@@ -262,7 +262,7 @@ public final class GUID implements Clone
             val = new BigInteger(val, base).add(BigInteger.valueOf((long) c)).multiply(BigInteger.valueOf(prime)).toString(base);
             if (val.length() > maxlen) val = val.substring(0, maxlen);
         }
-        
+
         return val;
     }
 }

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/InternPool.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/InternPool.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/InternPool.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/InternPool.java Thu May 27 18:09:53 2010
@@ -30,8 +30,8 @@ import org.apache.commons.collections.ma
 
 
 /**
- * A key value based cache that internalizes immutable values 
- * so that they can be shared across various BPEL objects. 
+ * A key value based cache that internalizes immutable values
+ * so that they can be shared across various BPEL objects.
  *
   */
 public class InternPool {
@@ -47,9 +47,9 @@ public class InternPool {
     /**
      * Runs the given block in the context of a cache.
      * If you do not run your block this way, the caching
-     * mechanism will be disabled.    
+     * mechanism will be disabled.
      *
-     * @param block block 
+     * @param block block
      */
     public static void runBlock(InternableBlock block) {
         String processId = getProcessId();
@@ -62,7 +62,7 @@ public class InternPool {
     /**
      * Returns an internalized value if it already exists in the cache
      *
-     * @param value value 
+     * @param value value
      *
      * @return the internalized value
      */
@@ -72,7 +72,7 @@ public class InternPool {
         if (!cachedBlocks.contains(processId)) {
             return value;
         }
-        
+
         synchronized (cachedValues) {
             List values = (List) cachedValues.get(processId, key);
             if (values == null) {
@@ -83,7 +83,7 @@ public class InternPool {
             if (values.contains(value)) {
                 intern = values.get(values.indexOf(value));
             } else {
-                values.add(intern = value);            	
+                values.add(intern = value);
             }
 
             return intern;
@@ -93,7 +93,7 @@ public class InternPool {
     /**
      * Clears all the values corresponding to the given process
      *
-     * @param processId processId 
+     * @param processId processId
      */
     protected static void clearAll(String processId) {
         synchronized (cachedValues) {
@@ -112,7 +112,7 @@ public class InternPool {
 
     /**
      * An interface that clients should implement to run their
-     * blocks of code in the context of this caching mechanism. 
+     * blocks of code in the context of this caching mechanism.
      */
     public interface InternableBlock {
         /**

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/LoggingInterceptor.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/LoggingInterceptor.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/LoggingInterceptor.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/LoggingInterceptor.java Thu May 27 18:09:53 2010
@@ -64,21 +64,21 @@ public class LoggingInterceptor<T> imple
         _log = log;
         _delegate = delegate;
     }
-    
+
     public Object invoke(Object proxy, Method method, Object[] args)
             throws Throwable {
         try {
-            if (method.getDeclaringClass() == DataSource.class 
+            if (method.getDeclaringClass() == DataSource.class
                     && "getConnection".equals(method.getName())) {
                 Connection conn = (Connection)method.invoke(_delegate, args);
                 print("getConnection (tx=" + conn.getTransactionIsolation() + ")");
-                return Proxy.newProxyInstance(_delegate.getClass().getClassLoader(), 
+                return Proxy.newProxyInstance(_delegate.getClass().getClassLoader(),
                         new Class[] {Connection.class}, new LoggingInterceptor<Connection>(conn, _log));
-            } else if (method.getDeclaringClass() == Connection.class 
+            } else if (method.getDeclaringClass() == Connection.class
                     && Statement.class.isAssignableFrom(method.getReturnType())) {
                 Statement stmt = (Statement)method.invoke(_delegate, args);
                 print(method, args);
-                return Proxy.newProxyInstance(_delegate.getClass().getClassLoader(), 
+                return Proxy.newProxyInstance(_delegate.getClass().getClassLoader(),
                         new Class[] {method.getReturnType()}, new LoggingInterceptor<Statement>(stmt, _log));
             } else {
                 print(method, args);
@@ -104,7 +104,7 @@ public class LoggingInterceptor<T> imple
                 print("rollback()");
             } else if ("setTransactionIsolation".equals(method.getName())) {
                 print("Set isolation level to " + args[0]);
-            } 
+            }
             // JDBC Statement
             else if (method.getName().startsWith("execute")) {
                 print(method.getName() + ", " + getParams());
@@ -163,9 +163,9 @@ public class LoggingInterceptor<T> imple
             _log.debug(str);
         else System.out.println(str);
     }
-    
+
     public static DataSource createLoggingDS(DataSource ds, Log log) {
-        return (DataSource)Proxy.newProxyInstance(ds.getClass().getClassLoader(), 
+        return (DataSource)Proxy.newProxyInstance(ds.getClass().getClassLoader(),
                 new Class[] {DataSource.class}, new LoggingInterceptor<DataSource>(ds,log));
     }
 }

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/NSContext.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/NSContext.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/NSContext.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/NSContext.java Thu May 27 18:09:53 2010
@@ -47,7 +47,7 @@ import org.apache.ode.utils.stl.Transfor
  * with fairly generic applicability. This class allows clients to manipulate
  * the context through publicly accessible methods, and provides serialization
  * support.
- * 
+ *
  * @see NamespaceContext
  */
 public class NSContext implements NamespaceContext, Externalizable {
@@ -65,7 +65,7 @@ public class NSContext implements Namesp
             return super.put(prefix, uri);
         }
     };
-    
+
     public NSContext() {
     }
 
@@ -105,7 +105,7 @@ public class NSContext implements Namesp
 
     /**
      * Get all the prefixes with a URI mapping in this context
-     * 
+     *
      * @return{@link Set} of prefix {@link String}s with a URI mapping in this
      *         context
      */
@@ -115,7 +115,7 @@ public class NSContext implements Namesp
 
     /**
      * Get all the URIs with a prefix mapping in this context
-     * 
+     *
      * @return{@link Set} of URI {@link String}s with a prefix mapping in this
      *         context
      */
@@ -139,10 +139,10 @@ public class NSContext implements Namesp
             __log.trace("readExternal: contents=" + _prefixToUriMap);
         }
     }
-    
+
     /**
      * Add a prefix to URI mapping to this context.
-     * 
+     *
      * @param prefix
      *            prefix
      * @param uri
@@ -153,7 +153,7 @@ public class NSContext implements Namesp
             uri = "";
         if (prefix == null)
             prefix = "";
-        
+
         if (__log.isTraceEnabled()) {
             __log.trace("register(prefix=" + prefix + ", uri=" + uri + ")");
         }
@@ -163,7 +163,7 @@ public class NSContext implements Namesp
 
     /**
      * Register a set of URI mappings at once.
-     * 
+     *
      * @param prefixMapping
      *            set (map rather) of prefix-to-URI mappings.
      */

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/NamespaceStack.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/NamespaceStack.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/NamespaceStack.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/NamespaceStack.java Thu May 27 18:09:53 2010
@@ -33,14 +33,14 @@ import org.xml.sax.SAXException;
  * This is a utility for a SAX <code>ContentHandler</code> implementation to use in
  * tracking namespace declarations during a parse.  The assumption is that the
  * handler has access to the full stream of events relevant to managing the
- * declarations.  The primary use case is the resolution of <code>String</code>s, 
+ * declarations.  The primary use case is the resolution of <code>String</code>s,
  * e.g., from attribute values or element content, to <code>QName</code> objects.
  * </p>
  */
 public class NamespaceStack {
 
   private Frame _current;
-  
+
   /**
    * <p>
    * Construct a new instance with the bare minimum bindings for the
@@ -66,7 +66,7 @@ public class NamespaceStack {
      */
     _current.declarePrefix("","");
   }
-  
+
   /**
    * <p>
    * Convert the current stack of contexts into a single <code>NSContext</code>.
@@ -86,7 +86,7 @@ public class NamespaceStack {
     }
     return n;
   }
-  
+
   /**
    * <p>
    * Push a fresh context onto the stack.  This method should be called somewhere in
@@ -99,7 +99,7 @@ public class NamespaceStack {
   public void pushNewContext() {
     _current = new Frame(_current);
   }
-  
+
   /**
    * <p>
    * Pop a context from the stack.  This method should be called somewhere in the
@@ -114,7 +114,7 @@ public class NamespaceStack {
     }
     _current = _current._parent;
   }
-  
+
   /**
    * <p>
    * Declare a new prefix binding.  This binding will supercede a binding with the
@@ -129,7 +129,7 @@ public class NamespaceStack {
   public void declarePrefix(String prefix, String uri) {
     _current.declarePrefix(prefix==null?"":prefix, uri==null?"":uri);
   }
-  
+
   /**
    * <p>
    * Retrieve the URI bound to the supplied prefix or <code>null</code> if no URI
@@ -142,10 +142,10 @@ public class NamespaceStack {
   public String getNamespaceUri(String prefix) {
     return _current.getNamespaceURI(prefix==null?"":prefix);
   }
-  
+
   /**
    * <p>
-   * Fire the events for the current frame's prefixes into a <code>ContentHandler</code>. 
+   * Fire the events for the current frame's prefixes into a <code>ContentHandler</code>.
    * </p>
    * @param ch the target <code>ContentHandler</code>
    * @throws SAXException if the target method does.
@@ -153,7 +153,7 @@ public class NamespaceStack {
   public void startPrefixMappings(ContentHandler ch) throws SAXException {
     _current.startPrefixMappings(ch);
   }
-  
+
   /**
    * <p>
    * Fire the events for the current frame's prefixes into a <code>ContentHandler</code>.
@@ -164,7 +164,7 @@ public class NamespaceStack {
   public void endPrefixMappings(ContentHandler ch) throws SAXException {
     _current.endPrefixMappings(ch);
   }
-  
+
   /**
    * <p>
    * Allocate and declare a new namespace prefix for the current context that uses
@@ -193,11 +193,11 @@ public class NamespaceStack {
     }
     return pfx;
   }
-  
+
   public String getPrefix(String uri) {
     return toNSContext().getPrefix(uri);
   }
-  
+
   /**
    * <p>
    * Derference the prefix on a QName in <code>String</code> form and return a Java
@@ -229,21 +229,21 @@ public class NamespaceStack {
     }
     return qn;
   }
-  
+
   private class Frame {
-    
+
     Frame _parent;
-    
+
     HashMap<String,String> _bindings;
-    
+
     Frame() {
       // This space intentionally left blank.
     }
-    
+
     Frame(Frame parent) {
       _parent = parent;
     }
-   
+
     void startPrefixMappings(ContentHandler ch) throws SAXException {
       if (_bindings != null) {
         for(Iterator it = _bindings.keySet().iterator();it.hasNext();) {
@@ -252,7 +252,7 @@ public class NamespaceStack {
         }
       }
     }
-    
+
     void endPrefixMappings(ContentHandler ch) throws SAXException {
       if (_bindings != null) {
         for (Iterator it = _bindings.keySet().iterator();it.hasNext();) {
@@ -260,19 +260,19 @@ public class NamespaceStack {
         }
       }
     }
-    
+
     void declarePrefix(String prefix, String uri) {
       if (_bindings == null) {
         _bindings = new HashMap<String,String>();
       }
       _bindings.put(prefix,uri);
     }
-    
+
     String getPrefix(String uri) {
       return "";
     }
 
-    
+
     String getNamespaceURI(String prefix) {
       String uri = null;
       if (_bindings != null) {
@@ -283,6 +283,6 @@ public class NamespaceStack {
       }
       return uri;
     }
-    
+
   }
 }

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/Namespaces.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/Namespaces.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/Namespaces.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/Namespaces.java Thu May 27 18:09:53 2010
@@ -26,10 +26,10 @@ import javax.xml.namespace.QName;
  */
 public class Namespaces {
 
-    /** XML namespaces */	
+    /** XML namespaces */
     public static final String XML_URI = "http://www.w3.org/XML/1998/namespace".intern();
     public static final String XMLNS_URI = "http://www.w3.org/2000/xmlns/".intern();
-    
+
     /** BPEL 2.0 Final namespaces */
     public static final String WSBPEL2_0_FINAL_ABSTRACT = "http://docs.oasis-open.org/wsbpel/2.0/process/abstract".intern();
     public static final String WSBPEL2_0_FINAL_EXEC = "http://docs.oasis-open.org/wsbpel/2.0/process/executable".intern();
@@ -61,7 +61,7 @@ public class Namespaces {
 
     /* ODE stuff */
     /**
-     * @deprecated use #ODE_PMAPI_TYPES_NS 
+     * @deprecated use #ODE_PMAPI_TYPES_NS
      */
     public static final String ODE_PMAPI = "http://www.apache.org/ode/pmapi/types/2006/08/02/".intern();
     public static final String ODE_PMAPI_TYPES_NS = "http://www.apache.org/ode/pmapi/types/2006/08/02/".intern();

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/ObjectPrinter.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/ObjectPrinter.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/ObjectPrinter.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/ObjectPrinter.java Thu May 27 18:09:53 2010
@@ -21,7 +21,7 @@ package org.apache.ode.utils;
 
 /**
  * Helper class for printing/formatting arbitrary objects.
- * 
+ *
  * <p>
  * Created on Feb 17, 2004 at 3:53:54 PM.
  * </p>

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/ProcessMutex.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/ProcessMutex.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/ProcessMutex.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/ProcessMutex.java Thu May 27 18:09:53 2010
@@ -28,7 +28,7 @@ import java.net.ServerSocket;
  * TCP port to synchronize multiple processes. The method of operation is
  * simple: by opening a port, a process prevents other processes on the local
  * machine from opening the same port.
- * 
+ *
  * @author Maciej Szefler  ( m s z e f l e r @ g m a i l . c o m)
  */
 public class ProcessMutex {

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/Properties.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/Properties.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/Properties.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/Properties.java Thu May 27 18:09:53 2010
@@ -196,7 +196,7 @@ public class Properties {
             if (properties.containsKey(PROP_JMS_REPLY_TIMEOUT)) {
                 String value = properties.get(PROP_JMS_REPLY_TIMEOUT);
                 options.setProperty(JMSConstants.JMS_WAIT_REPLY, value);
-                // The value of this property must be a string object, not a long object. 
+                // The value of this property must be a string object, not a long object.
 //                try {
 //                    options.setProperty(JMSConstants.JMS_WAIT_REPLY, Long.valueOf(value));
 //                } catch (NumberFormatException e) {
@@ -218,7 +218,7 @@ public class Properties {
                 options.setProperty(AddressingConstants.DISABLE_ADDRESSING_FOR_OUT_MESSAGES, !Boolean.parseBoolean(value));
             }
             if (properties.containsKey("ws-adddressing.headers")) {
-                if(log.isWarnEnabled())log.warn("Deprecated property: ws-adddressing.headers (Mind the 3 d's). Use ws-addressing.headers");                
+                if(log.isWarnEnabled())log.warn("Deprecated property: ws-adddressing.headers (Mind the 3 d's). Use ws-addressing.headers");
                 String value = properties.get("ws-adddressing.headers");
                 options.setProperty(AddressingConstants.DISABLE_ADDRESSING_FOR_OUT_MESSAGES, !Boolean.parseBoolean(value));
             }
@@ -298,7 +298,7 @@ public class Properties {
                 } catch (ProtocolException e) {
                     if (log.isWarnEnabled())
 
-                    
+
                         log.warn("Mal-formatted Property: [" + PROP_HTTP_PROTOCOL_VERSION + "]", e);
                 }
             }

Modified: ode/trunk/utils/src/main/java/org/apache/ode/utils/Reflect.java
URL: http://svn.apache.org/viewvc/ode/trunk/utils/src/main/java/org/apache/ode/utils/Reflect.java?rev=948937&r1=948936&r2=948937&view=diff
==============================================================================
--- ode/trunk/utils/src/main/java/org/apache/ode/utils/Reflect.java (original)
+++ ode/trunk/utils/src/main/java/org/apache/ode/utils/Reflect.java Thu May 27 18:09:53 2010
@@ -21,7 +21,7 @@ package org.apache.ode.utils;
 import java.lang.reflect.Method;
 
 public class Reflect {
-  
+
   /**
    * Generates a unique method signature string for a java.lang.reflect.Method.
    * Necessary b/c Method is not Serializable.