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/17 05:37:17 UTC

svn commit: r1434553 - in /ode/trunk/bpel-runtime/src: main/java/org/apache/ode/bpel/engine/ main/java/org/apache/ode/bpel/engine/replayer/ main/java/org/apache/ode/bpel/runtime/ main/java/org/apache/ode/bpel/runtime/channels/ test/java/org/apache/ode/...

Author: hadrian
Date: Thu Jan 17 04:37:16 2013
New Revision: 1434553

URL: http://svn.apache.org/viewvc?rev=1434553&view=rev
Log:
ODE-979. Remove use the last batch of *Channel classes

Modified:
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelRuntimeContextImpl.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/replayer/ReplayerBpelRuntimeContextImpl.java
    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/ActivityInfo.java
    ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/BpelRuntimeContext.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/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/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/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/channels/PickResponse.java
    ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/CoreBpelTest.java

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelRuntimeContextImpl.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelRuntimeContextImpl.java?rev=1434553&r1=1434552&r2=1434553&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelRuntimeContextImpl.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/BpelRuntimeContextImpl.java Thu Jan 17 04:37:16 2013
@@ -89,14 +89,10 @@ import org.apache.ode.bpel.runtime.Partn
 import org.apache.ode.bpel.runtime.Selector;
 import org.apache.ode.bpel.runtime.VariableInstance;
 import org.apache.ode.bpel.runtime.channels.ActivityRecovery;
-import org.apache.ode.bpel.runtime.channels.ActivityRecoveryChannel;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.InvokeResponse;
-import org.apache.ode.bpel.runtime.channels.InvokeResponseChannel;
 import org.apache.ode.bpel.runtime.channels.PickResponse;
-import org.apache.ode.bpel.runtime.channels.PickResponseChannel;
 import org.apache.ode.bpel.runtime.channels.TimerResponse;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
 import org.apache.ode.jacob.JacobRunnable;
 import org.apache.ode.jacob.ProcessUtil;
 import org.apache.ode.jacob.vpu.ExecutionQueueImpl;
@@ -320,7 +316,7 @@ public class BpelRuntimeContextImpl impl
         }
     }
 
-    public void select(PickResponseChannel pickResponseChannel, Date timeout, boolean createInstance,
+    public void select(PickResponse pickResponseChannel, Date timeout, boolean createInstance,
                        Selector[] selectors) throws FaultException {
         if (BpelProcess.__log.isTraceEnabled())
             BpelProcess.__log.trace(ObjectPrinter.stringifyMethodEnter("select", new Object[] { "pickResponseChannel",
@@ -653,7 +649,7 @@ public class BpelRuntimeContextImpl impl
         });
     }
 
-    public void registerTimer(TimerResponseChannel timerChannel, Date timeToFire) {
+    public void registerTimer(TimerResponse timerChannel, Date timeToFire) {
         JobDetails we = new JobDetails();
         we.setInstanceId(_dao.getInstanceId());
         we.setChannel(ProcessUtil.exportChannel(timerChannel));
@@ -695,7 +691,7 @@ public class BpelRuntimeContextImpl impl
      * in which case it is one of the bpel standard fault.
      */
     public String invoke(int aid, PartnerLinkInstance partnerLink, Operation operation, Element outgoingMessage,
-                         InvokeResponseChannel channel) throws FaultException {
+                         InvokeResponse channel) throws FaultException {
 
         PartnerLinkDAO plinkDAO = fetchPartnerLinkDAO(partnerLink);
         // The target (partner endpoint) -- if it has not been explicitly
@@ -992,14 +988,14 @@ public class BpelRuntimeContextImpl impl
             private static final long serialVersionUID = -7767141033611036745L;
 
             public void run() {
-                TimerResponseChannel responseChannel = importChannel(timerResponseChannel, TimerResponseChannel.class);
+                TimerResponse responseChannel = importChannel(timerResponseChannel, TimerResponse.class);
                 responseChannel.onTimeout();
             }
         });
         execute();
     }
 
-    public void cancel(final TimerResponseChannel timerResponseChannel) {
+    public void cancel(final TimerResponse timerResponseChannel) {
         // In case this is a pick response channel, we need to cancel routes and
         // receive/reply association.
         final String id = ProcessUtil.exportChannel(timerResponseChannel);
@@ -1354,7 +1350,7 @@ public class BpelRuntimeContextImpl impl
         return dao.getProperty(MessageExchange.PROPERTY_SEP_PARTNERROLE_SESSIONID);
     }
 
-    public void registerActivityForRecovery(ActivityRecoveryChannel channel, long activityId, String reason,
+    public void registerActivityForRecovery(ActivityRecovery channel, long activityId, String reason,
                                             Date dateTime, Element details, String[] actions, int retries) {
         if (reason == null)
             reason = "Unspecified";
@@ -1365,7 +1361,7 @@ public class BpelRuntimeContextImpl impl
         _dao.createActivityRecovery(ProcessUtil.exportChannel(channel), (int) activityId, reason, dateTime, details, actions, retries);
     }
 
-    public void unregisterActivityForRecovery(ActivityRecoveryChannel channel) {
+    public void unregisterActivityForRecovery(ActivityRecovery channel) {
         _dao.deleteActivityRecovery(ProcessUtil.exportChannel(channel));
     }
 

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/replayer/ReplayerBpelRuntimeContextImpl.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/replayer/ReplayerBpelRuntimeContextImpl.java?rev=1434553&r1=1434552&r2=1434553&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/replayer/ReplayerBpelRuntimeContextImpl.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/engine/replayer/ReplayerBpelRuntimeContextImpl.java Thu Jan 17 04:37:16 2013
@@ -45,12 +45,11 @@ import org.apache.ode.bpel.pmapi.Communi
 import org.apache.ode.bpel.runtime.PROCESS;
 import org.apache.ode.bpel.runtime.PartnerLinkInstance;
 import org.apache.ode.bpel.runtime.Selector;
-import org.apache.ode.bpel.runtime.channels.ActivityRecoveryChannel;
+import org.apache.ode.bpel.runtime.channels.ActivityRecovery;
 import org.apache.ode.bpel.runtime.channels.FaultData;
-import org.apache.ode.bpel.runtime.channels.InvokeResponseChannel;
-import org.apache.ode.bpel.runtime.channels.PickResponseChannel;
+import org.apache.ode.bpel.runtime.channels.InvokeResponse;
+import org.apache.ode.bpel.runtime.channels.PickResponse;
 import org.apache.ode.bpel.runtime.channels.TimerResponse;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
 import org.apache.ode.jacob.JacobRunnable;
 import org.apache.ode.jacob.ProcessUtil;
 import org.apache.ode.utils.DOMUtils;
@@ -81,7 +80,7 @@ public class ReplayerBpelRuntimeContextI
     }
 
     @Override
-    public void cancel(TimerResponseChannel timerResponseChannel) {
+    public void cancel(TimerResponse timerResponseChannel) {
         if (__log.isDebugEnabled()) {
             __log.debug("cancel " + ProcessUtil.exportChannel(timerResponseChannel));
         }
@@ -96,7 +95,7 @@ public class ReplayerBpelRuntimeContextI
     }
 
     @Override
-    public String invoke(int aid, PartnerLinkInstance partnerLink, Operation operation, Element outgoingMessage, InvokeResponseChannel channel) throws FaultException {
+    public String invoke(int aid, PartnerLinkInstance partnerLink, Operation operation, Element outgoingMessage, InvokeResponse channel) throws FaultException {
         __log.debug("invoke");
         AnswerResult answerResult = replayerContext.answers.fetchAnswer(partnerLink.partnerLink.partnerRolePortType.getQName(), operation.getName(), outgoingMessage, getCurrentEventDateTime());
 
@@ -195,7 +194,7 @@ public class ReplayerBpelRuntimeContextI
     }
 
     @Override
-    public void registerTimer(final TimerResponseChannel timerChannel, final Date timeToFire) {
+    public void registerTimer(final TimerResponse timerChannel, final Date timeToFire) {
         __log.debug("register timer " + timerChannel + " " + timeToFire);
         final String channel = ProcessUtil.exportChannel(timerChannel);
 
@@ -214,7 +213,7 @@ public class ReplayerBpelRuntimeContextI
 
 
     @Override
-    public void registerActivityForRecovery(ActivityRecoveryChannel channel, long activityId, String reason, Date dateTime, Element details, String[] actions, int retries) {
+    public void registerActivityForRecovery(ActivityRecovery channel, long activityId, String reason, Date dateTime, Element details, String[] actions, int retries) {
         super.registerActivityForRecovery(channel, activityId, reason, dateTime, details, actions, retries);
         replayerContext.checkRollbackOnFault();
     }
@@ -254,7 +253,7 @@ public class ReplayerBpelRuntimeContextI
     }
 
     @Override
-    public void select(PickResponseChannel pickResponseChannel, Date timeout, boolean createInstance, Selector[] selectors) throws FaultException {
+    public void select(PickResponse pickResponseChannel, Date timeout, boolean createInstance, Selector[] selectors) throws FaultException {
         super.select(pickResponseChannel, timeout, createInstance, selectors);
         if (__log.isDebugEnabled()) {
             __log.debug("select " + pickResponseChannel + " " + ObjectPrinter.toString(selectors, selectors));

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -42,14 +42,11 @@ import org.apache.ode.bpel.o.OInvoke;
 import org.apache.ode.bpel.o.OLink;
 import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.ActivityRecovery;
-import org.apache.ode.bpel.runtime.channels.ActivityRecoveryChannel;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.LinkStatus;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
 import org.apache.ode.bpel.runtime.channels.TimerResponse;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
@@ -88,7 +85,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                 ActivityExecStartEvent aese = new ActivityExecStartEvent();
                 sendEvent(aese);
                 // intercept completion channel in order to execute transition conditions.
-                ActivityInfo activity = new ActivityInfo(genMonotonic(),_self.o,_self.self, newChannel(ParentScopeChannel.class));
+                ActivityInfo activity = new ActivityInfo(genMonotonic(),_self.o,_self.self, newChannel(ParentScope.class));
                 instance(createActivity(activity));
                 instance(new TCONDINTERCEPT(activity.parent));
             } else {
@@ -180,7 +177,7 @@ class ACTIVITYGUARD extends ACTIVITY {
     }
 
     private void startGuardedActivity() {
-        ActivityInfo activity = new ActivityInfo(genMonotonic(),_self.o,_self.self, newChannel(ParentScopeChannel.class));
+        ActivityInfo activity = new ActivityInfo(genMonotonic(),_self.o,_self.self, newChannel(ParentScope.class));
         instance(createActivity(activity));
         instance(new TCONDINTERCEPT(activity.parent));
     }
@@ -188,14 +185,14 @@ class ACTIVITYGUARD extends ACTIVITY {
 
     /**
      * Intercepts the
-     * {@link ParentScopeChannel#completed(org.apache.ode.bpel.runtime.channels.FaultData, java.util.Set<org.apache.ode.bpel.runtime.CompensationHandler>)}
+     * {@link ParentScope#completed(org.apache.ode.bpel.runtime.channels.FaultData, java.util.Set<org.apache.ode.bpel.runtime.CompensationHandler>)}
      * call, to evaluate transition conditions before returning to the parent.
      */
     private class TCONDINTERCEPT extends BpelJacobRunnable {
         private static final long serialVersionUID = 4014873396828400441L;
-        ParentScopeChannel _in;
+        ParentScope _in;
 
-        public TCONDINTERCEPT(ParentScopeChannel in) {
+        public TCONDINTERCEPT(ParentScope in) {
             _in = in;
         }
 
@@ -272,7 +269,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                         __log.debug("ActivityRecovery: Retrying activity " + _self.aId);
                     Date future = new Date(new Date().getTime() +
                         (failureHandling == null ? 0L : failureHandling.retryDelay * 1000));
-                    final TimerResponseChannel timerChannel = newChannel(TimerResponseChannel.class);
+                    final TimerResponse timerChannel = newChannel(TimerResponse.class);
                     getBpelRuntimeContext().registerTimer(timerChannel, future);
                     object(false, new ReceiveProcess<TimerResponse>(timerChannel, new TimerResponse() {
                         public void onTimeout() {
@@ -291,7 +288,7 @@ class ACTIVITYGUARD extends ACTIVITY {
                     if (__log.isDebugEnabled())
                         __log.debug("ActivityRecovery: Activity " + _self.aId + " requires recovery");
                     sendEvent(new ActivityFailureEvent(_failure.reason));
-                    final ActivityRecoveryChannel recoveryChannel = newChannel(ActivityRecoveryChannel.class);
+                    final ActivityRecovery recoveryChannel = newChannel(ActivityRecovery.class);
                     getBpelRuntimeContext().registerActivityForRecovery(
                         recoveryChannel, _self.aId, _failure.reason, _failure.dateTime, _failure.data,
                         new String[] { "retry", "cancel", "fault" }, _failure.retryCount);

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ActivityInfo.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ActivityInfo.java?rev=1434553&r1=1434552&r2=1434553&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ActivityInfo.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/ActivityInfo.java Thu Jan 17 04:37:16 2013
@@ -21,8 +21,9 @@ package org.apache.ode.bpel.runtime;
 import java.io.Serializable;
 
 import org.apache.ode.bpel.o.OActivity;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
+import org.apache.ode.bpel.runtime.channels.ParentScope;
+import org.apache.ode.bpel.runtime.channels.Termination;
+
 
 class ActivityInfo implements Serializable {
 
@@ -32,10 +33,10 @@ class ActivityInfo implements Serializab
 
     /** Activity definition. */
     OActivity o;
-    TerminationChannel self;
-    ParentScopeChannel parent;
+    Termination self;
+    ParentScope parent;
 
-    ActivityInfo(long aid, OActivity o, TerminationChannel self, ParentScopeChannel parent) {
+    ActivityInfo(long aid, OActivity o, Termination self, ParentScope parent) {
         assert o != null;
         assert self != null;
         assert parent != null;

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/BpelRuntimeContext.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/BpelRuntimeContext.java?rev=1434553&r1=1434552&r2=1434553&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/BpelRuntimeContext.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/BpelRuntimeContext.java Thu Jan 17 04:37:16 2013
@@ -32,11 +32,11 @@ import org.apache.ode.bpel.o.OPartnerLin
 import org.apache.ode.bpel.o.OProcess;
 import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.o.OScope.Variable;
-import org.apache.ode.bpel.runtime.channels.ActivityRecoveryChannel;
+import org.apache.ode.bpel.runtime.channels.ActivityRecovery;
 import org.apache.ode.bpel.runtime.channels.FaultData;
-import org.apache.ode.bpel.runtime.channels.InvokeResponseChannel;
-import org.apache.ode.bpel.runtime.channels.PickResponseChannel;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
+import org.apache.ode.bpel.runtime.channels.InvokeResponse;
+import org.apache.ode.bpel.runtime.channels.PickResponse;
+import org.apache.ode.bpel.runtime.channels.TimerResponse;
 import org.apache.ode.bpel.evar.ExternalVariableModuleException;
 import org.apache.ode.bpel.iapi.ProcessConf.PartnerRoleConfig;
 import org.w3c.dom.Element;
@@ -185,14 +185,14 @@ public interface BpelRuntimeContext {
     /**
      * Non-deterministic selection on incoming message-exchanges.
      */
-    void select(PickResponseChannel response, Date timeout, boolean createInstnace,
+    void select(PickResponse response, Date timeout, boolean createInstnace,
                 Selector[] selectors) throws FaultException;
 
     /**
      * Cancel a timer, or pick.
      * @param timerResponseChannel
      */
-    void cancel(TimerResponseChannel timerResponseChannel);
+    void cancel(TimerResponse timerResponseChannel);
 
     void cancelOutstandingRequests(String channelId);
 
@@ -219,7 +219,7 @@ public interface BpelRuntimeContext {
      */
     String invoke(int activityId, PartnerLinkInstance partnerLinkInstance,
                   Operation operation, Element outboundMsg,
-                  InvokeResponseChannel invokeResponseChannel) throws FaultException;
+                  InvokeResponse invokeResponseChannel) throws FaultException;
 
 
     /**
@@ -227,7 +227,7 @@ public interface BpelRuntimeContext {
      * @param timerChannel channel for timer notification
      * @param timeToFire future time to fire timer notification
      */
-    void registerTimer(TimerResponseChannel timerChannel, Date timeToFire);
+    void registerTimer(TimerResponse timerChannel, Date timeToFire);
 
     /**
      * Terminates the process / sets state flag to terminate
@@ -262,10 +262,10 @@ public interface BpelRuntimeContext {
 
     Element getSourceEPR(String mexId);
 
-    void registerActivityForRecovery(ActivityRecoveryChannel channel, long activityId, String reason,
+    void registerActivityForRecovery(ActivityRecovery channel, long activityId, String reason,
                                      Date dateTime, Element details, String[] actions, int retries);
 
-    void unregisterActivityForRecovery(ActivityRecoveryChannel channel);
+    void unregisterActivityForRecovery(ActivityRecovery channel);
 
     void recoverActivity(String channel, long activityId, String action, FaultData fault);
 

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -27,8 +27,7 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.Compensation;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
+import org.apache.ode.bpel.runtime.channels.Termination;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
 import org.w3c.dom.Element;
@@ -61,7 +60,7 @@ class COMPENSATIONHANDLER_ extends BpelJ
 
                 ActivityInfo ai = new ActivityInfo(genMonotonic(),
                     _self.compensated.oscope.compensationHandler,
-                    newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+                    newChannel(Termination.class), newChannel(ParentScope.class));
 
 
                 ScopeFrame compHandlerScopeFrame = new ScopeFrame(

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -32,11 +32,8 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.EventHandlerControl;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.bpel.runtime.channels.TimerResponse;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
@@ -54,8 +51,8 @@ class EH_ALARM extends BpelJacobRunnable
 
     private static final long serialVersionUID = 1L;
 
-    private ParentScopeChannel _psc;
-    private TerminationChannel _tc;
+    private ParentScope _psc;
+    private Termination _tc;
     private OEventHandler.OAlarm _oalarm;
     private ScopeFrame _scopeFrame;
     private EventHandlerControl _cc;
@@ -69,7 +66,7 @@ class EH_ALARM extends BpelJacobRunnable
      * @param o our prototype / compiled representation
      * @param scopeFrame the {@link ScopeFrame} in which we are executing
      */
-    EH_ALARM(ParentScopeChannel psc, TerminationChannel tc, EventHandlerControl cc, OEventHandler.OAlarm o, ScopeFrame scopeFrame) {
+    EH_ALARM(ParentScope psc, Termination tc, EventHandlerControl cc, OEventHandler.OAlarm o, ScopeFrame scopeFrame) {
         _psc = psc;
         _tc = tc;
         _cc = cc;
@@ -148,7 +145,7 @@ class EH_ALARM extends BpelJacobRunnable
             if (_alarm == null) {
                 object(false, listeners);
             } else if (now.before(_alarm)) {
-                TimerResponseChannel trc = newChannel(TimerResponseChannel.class);
+                TimerResponse trc = newChannel(TimerResponse.class);
                 getBpelRuntimeContext().registerTimer(trc,_alarm.getTime());
 
                 listeners.add(new ReceiveProcess<TimerResponse>(trc, new TimerResponse(){
@@ -167,8 +164,8 @@ class EH_ALARM extends BpelJacobRunnable
             } else /* now is later then alarm time */ {
                 // If the alarm has passed we fire the nested activity
                 ActivityInfo child = new ActivityInfo(genMonotonic(),
-                        _oalarm.activity,
-                        newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+                    _oalarm.activity,
+                    newChannel(Termination.class), newChannel(ParentScope.class));
                 instance(createChild(child, _scopeFrame, new LinkFrame(null) ));
                 instance(new ACTIVE(child));
             }
@@ -184,8 +181,8 @@ class EH_ALARM extends BpelJacobRunnable
         public void run() {
             // Start the child activity.
             ActivityInfo child = new ActivityInfo(genMonotonic(),
-                    _oalarm.activity,
-                    newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+                _oalarm.activity,
+                newChannel(Termination.class), newChannel(ParentScope.class));
             instance(createChild(child, _scopeFrame, new LinkFrame(null) ));
             instance(new ACTIVE(child));
         }

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -32,11 +32,8 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.EventHandlerControl;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.PickResponse;
-import org.apache.ode.bpel.runtime.channels.PickResponseChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ProcessUtil;
 import org.apache.ode.jacob.ReceiveProcess;
@@ -54,8 +51,8 @@ class EH_EVENT extends BpelJacobRunnable
     private static final Log __log = LogFactory.getLog(EH_EVENT.class);
 
     private EventHandlerControl _ehc;
-    private TerminationChannel _tc;
-    private ParentScopeChannel _psc;
+    private Termination _tc;
+    private ParentScope _psc;
     private ScopeFrame _scopeFrame;
     private OEventHandler.OEvent _oevent;
 
@@ -76,7 +73,7 @@ class EH_EVENT extends BpelJacobRunnable
     private boolean _childrenTerminated;
 
 
-    EH_EVENT(ParentScopeChannel psc,TerminationChannel tc, EventHandlerControl ehc, OEventHandler.OEvent o, ScopeFrame scopeFrame) {
+    EH_EVENT(ParentScope psc,Termination tc, EventHandlerControl ehc, OEventHandler.OEvent o, ScopeFrame scopeFrame) {
         _scopeFrame = scopeFrame;
         _oevent = o;
         _tc = tc;
@@ -114,7 +111,7 @@ class EH_EVENT extends BpelJacobRunnable
         public void run() {
             Selector selector;
             try {
-                PickResponseChannel pickResponseChannel = newChannel(PickResponseChannel.class);
+                PickResponse pickResponseChannel = newChannel(PickResponse.class);
                 CorrelationKeySet keySet = new CorrelationKeySet();
                 PartnerLinkInstance pLinkInstance = _scopeFrame.resolve(_oevent.partnerLink);
                 for( OScope.CorrelationSet cset : _oevent.joinCorrelations ) {
@@ -153,9 +150,9 @@ class EH_EVENT extends BpelJacobRunnable
      */
     private class WAITING extends BpelJacobRunnable {
         private static final long serialVersionUID = 1L;
-        private PickResponseChannel _pickResponseChannel;
+        private PickResponse _pickResponseChannel;
 
-        private WAITING(PickResponseChannel pickResponseChannel) {
+        private WAITING(PickResponse pickResponseChannel) {
             _pickResponseChannel = pickResponseChannel;
         }
 
@@ -293,19 +290,18 @@ class EH_EVENT extends BpelJacobRunnable
                             // load 'onMessage' activity; we'll do this even if a stop/terminate has been
                             // requested becasue we cannot undo the receipt of the message at this point.
                             ActivityInfo child = new ActivityInfo(genMonotonic(),
-                                    _oevent.activity,
-                                    newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
-
+                                _oevent.activity,
+                                newChannel(Termination.class), newChannel(ParentScope.class));
 
                             _active.add(child);
 
                             LinkFrame lf = new LinkFrame(null);
 
                             ScopeFrame innerScopeFrame = new ScopeFrame((OScope) _oevent.activity,
-                                    getBpelRuntimeContext().createScopeInstance(_scopeFrame.scopeInstanceId, (OScope) _oevent.activity),
-                                    ehScopeFrame,
-                                    _comps,
-                                    _fault);
+                                getBpelRuntimeContext().createScopeInstance(_scopeFrame.scopeInstanceId, (OScope) _oevent.activity),
+                                ehScopeFrame,
+                                _comps,
+                                _fault);
                             instance(new SCOPE(child, innerScopeFrame, lf));
 
                             // If we previously terminated the other activiites, then we do the same

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -29,9 +29,7 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.LinkStatus;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
@@ -63,7 +61,7 @@ class FLOW extends ACTIVITY {
             OActivity ochild = i.next();
             ChildInfo childInfo = new ChildInfo(
                 new ActivityInfo(genMonotonic(), ochild,
-                                 newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class)));
+                                 newChannel(Termination.class), newChannel(ParentScope.class)));
             _children.add(childInfo);
 
             instance(createChild(childInfo.activity,_scopeFrame, myLinkFrame));

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -34,9 +34,7 @@ import org.apache.ode.bpel.o.OForEach;
 import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
@@ -198,7 +196,7 @@ public class FOREACH extends ACTIVITY {
 
     private void newChild() {
         ChildInfo child = new ChildInfo(new ActivityInfo(genMonotonic(), _oforEach.innerScope,
-                newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class)));
+                newChannel(Termination.class), newChannel(ParentScope.class)));
         _children.add(child);
 
         // Creating the current counter value node

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -32,7 +32,6 @@ import org.apache.ode.bpel.o.OInvoke;
 import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.InvokeResponse;
-import org.apache.ode.bpel.runtime.channels.InvokeResponseChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.utils.DOMUtils;
@@ -91,7 +90,7 @@ public class INVOKE extends ACTIVITY {
 
             } else /* two-way */{
                 final VariableInstance outputVar = _scopeFrame.resolve(_oinvoke.outputVar);
-                InvokeResponseChannel invokeResponseChannel = newChannel(InvokeResponseChannel.class);
+                InvokeResponse invokeResponseChannel = newChannel(InvokeResponse.class);
 
                 final String mexId = getBpelRuntimeContext().invoke(_oinvoke.getId(),
                         _scopeFrame.resolve(_oinvoke.partnerLink), _oinvoke.operation,

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -42,7 +42,6 @@ import org.apache.ode.bpel.o.OPickReceiv
 import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.PickResponse;
-import org.apache.ode.bpel.runtime.channels.PickResponseChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
 import org.apache.ode.jacob.ProcessUtil;
 import org.apache.ode.jacob.ReceiveProcess;
@@ -74,7 +73,7 @@ class PICK extends ACTIVITY {
      * @see org.apache.ode.jacob.JacobRunnable#run()
      */
     public void run() {
-        PickResponseChannel pickResponseChannel = newChannel(PickResponseChannel.class);
+        PickResponse pickResponseChannel = newChannel(PickResponse.class);
         Date timeout;
         Selector[] selectors;
 
@@ -273,9 +272,9 @@ class PICK extends ACTIVITY {
     private class WAITING extends BpelJacobRunnable {
         private static final long serialVersionUID = 1L;
 
-        private PickResponseChannel _pickResponseChannel;
+        private PickResponse _pickResponseChannel;
 
-        private WAITING(PickResponseChannel pickResponseChannel) {
+        private WAITING(PickResponse pickResponseChannel) {
             this._pickResponseChannel = pickResponseChannel;
         }
 

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -28,9 +28,8 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.o.OScope.Variable;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.ReadWriteLock;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
+import org.apache.ode.bpel.runtime.channels.Termination;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
 import org.w3c.dom.Element;
@@ -56,7 +55,7 @@ public class PROCESS extends BpelJacobRu
 
         ActivityInfo child = new ActivityInfo(genMonotonic(),
             _oprocess.procesScope,
-            newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+            newChannel(Termination.class), newChannel(ParentScope.class));
         ScopeFrame processFrame = new ScopeFrame(_oprocess.procesScope, scopeInstanceId, null, null,_globals);
         instance(new SCOPE(child, processFrame, new LinkFrame(null)));
 

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -29,9 +29,7 @@ import org.apache.ode.bpel.o.ORepeatUnti
 import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
 import org.w3c.dom.Element;
@@ -50,7 +48,7 @@ public class REPEATUNTIL extends ACTIVIT
     public void run() {
         ActivityInfo child = new ActivityInfo(genMonotonic(),
                 getORepeatUntil().activity,
-                newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+                newChannel(Termination.class), newChannel(ParentScope.class));
         instance(createChild(child, _scopeFrame, _linkFrame));
         instance(new WAITER(child));
     }

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -48,9 +48,7 @@ import org.apache.ode.bpel.runtime.chann
 import org.apache.ode.bpel.runtime.channels.EventHandlerControl;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
@@ -80,7 +78,7 @@ class SCOPE extends ACTIVITY {
         // Start the child activity.
         _child = new ActivityInfo(genMonotonic(),
             _oscope.activity,
-            newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+            newChannel(Termination.class), newChannel(ParentScope.class));
         instance(createChild(_child, _scopeFrame, _linkFrame));
 
         if (_oscope.eventHandler != null) {
@@ -88,8 +86,8 @@ class SCOPE extends ACTIVITY {
                 OEventHandler.OAlarm alarm = i.next();
                 EventHandlerInfo ehi = new EventHandlerInfo(alarm,
                         newChannel(EventHandlerControl.class),
-                        newChannel(ParentScopeChannel.class),
-                        newChannel(TerminationChannel.class));
+                        newChannel(ParentScope.class),
+                        newChannel(Termination.class));
                 _eventHandlers.add(ehi);
                 instance(new EH_ALARM(ehi.psc,ehi.tc, ehi.cc, alarm, _scopeFrame));
             }
@@ -98,8 +96,8 @@ class SCOPE extends ACTIVITY {
                 OEventHandler.OEvent event = i.next();
                 EventHandlerInfo ehi = new EventHandlerInfo(event,
                         newChannel(EventHandlerControl.class),
-                        newChannel(ParentScopeChannel.class),
-                        newChannel(TerminationChannel.class));
+                        newChannel(ParentScope.class),
+                        newChannel(Termination.class));
                 _eventHandlers.add(ehi);
                 instance(new EH_EVENT(ehi.psc,ehi.tc, ehi.cc, event, _scopeFrame));
             }
@@ -285,7 +283,7 @@ class SCOPE extends ACTIVITY {
                         BpelRuntimeContext ntive = getBpelRuntimeContext();
 
                         ActivityInfo terminationHandlerActivity = new ActivityInfo(genMonotonic(), _oscope.terminationHandler,
-                                newChannel(TerminationChannel.class,"TH"), newChannel(ParentScopeChannel.class,"TH"));
+                                newChannel(Termination.class,"TH"), newChannel(ParentScope.class,"TH"));
 
                         ScopeFrame terminationHandlerScopeFrame = new ScopeFrame(_oscope.terminationHandler,
                                 ntive.createScopeInstance(_scopeFrame.scopeInstanceId, _oscope.terminationHandler),
@@ -348,7 +346,7 @@ class SCOPE extends ACTIVITY {
                         BpelRuntimeContext ntive = getBpelRuntimeContext();
 
                         ActivityInfo faultHandlerActivity = new ActivityInfo(genMonotonic(), catchBlock,
-                                newChannel(TerminationChannel.class,"FH"), newChannel(ParentScopeChannel.class,"FH"));
+                                newChannel(Termination.class,"FH"), newChannel(ParentScope.class,"FH"));
 
                         ScopeFrame faultHandlerScopeFrame = new ScopeFrame(catchBlock,
                                 ntive.createScopeInstance(_scopeFrame.scopeInstanceId, catchBlock),
@@ -501,12 +499,12 @@ class SCOPE extends ACTIVITY {
         private static final long serialVersionUID = -9046603073542446478L;
         final OBase o;
         final EventHandlerControl cc;
-        final ParentScopeChannel psc;
-        final TerminationChannel tc;
+        final ParentScope psc;
+        final Termination tc;
         boolean terminateRequested;
         boolean stopRequested;
 
-        EventHandlerInfo(OBase o, EventHandlerControl cc, ParentScopeChannel psc, TerminationChannel tc) {
+        EventHandlerInfo(OBase o, EventHandlerControl cc, ParentScope psc, Termination tc) {
             this.o = o;
             this.cc = cc;
             this.psc = psc;

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -35,7 +35,6 @@ import org.apache.ode.bpel.o.OScope.Vari
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.LinkStatus;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.ReadWriteLock;
 import org.apache.ode.jacob.ChannelListener;
 import org.apache.ode.jacob.ReceiveProcess;
@@ -68,7 +67,7 @@ public class SCOPEACT extends ACTIVITY {
             LinkFrame linkframe;
             if (((OScope) _self.o).atomicScope && !_self.o.outgoingLinks.isEmpty()) {
                 Val linkInterceptorControl = newChannel(Val.class);
-                ParentScopeChannel psc = newChannel(ParentScopeChannel.class);
+                ParentScope psc = newChannel(ParentScope.class);
                 linkframe = createInterceptorLinkFrame();
                 instance(new LINKSTATUSINTERCEPTOR(linkInterceptorControl,linkframe));
                 instance(new UNLOCKER(psc, _self.parent, null, Collections.<IsolationLock>emptyList(), linkInterceptorControl));
@@ -238,8 +237,8 @@ public class SCOPEACT extends ACTIVITY {
                         _scopeFrame.scopeInstanceId, (OScope) _self.o), _scopeFrame, null);
 
                 
-                final ParentScopeChannel parent = _self.parent;
-                _self.parent = newChannel(ParentScopeChannel.class);
+                final ParentScope parent = _self.parent;
+                _self.parent = newChannel(ParentScope.class);
                 Val lsi = newChannel(Val.class);
                 instance(new UNLOCKER(_self.parent, parent, _synchChannel, _locksAcquired, lsi));
                 LinkFrame linkframe = createInterceptorLinkFrame();
@@ -283,9 +282,9 @@ public class SCOPEACT extends ACTIVITY {
 
         private static final long serialVersionUID = -476393080609348172L;
 
-        private final ParentScopeChannel _self;
+        private final ParentScope _self;
 
-        private final ParentScopeChannel _parent;
+        private final ParentScope _parent;
 
         private final Synch _synchChannel;
         
@@ -293,7 +292,7 @@ public class SCOPEACT extends ACTIVITY {
 
         private final Val _linkStatusInterceptor;
 
-        public UNLOCKER(ParentScopeChannel self, ParentScopeChannel parent, Synch synchChannel,
+        public UNLOCKER(ParentScope self, ParentScope parent, Synch synchChannel,
                 List<IsolationLock> locksAcquired, Val linkStatusInterceptor) {
             _self = self;
             _parent = parent;

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -30,9 +30,7 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.o.OSequence;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
 import org.w3c.dom.Element;
@@ -62,7 +60,7 @@ class SEQUENCE extends ACTIVITY {
     public void run() {
         final ActivityInfo child = new  ActivityInfo(genMonotonic(),
             _remaining.get(0),
-            newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+            newChannel(Termination.class), newChannel(ParentScope.class));
         instance(createChild(child, _scopeFrame, _linkFrame));
         instance(new ACTIVE(child));
     }

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -29,7 +29,6 @@ import org.apache.ode.bpel.explang.Evalu
 import org.apache.ode.bpel.o.OWait;
 import org.apache.ode.bpel.runtime.channels.Termination;
 import org.apache.ode.bpel.runtime.channels.TimerResponse;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.utils.xsd.Duration;
 
@@ -64,7 +63,7 @@ class WAIT extends ACTIVITY {
 
 
         if(dueDate.getTime() > getBpelRuntimeContext().getCurrentEventDateTime().getTime()) {
-            final TimerResponseChannel timerChannel = newChannel(TimerResponseChannel.class);
+            final TimerResponse timerChannel = newChannel(TimerResponse.class);
             getBpelRuntimeContext().registerTimer(timerChannel, dueDate);
 
             object(false, new ReceiveProcess<TimerResponse>(timerChannel, new TimerResponse() {

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=1434553&r1=1434552&r2=1434553&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 Thu Jan 17 04:37:16 2013
@@ -29,9 +29,7 @@ import org.apache.ode.bpel.o.OScope;
 import org.apache.ode.bpel.o.OWhile;
 import org.apache.ode.bpel.runtime.channels.FaultData;
 import org.apache.ode.bpel.runtime.channels.ParentScope;
-import org.apache.ode.bpel.runtime.channels.ParentScopeChannel;
 import org.apache.ode.bpel.runtime.channels.Termination;
-import org.apache.ode.bpel.runtime.channels.TerminationChannel;
 import org.apache.ode.jacob.ReceiveProcess;
 import org.apache.ode.jacob.Synch;
 import org.w3c.dom.Element;
@@ -65,7 +63,7 @@ class WHILE extends ACTIVITY {
         if (condResult) {
             ActivityInfo child = new ActivityInfo(genMonotonic(),
                     getOWhile().activity,
-                    newChannel(TerminationChannel.class), newChannel(ParentScopeChannel.class));
+                    newChannel(Termination.class), newChannel(ParentScope.class));
             instance(createChild(child, _scopeFrame, _linkFrame));
             instance(new WAITER(child));
         } else /* stop. */ {

Modified: ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/channels/PickResponse.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/channels/PickResponse.java?rev=1434553&r1=1434552&r2=1434553&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/channels/PickResponse.java (original)
+++ ode/trunk/bpel-runtime/src/main/java/org/apache/ode/bpel/runtime/channels/PickResponse.java Thu Jan 17 04:37:16 2013
@@ -23,7 +23,6 @@ package org.apache.ode.bpel.runtime.chan
 /**
  * Response channel for pick requests.
  * @jacob.kind
- * @jacob.parent TimerResponseChannel
  */
 public interface PickResponse extends TimerResponse {
 

Modified: ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/CoreBpelTest.java
URL: http://svn.apache.org/viewvc/ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/CoreBpelTest.java?rev=1434553&r1=1434552&r2=1434553&view=diff
==============================================================================
--- ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/CoreBpelTest.java (original)
+++ ode/trunk/bpel-runtime/src/test/java/org/apache/ode/bpel/runtime/CoreBpelTest.java Thu Jan 17 04:37:16 2013
@@ -32,29 +32,28 @@ import junit.framework.TestCase;
 
 import org.apache.ode.bpel.common.CorrelationKey;
 import org.apache.ode.bpel.common.FaultException;
+import org.apache.ode.bpel.evar.ExternalVariableModuleException;
 import org.apache.ode.bpel.evt.ProcessInstanceEvent;
+import org.apache.ode.bpel.iapi.ProcessConf.PartnerRoleConfig;
 import org.apache.ode.bpel.o.OCatch;
 import org.apache.ode.bpel.o.OEmpty;
-import org.apache.ode.bpel.o.OFailureHandling;
 import org.apache.ode.bpel.o.OFaultHandler;
 import org.apache.ode.bpel.o.OFlow;
 import org.apache.ode.bpel.o.OMessageVarType;
+import org.apache.ode.bpel.o.OMessageVarType.Part;
 import org.apache.ode.bpel.o.OPartnerLink;
 import org.apache.ode.bpel.o.OProcess;
 import org.apache.ode.bpel.o.OScope;
+import org.apache.ode.bpel.o.OScope.Variable;
 import org.apache.ode.bpel.o.OSequence;
 import org.apache.ode.bpel.o.OThrow;
-import org.apache.ode.bpel.o.OMessageVarType.Part;
-import org.apache.ode.bpel.o.OScope.Variable;
-import org.apache.ode.bpel.runtime.channels.ActivityRecoveryChannel;
+import org.apache.ode.bpel.runtime.channels.ActivityRecovery;
 import org.apache.ode.bpel.runtime.channels.FaultData;
-import org.apache.ode.bpel.runtime.channels.InvokeResponseChannel;
-import org.apache.ode.bpel.runtime.channels.PickResponseChannel;
-import org.apache.ode.bpel.runtime.channels.TimerResponseChannel;
+import org.apache.ode.bpel.runtime.channels.InvokeResponse;
+import org.apache.ode.bpel.runtime.channels.PickResponse;
+import org.apache.ode.bpel.runtime.channels.TimerResponse;
 import org.apache.ode.jacob.vpu.ExecutionQueueImpl;
 import org.apache.ode.jacob.vpu.JacobVPU;
-import org.apache.ode.bpel.evar.ExternalVariableModuleException;
-import org.apache.ode.bpel.iapi.ProcessConf.PartnerRoleConfig;
 import org.w3c.dom.Element;
 import org.w3c.dom.Node;
 
@@ -129,7 +128,7 @@ public class CoreBpelTest extends TestCa
     public void writeCorrelation(CorrelationSetInstance cset, CorrelationKey correlation) {
     }
 
-    public void cancel(TimerResponseChannel timerResponseChannel) {
+    public void cancel(TimerResponse timerResponseChannel) {
     }
 
     public void completedOk() {
@@ -140,7 +139,7 @@ public class CoreBpelTest extends TestCa
         _fault = faultData;
     }
 
-    public void select(PickResponseChannel response, Date timeout, boolean createInstnace, Selector[] selectors) throws FaultException {
+    public void select(PickResponse response, Date timeout, boolean createInstnace, Selector[] selectors) throws FaultException {
     }
 
     public void cancelOutstandingRequests(String channelId) {
@@ -149,11 +148,11 @@ public class CoreBpelTest extends TestCa
     public void reply(PartnerLinkInstance plink, String opName, String mexId, Element msg, QName fault) throws FaultException {
     }
 
-    public String invoke(int aid, PartnerLinkInstance partnerLinkInstance, Operation operation, Element outboundMsg, InvokeResponseChannel invokeResponseChannel) {
+    public String invoke(int aid, PartnerLinkInstance partnerLinkInstance, Operation operation, Element outboundMsg, InvokeResponse invokeResponseChannel) {
         return null;
     }
 
-    public void registerTimer(TimerResponseChannel timerChannel, Date timeToFire) {
+    public void registerTimer(TimerResponse timerChannel, Date timeToFire) {
     }
 
     public void terminate() {
@@ -398,10 +397,10 @@ public class CoreBpelTest extends TestCa
         return null;
     }
 
-    public void registerActivityForRecovery(ActivityRecoveryChannel channel, long activityId, String reason, Date dateTime, Element data, String[] actions, int retries) {
+    public void registerActivityForRecovery(ActivityRecovery channel, long activityId, String reason, Date dateTime, Element data, String[] actions, int retries) {
     }
 
-    public void unregisterActivityForRecovery(ActivityRecoveryChannel channel) {
+    public void unregisterActivityForRecovery(ActivityRecovery channel) {
     }
 
     public void recoverActivity(String channel, long activityId, String action, FaultData fault) {