You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ode.apache.org by ha...@apache.org on 2013/01/22 23:26:31 UTC

svn commit: r1437220 - in /ode/trunk: bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ jacob/src/main/java/org/apache/ode/jacob/ jacob/src/main/java/org/apache/ode/jacob/vpu/ jacob/src/test/java/org/apache/ode/jacob/examples/cell/ jacob/src/test...

Author: hadrian
Date: Tue Jan 22 22:26:31 2013
New Revision: 1437220

URL: http://svn.apache.org/viewvc?rev=1437220&view=rev
Log:
ODE-987. Remove unnecessary generics from ReceiveProcess

Modified:
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ACTIVITYGUARD.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATE.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATIONHANDLER_.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_ALARM.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_EVENT.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FLOW.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FOREACH.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/INVOKE.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ORDEREDCOMPENSATOR.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PICK.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PROCESS.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/READWRITELOCK.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/REPEATUNTIL.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPE.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPEACT.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SEQUENCE.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WAIT.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WHILE.java
    ode/trunk/jacob/src/main/java/org/apache/ode/jacob/JacobRunnable.java
    ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ProcessUtil.java
    ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ReceiveProcess.java
    ode/trunk/jacob/src/main/java/org/apache/ode/jacob/vpu/JacobVPU.java
    ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/cell/CELL_.java
    ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/eratosthenes/Sieve.java
    ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/helloworld/HelloWorld.java
    ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/sequence/Sequence.java
    ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/synch/SynchPrinter.java

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ACTIVITYGUARD.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ACTIVITYGUARD.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ACTIVITYGUARD.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ACTIVITYGUARD.java Tue Jan 22 22:26:31 2013
@@ -105,7 +105,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                 dpe(_oactivity);
             }
         } else /* don't know all our links statuses */ {
-            CompositeProcess mlset = compose(new ReceiveProcess<Termination>() {
+            CompositeProcess mlset = compose(new ReceiveProcess() {
                 private static final long serialVersionUID = 5094153128476008961L;
             }.setChannel(_self.self).setReceiver(new Termination() {
                 public void terminate() {
@@ -116,7 +116,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                 }
             }));
             for (final OLink link : _oactivity.targetLinks) {
-                mlset.or(new ReceiveProcess<LinkStatus>() {
+                mlset.or(new ReceiveProcess() {
                     private static final long serialVersionUID = 1024137371118887935L;
                 }.setChannel(_linkFrame.resolve(link).sub).setReceiver(new LinkStatus() {
                     public void linkStatus(boolean value) {
@@ -198,7 +198,7 @@ class ACTIVITYGUARD extends ACTIVITY {
         }
 
         public void run() {
-            object(new ReceiveProcess<ParentScope>() {
+            object(new ReceiveProcess() {
                 private static final long serialVersionUID = 2667359535900385952L;
             }.setChannel(_in).setReceiver(new ParentScope() {
                 public void compensate(OScope scope, Synch ret) {
@@ -274,7 +274,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                         (failureHandling == null ? 0L : failureHandling.retryDelay * 1000));
                     final TimerResponse timerChannel = newChannel(TimerResponse.class);
                     getBpelRuntimeContext().registerTimer(timerChannel, future);
-                    object(false, new ReceiveProcess<TimerResponse>() {
+                    object(false, new ReceiveProcess() {
                         private static final long serialVersionUID = -261911108068231376L;
                     }.setChannel(timerChannel).setReceiver(new TimerResponse() {
                         public void onTimeout() {
@@ -295,7 +295,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                     getBpelRuntimeContext().registerActivityForRecovery(
                         recoveryChannel, _self.aId, _failure.reason, _failure.dateTime, _failure.data,
                         new String[] { "retry", "cancel", "fault" }, _failure.retryCount);
-                    object(false, compose(new ReceiveProcess<ActivityRecovery>() {
+                    object(false, compose(new ReceiveProcess() {
                         private static final long serialVersionUID = 8397883882810521685L;
                     }.setChannel(recoveryChannel).setReceiver(new ActivityRecovery() {
                         public void retry() {
@@ -322,7 +322,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                                 faultData = createFault(OFailureHandling.FAILURE_FAULT_NAME, _self.o, _failure.reason);
                             completed(faultData, CompensationHandler.emptySet());
                         }
-                    })).or(new ReceiveProcess<Termination>() {
+                    })).or(new ReceiveProcess() {
                         private static final long serialVersionUID = 2148587381204858397L;
                     }.setChannel(_self.self).setReceiver(new Termination() {
                         public void terminate() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATE.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATE.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATE.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATE.java Tue Jan 22 22:26:31 2013
@@ -40,7 +40,7 @@ class COMPENSATE extends ACTIVITY {
         OScope scopeToCompensate = _ocompact.compensatedScope;
         Synch sc = newChannel(Synch.class);
         _self.parent.compensate(scopeToCompensate,sc);
-        object(new ReceiveProcess<Synch>() {
+        object(new ReceiveProcess() {
             private static final long serialVersionUID = 3763991229748926216L;
         }.setChannel(sc).setReceiver(new Synch() {
             public void ret() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATIONHANDLER_.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATIONHANDLER_.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATIONHANDLER_.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/COMPENSATIONHANDLER_.java Tue Jan 22 22:26:31 2013
@@ -47,7 +47,7 @@ class COMPENSATIONHANDLER_ extends BpelJ
 
     public void run() {
         sendEvent(new CompensationHandlerRegistered());
-        object(new ReceiveProcess<Compensation>() {
+        object(new ReceiveProcess() {
             private static final long serialVersionUID = -477602498730810094L;
         }.setChannel(_self.compChannel).setReceiver(new Compensation() {
             public void forget() {
@@ -74,7 +74,7 @@ class COMPENSATIONHANDLER_ extends BpelJ
                 // Create the compensation handler scope.
                 instance(new SCOPE(ai,compHandlerScopeFrame, new LinkFrame(null)));
 
-                object(new ReceiveProcess<ParentScope>() {
+                object(new ReceiveProcess() {
                     private static final long serialVersionUID = 8044120498580711546L;
                 }.setChannel(ai.parent).setReceiver(new ParentScope() {
                     public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_ALARM.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_ALARM.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_ALARM.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_ALARM.java Tue Jan 22 22:26:31 2013
@@ -130,13 +130,13 @@ class EH_ALARM extends BpelJacobRunnable
         public void run() {
             Calendar now = Calendar.getInstance();
 
-            CompositeProcess listeners = compose(new ReceiveProcess<EventHandlerControl>() {
+            CompositeProcess listeners = compose(new ReceiveProcess() {
                 private static final long serialVersionUID = -7750428941445331236L;
             }.setChannel(_cc).setReceiver(new EventHandlerControl() {
                 public void stop() {
                     _psc.completed(null, _comps);
                 }
-            })).or(new ReceiveProcess<Termination>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = 6100105997983514609L;
             }.setChannel(_tc).setReceiver(new Termination() {
                 public void terminate() {
@@ -150,7 +150,7 @@ class EH_ALARM extends BpelJacobRunnable
                 TimerResponse trc = newChannel(TimerResponse.class);
                 getBpelRuntimeContext().registerTimer(trc,_alarm.getTime());
 
-                listeners.or(new ReceiveProcess<TimerResponse>() {
+                listeners.or(new ReceiveProcess() {
                     private static final long serialVersionUID = 1110683632756756017L;
                 }.setChannel(trc).setReceiver(new TimerResponse(){
                     public void onTimeout() {
@@ -206,7 +206,7 @@ class EH_ALARM extends BpelJacobRunnable
         }
 
         public void run() {
-            object(false, compose(new ReceiveProcess<ParentScope>() {
+            object(false, compose(new ReceiveProcess() {
                 private static final long serialVersionUID = -3357030137175178040L;
             }.setChannel(_activity.parent).setReceiver(new ParentScope() {
                 public void compensate(OScope scope, Synch ret) {
@@ -240,14 +240,14 @@ class EH_ALARM extends BpelJacobRunnable
 
                 public void cancelled() { completed(null, CompensationHandler.emptySet()); }
                 public void failure(String reason, Element data) { completed(null, CompensationHandler.emptySet()); }
-            })).or(new ReceiveProcess<EventHandlerControl>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = -3873619538789039424L;
             }.setChannel(_cc).setReceiver(new EventHandlerControl() {
                 public void stop() {
                     _stopped = true;
                     instance(ACTIVE.this);
                 }
-            })).or(new ReceiveProcess<Termination>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = -4566956567870652885L;
             }.setChannel(_tc).setReceiver(new Termination() {
                 public void terminate() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_EVENT.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_EVENT.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_EVENT.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/EH_EVENT.java Tue Jan 22 22:26:31 2013
@@ -162,7 +162,7 @@ class EH_EVENT extends BpelJacobRunnable
                 CompositeProcess mlset = ProcessUtil.compose(null);
 
                 if (!_terminated) {
-                    mlset.or(new ReceiveProcess<Termination>() {
+                    mlset.or(new ReceiveProcess() {
                         private static final long serialVersionUID = 7666910462948788042L;
                     }.setChannel(_tc).setReceiver(new Termination() {
                         public void terminate() {
@@ -176,7 +176,7 @@ class EH_EVENT extends BpelJacobRunnable
                 }
 
                 if (!_stopped) {
-                    mlset.or(new ReceiveProcess<EventHandlerControl>() {
+                    mlset.or(new ReceiveProcess() {
                         private static final long serialVersionUID = -1050788954724647970L;
                     }.setChannel(_ehc).setReceiver(new EventHandlerControl() {
                         public void stop() {
@@ -189,7 +189,7 @@ class EH_EVENT extends BpelJacobRunnable
                 }
 
                 for (final ActivityInfo ai : _active) {
-                    mlset.or(new ReceiveProcess<ParentScope>() {
+                    mlset.or(new ReceiveProcess() {
                         private static final long serialVersionUID = 5341207762415360982L;
                     }.setChannel(ai.parent).setReceiver(new ParentScope() {
                         public void compensate(OScope scope, Synch ret) {
@@ -217,7 +217,7 @@ class EH_EVENT extends BpelJacobRunnable
                 }
 
                 if (_pickResponseChannel != null)
-                    mlset.or(new ReceiveProcess<PickResponse>() {
+                    mlset.or(new ReceiveProcess() {
                         private static final long serialVersionUID = -4929999153478677288L;
                     }.setChannel(_pickResponseChannel).setReceiver(new PickResponse() {
                          public void onRequestRcvd(int selectorIdx, String mexId) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FLOW.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FLOW.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FLOW.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FLOW.java Tue Jan 22 22:26:31 2013
@@ -79,7 +79,7 @@ class FLOW extends ACTIVITY {
         public void run() {
             Iterator<ChildInfo> active = active();
             if (active.hasNext()) {
-                CompositeProcess mlSet = ProcessUtil.compose(new ReceiveProcess<Termination>() {
+                CompositeProcess mlSet = ProcessUtil.compose(new ReceiveProcess() {
                     private static final long serialVersionUID = 2554750258974084466L;
                 }.setChannel(_self.self).setReceiver(new Termination() {
                     public void terminate() {
@@ -91,7 +91,7 @@ class FLOW extends ACTIVITY {
 
                 for (;active.hasNext();) {
                     final ChildInfo child = active.next();
-                    mlSet.or(new ReceiveProcess<ParentScope>() {
+                    mlSet.or(new ReceiveProcess() {
                         private static final long serialVersionUID = -8027205709169238172L;
                     }.setChannel(child.activity.parent).setReceiver(new ParentScope() {
                         public void completed(FaultData faultData, Set<CompensationHandler> compensations) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FOREACH.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FOREACH.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FOREACH.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/FOREACH.java Tue Jan 22 22:26:31 2013
@@ -111,7 +111,7 @@ public class FOREACH extends ACTIVITY {
             Iterator<ChildInfo> active = active();
             // Continuing as long as a child is active
             if (active().hasNext()) {
-                CompositeProcess mlSet = ProcessUtil.compose(new ReceiveProcess<Termination>() {
+                CompositeProcess mlSet = ProcessUtil.compose(new ReceiveProcess() {
                     private static final long serialVersionUID = 2554750257484084466L;
                 }.setChannel(_self.self).setReceiver(new Termination() {
                     public void terminate() {
@@ -125,7 +125,7 @@ public class FOREACH extends ACTIVITY {
                 for (;active.hasNext();) {
                     // Checking out our children
                     final ChildInfo child = active.next();
-                    mlSet.or(new ReceiveProcess<ParentScope>() {
+                    mlSet.or(new ReceiveProcess() {
                         private static final long serialVersionUID = -8027205709961438172L;
                     }.setChannel(child.activity.parent).setReceiver(new ParentScope() {
                         public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/INVOKE.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/INVOKE.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/INVOKE.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/INVOKE.java Tue Jan 22 22:26:31 2013
@@ -99,7 +99,7 @@ public class INVOKE extends ACTIVITY {
                         _scopeFrame.resolve(_oinvoke.partnerLink), _oinvoke.operation,
                         outboundMsg, invokeResponseChannel);
 
-                object(false, compose(new ReceiveProcess<InvokeResponse>() {
+                object(false, compose(new ReceiveProcess() {
                     private static final long serialVersionUID = 4496880438819196765L;
                 }.setChannel(invokeResponseChannel).setReceiver(new InvokeResponse() {
                     public void onResponse() {
@@ -193,7 +193,7 @@ public class INVOKE extends ACTIVITY {
                         getBpelRuntimeContext().releasePartnerMex(mexId, false);
                     }
 
-                })).or(new ReceiveProcess<Termination>() {
+                })).or(new ReceiveProcess() {
                     private static final long serialVersionUID = 4219496341785922396L;
                 }.setChannel(_self.self).setReceiver(new Termination() {
                     public void terminate() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ORDEREDCOMPENSATOR.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ORDEREDCOMPENSATOR.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ORDEREDCOMPENSATOR.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ORDEREDCOMPENSATOR.java Tue Jan 22 22:26:31 2013
@@ -49,7 +49,7 @@ class ORDEREDCOMPENSATOR extends BpelJac
             Synch r = newChannel(Synch.class);
             CompensationHandler cdata = _compensations.remove(0);
             cdata.compChannel.compensate(r);
-            object(new ReceiveProcess<Synch>() {
+            object(new ReceiveProcess() {
                 private static final long serialVersionUID = 7173916663479205420L;
             }.setChannel(r).setReceiver(new Synch() {
                 public void ret() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PICK.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PICK.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PICK.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PICK.java Tue Jan 22 22:26:31 2013
@@ -282,7 +282,7 @@ class PICK extends ACTIVITY {
         }
 
         public void run() {
-            object(false, compose(new ReceiveProcess<PickResponse>() {
+            object(false, compose(new ReceiveProcess() {
                 private static final long serialVersionUID = -8237296827418738011L;
             }.setChannel(_pickResponseChannel).setReceiver(new PickResponse() {
                 public void onRequestRcvd(int selectorIdx, String mexId) {
@@ -376,7 +376,7 @@ class PICK extends ACTIVITY {
                     _self.parent.completed(null, CompensationHandler.emptySet());
                 }
 
-            })).or(new ReceiveProcess<Termination>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = 4399496341785922396L;
             }.setChannel(_self.self).setReceiver(new Termination() {
                 public void terminate() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PROCESS.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PROCESS.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PROCESS.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/PROCESS.java Tue Jan 22 22:26:31 2013
@@ -59,7 +59,7 @@ public class PROCESS extends BpelJacobRu
         ScopeFrame processFrame = new ScopeFrame(_oprocess.procesScope, scopeInstanceId, null, null,_globals);
         instance(new SCOPE(child, processFrame, new LinkFrame(null)));
 
-        object(new ReceiveProcess<ParentScope>() {
+        object(new ReceiveProcess() {
             private static final long serialVersionUID = -8564969578471906493L;
         }.setChannel(child.parent).setReceiver(new ParentScope() {
             public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/READWRITELOCK.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/READWRITELOCK.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/READWRITELOCK.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/READWRITELOCK.java Tue Jan 22 22:26:31 2013
@@ -55,7 +55,7 @@ public class READWRITELOCK extends Jacob
 
     @Override
     public void run() {
-        object(new ReceiveProcess<ReadWriteLock>() {
+        object(new ReceiveProcess() {
             private static final long serialVersionUID = -8644268413754259515L;
         }.setChannel(_self).setReceiver(new ReadWriteLock() {
             public void readLock(Synch s) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/REPEATUNTIL.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/REPEATUNTIL.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/REPEATUNTIL.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/REPEATUNTIL.java Tue Jan 22 22:26:31 2013
@@ -97,7 +97,7 @@ public class REPEATUNTIL extends ACTIVIT
         }
 
         public void run() {
-            object(false, compose(new ReceiveProcess<Termination>() {
+            object(false, compose(new ReceiveProcess() {
                 private static final long serialVersionUID = -5471984635653784051L;
             }.setChannel(_self.self).setReceiver(new Termination() {
                 public void terminate() {
@@ -105,7 +105,7 @@ public class REPEATUNTIL extends ACTIVIT
                     replication(_child.self).terminate();
                     instance(WAITER.this);
                 }
-            })).or(new ReceiveProcess<ParentScope>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = 3907167240907524405L;
             }.setChannel(_child.parent).setReceiver(new ParentScope() {
                 public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPE.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPE.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPE.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPE.java Tue Jan 22 22:26:31 2013
@@ -140,7 +140,7 @@ class SCOPE extends ACTIVITY {
 
         public void run() {
             if (_child != null || !_eventHandlers.isEmpty()) {
-                CompositeProcess mlSet = ProcessUtil.compose(new ReceiveProcess<Termination>() {
+                CompositeProcess mlSet = ProcessUtil.compose(new ReceiveProcess() {
                     private static final long serialVersionUID = 1913414844895865116L;
                 }.setChannel(_self.self).setReceiver(new Termination() {
                     public void terminate() {
@@ -161,7 +161,7 @@ class SCOPE extends ACTIVITY {
 
                 // Handle messages from the child if it is still alive
                 if (_child != null) {
-                    mlSet.or(new ReceiveProcess<ParentScope>() {
+                    mlSet.or(new ReceiveProcess() {
                         private static final long serialVersionUID = -6934246487304813033L;
                     }.setChannel(_child.parent).setReceiver(new ParentScope() {
                         public void compensate(OScope scope, Synch ret) {
@@ -216,7 +216,7 @@ class SCOPE extends ACTIVITY {
                 for (Iterator<EventHandlerInfo> i = _eventHandlers.iterator();i.hasNext();) {
                     final EventHandlerInfo ehi = i.next();
 
-                    mlSet.or(new ReceiveProcess<ParentScope>() {
+                    mlSet.or(new ReceiveProcess() {
                         private static final long serialVersionUID = -4694721357537858221L;
                     }.setChannel(ehi.psc).setReceiver(new ParentScope() {
                         public void compensate(OScope scope, Synch ret) {
@@ -291,7 +291,7 @@ class SCOPE extends ACTIVITY {
                         // Create the temination handler scope.
                         instance(new SCOPE(terminationHandlerActivity,terminationHandlerScopeFrame, SCOPE.this._linkFrame));
 
-                        object(new ReceiveProcess<ParentScope>() {
+                        object(new ReceiveProcess() {
                             private static final long serialVersionUID = -6009078124717125270L;
                         }.setChannel(terminationHandlerActivity.parent).setReceiver(new ParentScope() {
                             public void compensate(OScope scope, Synch ret) {
@@ -370,7 +370,7 @@ class SCOPE extends ACTIVITY {
                         // Create the fault handler scope.
                         instance(new SCOPE(faultHandlerActivity,faultHandlerScopeFrame, SCOPE.this._linkFrame));
 
-                        object(new ReceiveProcess<ParentScope>() {
+                        object(new ReceiveProcess() {
                             private static final long serialVersionUID = -6009078124717125270L;
                         }.setChannel(faultHandlerActivity.parent).setReceiver(new ParentScope() {
                             public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPEACT.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPEACT.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPEACT.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SCOPEACT.java Tue Jan 22 22:26:31 2013
@@ -150,7 +150,7 @@ public class SCOPEACT extends ACTIVITY {
 
             CompositeProcess mlset = ProcessUtil.compose(null);
             if (_status == null)
-                mlset.or(new ReceiveProcess<Val>() {
+                mlset.or(new ReceiveProcess() {
                     private static final long serialVersionUID = 5029554538593371750L;
                 }.setChannel(_self).setReceiver(new Val() {
                     /** Our owner will notify us when it becomes clear what to do with the links. */
@@ -174,7 +174,7 @@ public class SCOPEACT extends ACTIVITY {
                 if (_statuses.containsKey(m.getKey()))
                     continue;
             
-                mlset.or(new ReceiveProcess<LinkStatus>() {
+                mlset.or(new ReceiveProcess() {
                     private static final long serialVersionUID = 1568144473514091593L;
                 }.setChannel(m.getValue().pub).setReceiver(new LinkStatus() {
                     public void linkStatus(boolean value) {
@@ -256,7 +256,7 @@ public class SCOPEACT extends ACTIVITY {
                 else
                     il.lockChannel.readLock(_synchChannel);
 
-                object(new ReceiveProcess<Synch>() {
+                object(new ReceiveProcess() {
                     private static final long serialVersionUID = 2857261074409098274L;
                 }.setChannel(_synchChannel).setReceiver(new Synch() {
                     public void ret() {
@@ -303,7 +303,7 @@ public class SCOPEACT extends ACTIVITY {
         public void run() {
 
             __log.debug("running UNLOCKER");
-            object(new ReceiveProcess<ParentScope>() {
+            object(new ReceiveProcess() {
                 private static final long serialVersionUID = 1L;
             }.setChannel(_self).setReceiver(new ParentScope() {
                 public void cancelled() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SEQUENCE.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SEQUENCE.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SEQUENCE.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/SEQUENCE.java Tue Jan 22 22:26:31 2013
@@ -78,7 +78,7 @@ class SEQUENCE extends ACTIVITY {
         }
 
         public void run() {
-            object(false, compose(new ReceiveProcess<Termination>() {
+            object(false, compose(new ReceiveProcess() {
                 private static final long serialVersionUID = -2680515407515637639L;
             }.setChannel(_self.self).setReceiver(new Termination() {
                 public void terminate() {
@@ -92,7 +92,7 @@ class SEQUENCE extends ACTIVITY {
                     _terminateRequested = true;
                     instance(ACTIVE.this);
                 }
-            })).or(new ReceiveProcess<ParentScope>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = 7195562310281985971L;
             }.setChannel(_child.parent).setReceiver(new ParentScope() {
                 public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WAIT.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WAIT.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WAIT.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WAIT.java Tue Jan 22 22:26:31 2013
@@ -68,7 +68,7 @@ class WAIT extends ACTIVITY {
             final TimerResponse timerChannel = newChannel(TimerResponse.class);
             getBpelRuntimeContext().registerTimer(timerChannel, dueDate);
 
-            object(false, compose(new ReceiveProcess<TimerResponse>() {
+            object(false, compose(new ReceiveProcess() {
                 private static final long serialVersionUID = 3120518305645437327L;
             }.setChannel(timerChannel).setReceiver(new TimerResponse() {
                 public void onTimeout() {
@@ -78,12 +78,12 @@ class WAIT extends ACTIVITY {
                 public void onCancel() {
                     _self.parent.completed(null, CompensationHandler.emptySet());
                 }
-            })).or(new ReceiveProcess<Termination>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = -2791243270691333946L;
             }.setChannel(_self.self).setReceiver(new Termination() {
                 public void terminate() {
                     _self.parent.completed(null, CompensationHandler.emptySet());
-                    object(new ReceiveProcess<TimerResponse>() {
+                    object(new ReceiveProcess() {
                         private static final long serialVersionUID = 677746737897792929L;
                     }.setChannel(timerChannel).setReceiver(new TimerResponse() {
                         public void onTimeout() {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WHILE.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WHILE.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WHILE.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/WHILE.java Tue Jan 22 22:26:31 2013
@@ -115,7 +115,7 @@ class WHILE extends ACTIVITY {
         }
 
         public void run() {
-            object(false, compose(new ReceiveProcess<Termination>() {
+            object(false, compose(new ReceiveProcess() {
                 private static final long serialVersionUID = -5471984635653784051L;
             }.setChannel(_self.self).setReceiver(new Termination() {
                 public void terminate() {
@@ -123,7 +123,7 @@ class WHILE extends ACTIVITY {
                     replication(_child.self).terminate();
                     instance(WAITER.this);
                 }
-            })).or(new ReceiveProcess<ParentScope>() {
+            })).or(new ReceiveProcess() {
                 private static final long serialVersionUID = 3907167240907524405L;
             }.setChannel(_child.parent).setReceiver(new ParentScope() {
                 public void compensate(OScope scope, Synch ret) {

Modified: ode/trunk/jacob/src/main/java/org/apache/ode/jacob/JacobRunnable.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/main/java/org/apache/ode/jacob/JacobRunnable.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/main/java/org/apache/ode/jacob/JacobRunnable.java (original)
+++ ode/trunk/jacob/src/main/java/org/apache/ode/jacob/JacobRunnable.java Tue Jan 22 22:26:31 2013
@@ -44,7 +44,7 @@ import java.util.Set;
  *     }
  *
  *     public void run() {
- *      object(new ReceiveProcess<Cell> { read(...) {...}
+ *      object(new ReceiveProcess { read(...) {...}
  *                             write(...) {...} } );
  *    }
  * }

Modified: ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ProcessUtil.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ProcessUtil.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ProcessUtil.java (original)
+++ ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ProcessUtil.java Tue Jan 22 22:26:31 2013
@@ -37,7 +37,7 @@ public final class ProcessUtil {
     	    + channel == null ? "<null>" : channel.getClass().toString());
     }
     
-    public static CompositeProcess compose(ReceiveProcess<?> process) {
+    public static CompositeProcess compose(ReceiveProcess process) {
         CompositeProcess result = new CompositeProcess();
         return result.or(process);
     }
@@ -47,6 +47,6 @@ public final class ProcessUtil {
     	// TODO: NOTE: this *only* works when the listnere doesn't need to be Serialiazble really
     	//  because we cannot declare a staic serialVersionUID like this
     	//  once we fix serialization, this can be simplified significantly via a dsl
-    	return new ReceiveProcess<T>() {}.setChannel(proxy).setReceiver(listener);
+    	return new ReceiveProcess() {}.setChannel(proxy).setReceiver(listener);
     }
 }

Modified: ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ReceiveProcess.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ReceiveProcess.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ReceiveProcess.java (original)
+++ ode/trunk/jacob/src/main/java/org/apache/ode/jacob/ReceiveProcess.java Tue Jan 22 22:26:31 2013
@@ -25,7 +25,7 @@ import java.util.Set;
 
 
 @SuppressWarnings("serial")
-public abstract class ReceiveProcess<T extends Channel> extends ChannelListener {
+public abstract class ReceiveProcess extends ChannelListener {
     private transient Set<Method> _implementedMethods;
     private transient Channel channel;
     private Channel receiver;
@@ -33,19 +33,11 @@ public abstract class ReceiveProcess<T e
     public ReceiveProcess() {        
     }
 
-    protected ReceiveProcess(T channel, T receiver) {
-        if (channel == null) {
-            throw new IllegalArgumentException("Null channel!");
-        }
-        this.channel = channel;
-        this.receiver = receiver;
-    }
-
     public Channel getChannel() {
         return channel;
     }
 
-    public ReceiveProcess<T> setChannel(Channel channel) {
+    public ReceiveProcess setChannel(Channel channel) {
         this.channel = channel;
         return this;
     }
@@ -54,7 +46,7 @@ public abstract class ReceiveProcess<T e
         return receiver;
     }
 
-    public ReceiveProcess<T> setReceiver(Channel receiver) {
+    public ReceiveProcess setReceiver(Channel receiver) {
         this.receiver = receiver;
         return this;
     }

Modified: ode/trunk/jacob/src/main/java/org/apache/ode/jacob/vpu/JacobVPU.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/main/java/org/apache/ode/jacob/vpu/JacobVPU.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/main/java/org/apache/ode/jacob/vpu/JacobVPU.java (original)
+++ ode/trunk/jacob/src/main/java/org/apache/ode/jacob/vpu/JacobVPU.java Tue Jan 22 22:26:31 2013
@@ -331,7 +331,7 @@ public final class JacobVPU {
                 msg.append(_cycle);
                 msg.append(": ");
                 if (ml instanceof ReceiveProcess) {
-                    ReceiveProcess<?> rp = (ReceiveProcess<?>)ml;
+                    ReceiveProcess rp = (ReceiveProcess)ml;
                     msg.append(rp.getChannel());
                     msg.append(" ? ");
                     msg.append(rp.toString());
@@ -353,7 +353,7 @@ public final class JacobVPU {
                 }
             } else if (receiver instanceof ReceiveProcess) {
                 CommChannel chnl = (CommChannel)ChannelFactory.getBackend(
-                        ((ReceiveProcess<?>)receiver).getChannel());
+                        ((ReceiveProcess)receiver).getChannel());
                     // TODO see below..
                     // oframe.setDebugInfo(fillDebugInfo());
                     CommRecv recv = new CommRecv(chnl, receiver);
@@ -406,7 +406,7 @@ public final class JacobVPU {
             long ctime = System.currentTimeMillis();
             try {
                 _method.invoke(_methodBody instanceof ReceiveProcess ? 
-                    ((ReceiveProcess<?>)_methodBody).getReceiver() : _methodBody, args);
+                    ((ReceiveProcess)_methodBody).getReceiver() : _methodBody, args);
                 if (synchChannel != null) {
                     synchChannel.ret();
                 }

Modified: ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/cell/CELL_.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/cell/CELL_.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/cell/CELL_.java (original)
+++ ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/cell/CELL_.java Tue Jan 22 22:26:31 2013
@@ -44,7 +44,7 @@ public class CELL_<T> extends JacobRunna
     public void run() {
         // INSTANTIATION{Cell(run,val)}
         // ==> run ? [ read(r)={...} & write(newVal)={...} ]
-        object(new ReceiveProcess<Cell>() {
+        object(new ReceiveProcess() {
             private static final long serialVersionUID = 8883128084307471572L;
         }.setChannel(_self).setReceiver(new Cell() {
             public void read(Val r) {

Modified: ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/eratosthenes/Sieve.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/eratosthenes/Sieve.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/eratosthenes/Sieve.java (original)
+++ ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/eratosthenes/Sieve.java Tue Jan 22 22:26:31 2013
@@ -71,7 +71,7 @@ public class Sieve extends JacobRunnable
 
     public void run() {
         Synch ret = newChannel(Synch.class);
-        object(new ReceiveProcess<Synch>() {
+        object(new ReceiveProcess() {
             private static final long serialVersionUID = -4336285925619915276L;
         }.setChannel(ret).setReceiver(new Synch() {
             public void ret() {
@@ -104,12 +104,12 @@ public class Sieve extends JacobRunnable
     }
 
     public void run() {
-      object(new ReceiveProcess<NaturalNumberStream>() {
+      object(new ReceiveProcess() {
           private static final long serialVersionUID = -2145752474431263689L;
       }.setChannel(_in).setReceiver(new NaturalNumberStream() {
         public void val(final int n, final Synch ret) {
             Synch r = newChannel(Synch.class);
-            object(new ReceiveProcess<Synch>() {
+            object(new ReceiveProcess() {
                 private static final long serialVersionUID = -3009595654233593893L;
             }.setChannel(r).setReceiver(new Synch() {
                 public void ret() {
@@ -133,7 +133,7 @@ public class Sieve extends JacobRunnable
       _in = in;
     }
     public void run() {
-      object(true, new ReceiveProcess<NaturalNumberStream>() {
+      object(true, new ReceiveProcess() {
           private static final long serialVersionUID = 7671019806323866866L;
       }.setChannel(_in).setReceiver(new NaturalNumberStream(){
         public void val(int n, Synch ret) {
@@ -167,13 +167,13 @@ public class Sieve extends JacobRunnable
       _out = out;
     }
     public void run() {
-       object(true, new ReceiveProcess<NaturalNumberStream>() {
+       object(true, new ReceiveProcess() {
            private static final long serialVersionUID = 2523405590764193613L;
        }.setChannel(_in).setReceiver(new NaturalNumberStream() {
           public void val(int n, final Synch ret) {
               if (n % _prime != 0) {
                   Synch r = newChannel(Synch.class);
-                  object(new ReceiveProcess<Synch>() {
+                  object(new ReceiveProcess() {
                       private static final long serialVersionUID = 2523405590764193613L;
                   }.setChannel(r).setReceiver(new Synch() {
                       public void ret() {

Modified: ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/helloworld/HelloWorld.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/helloworld/HelloWorld.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/helloworld/HelloWorld.java (original)
+++ ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/helloworld/HelloWorld.java Tue Jan 22 22:26:31 2013
@@ -48,7 +48,7 @@ public class HelloWorld extends JacobRun
         }
 
         public void run() {
-            object(true, new ReceiveProcess<Callback<String, Synch>>() {
+            object(true, new ReceiveProcess() {
                 private static final long serialVersionUID = 1L;
             }.setChannel(_in).setReceiver(new Callback<String, Synch>(){
                 @Override
@@ -71,7 +71,7 @@ public class HelloWorld extends JacobRun
 
         public void run() {
             Synch callback = newChannel(Synch.class, "callback channel to ACK " + str);
-            object(new ReceiveProcess<Synch>() {
+            object(new ReceiveProcess() {
                 private static final long serialVersionUID = 1L;
             }.setChannel(callback).setReceiver(new Synch() {
                 @Override
@@ -90,7 +90,7 @@ public class HelloWorld extends JacobRun
         }
 
         public void run() {
-            object(true, new ReceiveProcess<Val>() {
+            object(true, new ReceiveProcess() {
                 private static final long serialVersionUID = 1L;
             }.setChannel(_in).setReceiver(new Val(){
                 public void val(Object o) {
@@ -123,7 +123,7 @@ public class HelloWorld extends JacobRun
         }
 
         public void run() {
-            object(true, new ReceiveProcess<Val>() {
+            object(true, new ReceiveProcess() {
                 private static final long serialVersionUID = 1L;
             }.setChannel(in).setReceiver(new Val(){
                 public void val(Object o) {

Modified: ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/sequence/Sequence.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/sequence/Sequence.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/sequence/Sequence.java (original)
+++ ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/sequence/Sequence.java Tue Jan 22 22:26:31 2013
@@ -53,7 +53,7 @@ public abstract class Sequence extends J
             }
         } else {
             Synch r = newChannel(Synch.class);
-            object(new ReceiveProcess<Synch>() {
+            object(new ReceiveProcess() {
                 private static final long serialVersionUID = -6999108928780639603L;
             }.setChannel(r).setReceiver(new Synch() {
                 public void ret() {

Modified: ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/synch/SynchPrinter.java
URL: http://svn.apache.org/viewvc/ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/synch/SynchPrinter.java?rev=1437220&r1=1437219&r2=1437220&view=diff
==============================================================================
--- ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/synch/SynchPrinter.java (original)
+++ ode/trunk/jacob/src/test/java/org/apache/ode/jacob/examples/synch/SynchPrinter.java Tue Jan 22 22:26:31 2013
@@ -44,7 +44,7 @@ public class SynchPrinter {
 
         @SuppressWarnings("serial")
         public void run() {
-            object(true, new ReceiveProcess<SynchPrint>() {
+            object(true, new ReceiveProcess() {
                 private static final long serialVersionUID = -1990741944766989782L;
             }.setChannel(_self).setReceiver(new SynchPrint() {
                 public Synch print(String msg) {