You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ode.apache.org by ms...@apache.org on 2007/08/07 20:23:11 UTC

svn commit: r563602 - in /ode/branches/bart/scheduler-simple/src: main/java/org/apache/ode/scheduler/simple/ test/java/org/apache/ode/scheduler/simple/ test/resources/HelloWorld2/

Author: mszefler
Date: Tue Aug  7 11:23:09 2007
New Revision: 563602

URL: http://svn.apache.org/viewvc?view=rev&rev=563602
Log:
Caught up to trunk.

Modified:
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseDelegate.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseException.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JdbcDelegate.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Job.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobComparatorByDate.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobNoLongerInDbException.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SchedulerThread.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SimpleScheduler.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Task.java
    ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/TaskRunner.java
    ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/DelegateSupport.java
    ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/JdbcDelegateTest.java
    ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java
    ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java
    ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel
    ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl
    ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml
    ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/test.properties

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseDelegate.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseDelegate.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseDelegate.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseDelegate.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.List;

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseException.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseException.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseException.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/DatabaseException.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 /**

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JdbcDelegate.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JdbcDelegate.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JdbcDelegate.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JdbcDelegate.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.io.ByteArrayOutputStream;

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Job.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Job.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Job.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Job.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.Map;

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobComparatorByDate.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobComparatorByDate.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobComparatorByDate.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobComparatorByDate.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.Comparator;

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobNoLongerInDbException.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobNoLongerInDbException.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobNoLongerInDbException.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/JobNoLongerInDbException.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 /**

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SchedulerThread.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SchedulerThread.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SchedulerThread.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SchedulerThread.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.concurrent.PriorityBlockingQueue;

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SimpleScheduler.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SimpleScheduler.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SimpleScheduler.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/SimpleScheduler.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.ArrayList;

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Task.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Task.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Task.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/Task.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 /**

Modified: ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/TaskRunner.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/TaskRunner.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/TaskRunner.java (original)
+++ ode/branches/bart/scheduler-simple/src/main/java/org/apache/ode/scheduler/simple/TaskRunner.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 /**

Modified: ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/DelegateSupport.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/DelegateSupport.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/DelegateSupport.java (original)
+++ ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/DelegateSupport.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.sql.Connection;

Modified: ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/JdbcDelegateTest.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/JdbcDelegateTest.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/JdbcDelegateTest.java (original)
+++ ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/JdbcDelegateTest.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.HashMap;

Modified: ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java (original)
+++ ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SchedulerThreadTest.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.ArrayList;

Modified: ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java (original)
+++ ode/branches/bart/scheduler-simple/src/test/java/org/apache/ode/scheduler/simple/SimpleSchedulerTest.java Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.ode.scheduler.simple;
 
 import java.util.ArrayList;
@@ -16,25 +35,19 @@
 import org.apache.ode.bpel.iapi.Scheduler.JobInfo;
 import org.apache.ode.bpel.iapi.Scheduler.JobProcessor;
 import org.apache.ode.bpel.iapi.Scheduler.JobProcessorException;
-import org.objectweb.jotm.Jotm;
+import org.apache.geronimo.transaction.manager.GeronimoTransactionManager;
 
 public class SimpleSchedulerTest extends TestCase implements JobProcessor {
 
     DelegateSupport _ds;
-
     SimpleScheduler _scheduler;
-
     ArrayList<JobInfo> _jobs;
     ArrayList<JobInfo> _commit;
-
     TransactionManager _txm;
 
-    
-    Jotm _jotm;
 
     public void setUp() throws Exception {
-        _jotm = new Jotm(true, false);
-        _txm = _jotm.getTransactionManager();
+        _txm = new GeronimoTransactionManager();
         _ds = new DelegateSupport();
 
         _scheduler = newScheduler("n1");
@@ -44,7 +57,6 @@
 
     public void tearDown() throws Exception {
         _scheduler.shutdown();
-
     }
 
     public void testConcurrentExec() throws Exception  {
@@ -118,7 +130,7 @@
             _txm.commit();
         }
 
-        Thread.sleep(7500);
+        Thread.sleep(8500);
         assertEquals(1, _jobs.size());
     }
 
@@ -135,7 +147,7 @@
             _txm.commit();
         }
 
-        Thread.sleep(7500);
+        Thread.sleep(8500);
         assertEquals(1, _jobs.size());
     }
 
@@ -189,7 +201,8 @@
         }
 
         _scheduler.stop();
-        
+        Thread.sleep(1000);
+
         assertEquals(0, _jobs.size());
     }
 

Modified: ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel (original)
+++ ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.bpel Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+<!--
+  ~ Licensed to the Apache Software Foundation (ASF) under one
+  ~ or more contributor license agreements.  See the NOTICE file
+  ~ distributed with this work for additional information
+  ~ regarding copyright ownership.  The ASF licenses this file
+  ~ to you under the Apache License, Version 2.0 (the
+  ~ "License"); you may not use this file except in compliance
+  ~ with the License.  You may obtain a copy of the License at
+  ~
+  ~    http://www.apache.org/licenses/LICENSE-2.0
+  ~
+  ~ Unless required by applicable law or agreed to in writing,
+  ~ software distributed under the License is distributed on an
+  ~ "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+  ~ KIND, either express or implied.  See the License for the
+  ~ specific language governing permissions and limitations
+  ~ under the License.
+  -->
+
 <process name="HelloWorld2"
     targetNamespace="http://ode/bpel/unit-test" 
     xmlns:bpws="http://schemas.xmlsoap.org/ws/2004/03/business-process/"

Modified: ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl (original)
+++ ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/HelloWorld2.wsdl Tue Aug  7 11:23:09 2007
@@ -1,4 +1,22 @@
 <?xml version="1.0" encoding="utf-8" ?>
+<!--
+  ~ Licensed to the Apache Software Foundation (ASF) under one
+  ~ or more contributor license agreements.  See the NOTICE file
+  ~ distributed with this work for additional information
+  ~ regarding copyright ownership.  The ASF licenses this file
+  ~ to you under the Apache License, Version 2.0 (the
+  ~ "License"); you may not use this file except in compliance
+  ~ with the License.  You may obtain a copy of the License at
+  ~
+  ~    http://www.apache.org/licenses/LICENSE-2.0
+  ~
+  ~ Unless required by applicable law or agreed to in writing,
+  ~ software distributed under the License is distributed on an
+  ~ "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+  ~ KIND, either express or implied.  See the License for the
+  ~ specific language governing permissions and limitations
+  ~ under the License.
+  -->
 
 <wsdl:definitions 
     targetNamespace="http://ode/bpel/unit-test.wsdl"

Modified: ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml (original)
+++ ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/deploy.xml Tue Aug  7 11:23:09 2007
@@ -1,3 +1,22 @@
+<!--
+  ~ 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.
+  -->
+
 <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/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/test.properties
URL: http://svn.apache.org/viewvc/ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/test.properties?view=diff&rev=563602&r1=563601&r2=563602
==============================================================================
--- ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/test.properties (original)
+++ ode/branches/bart/scheduler-simple/src/test/resources/HelloWorld2/test.properties Tue Aug  7 11:23:09 2007
@@ -1,3 +1,20 @@
+#
+#    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.
+#
+
 namespace=http://ode/bpel/unit-test.wsdl
 service=HelloService
 operation=hello