You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafodion.apache.org by an...@apache.org on 2017/09/07 01:55:07 UTC

[13/30] incubator-trafodion git commit: TRAFODION-2731 CodeCleanup: Remove obsolete, legacy and unused code

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_mdam.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_mdam.h b/core/sql/executor/ex_mdam.h
index e07aaa7..e7fa197 100644
--- a/core/sql/executor/ex_mdam.h
+++ b/core/sql/executor/ex_mdam.h
@@ -86,25 +86,25 @@ class MdamPredIterator : public ExGod
 
 public:
 
-   NA_EIDPROC MdamPredIterator(MdamColumn * first,Lng32 maxDisjunctNumber);
+   MdamPredIterator(MdamColumn * first,Lng32 maxDisjunctNumber);
 
-   NA_EIDPROC ~MdamPredIterator()
+   ~MdamPredIterator()
        {  };
 
-   NA_EIDPROC Lng32 getNextDisjunctNumber();  // -1 means no more disjuncts
+   Lng32 getNextDisjunctNumber();  // -1 means no more disjuncts
 
    // In the next three methods, currentPred is state stored in MdamColumn
    // objects, but updated by these methods only.
 
    // FALSE means no more predicates
-   NA_EIDPROC NABoolean positionToNextOr(MdamPred **currentPred);
+   NABoolean positionToNextOr(MdamPred **currentPred);
 
    // 0 (NULL) means no more predicates
    // for this key column within this predicate  
-   NA_EIDPROC MdamPred * getNextPred(MdamPred **currentPred); 
+   MdamPred * getNextPred(MdamPred **currentPred); 
    
    // Position the predicate list to the current disjunct.
-   NA_EIDPROC void positionToCurrentDisjunct(MdamPred **currentPred);
+   void positionToCurrentDisjunct(MdamPred **currentPred);
 
 };
 
@@ -189,7 +189,7 @@ public:
 
   enum getNextValueReturnType { TRAVERSE_DOWN, TRAVERSE_UP, SUBSET, PROBE };
 
-  NA_EIDPROC MdamColumn(MdamColumn * previous,
+  MdamColumn(MdamColumn * previous,
 			MdamColumnGen *columnGenInfo,
 			ex_globals *glob,
 			sql_buffer_pool *pool,
@@ -198,15 +198,15 @@ public:
 			unsigned short valueAtpIndex,
                         const ex_tcb *tcb);
 
-  NA_EIDPROC ~MdamColumn();
+  ~MdamColumn();
 
   // methods used to build an Mdam network
 
-  NA_EIDPROC void initCurrentPred()
+  void initCurrentPred()
   { currentPred_ = columnGenInfo_->getFirstPred(); };
   
   // returns TRUE if the disjunct number is in some stop list
-  NA_EIDPROC NABoolean buildDisjunct(MdamPredIterator & predIterator,
+  NABoolean buildDisjunct(MdamPredIterator & predIterator,
 				     sql_buffer_pool *pool,
 				     atp_struct *atp0,
 				     atp_struct *atp1,
@@ -220,29 +220,29 @@ public:
                                       mdamRefListEntrysForStopListsHeap,
                                      Lng32 & dataConvErrorFlag);
 
-  NA_EIDPROC void tossDisjunct(FixedSizeHeapManager & mdamIntervalHeap,
+  void tossDisjunct(FixedSizeHeapManager & mdamIntervalHeap,
                                FixedSizeHeapManager & mdamRefListEntryHeap);
 
-  NA_EIDPROC void mergeDisjunct(Lng32 disjunct_number,
+  void mergeDisjunct(Lng32 disjunct_number,
 				FixedSizeHeapManager & mdamIntervalHeap,
 				FixedSizeHeapManager & mdamRefListEntryHeap);
 
-  NA_EIDPROC NABoolean disjunctIsEmpty();
+  NABoolean disjunctIsEmpty();
 
   // Method used to destroy an Mdam network.
-  NA_EIDPROC void releaseNetwork(FixedSizeHeapManager & mdamIntervalHeap,
+  void releaseNetwork(FixedSizeHeapManager & mdamIntervalHeap,
                                  FixedSizeHeapManager & mdamRefListEntryHeap);
 
   // Member function used when we are done with the plan.
-  NA_EIDPROC void release(FixedSizeHeapManager & mdamRefListEntrysForStopListsHeap);
+  void release(FixedSizeHeapManager & mdamRefListEntrysForStopListsHeap);
 
   // methods used to traverse an Mdam network
-  NA_EIDPROC MdamIntervalList & getIntervalList();
+  MdamIntervalList & getIntervalList();
 
-  NA_EIDPROC MdamColumn * nextColumn() { return next_; };
-  NA_EIDPROC MdamColumn * previousColumn() { return previous_; };
+  MdamColumn * nextColumn() { return next_; };
+  MdamColumn * previousColumn() { return previous_; };
 
-  NA_EIDPROC NABoolean initNextValue();
+  NABoolean initNextValue();
 
   // returns TRAVERSE_DOWN if a value was obtained, and the current
   // interval is not a subset interval; SUBSET if values were obtained
@@ -259,30 +259,30 @@ public:
   //                        (but might not be the same value)
   //                        beginExclFlag and endExclFlag are both set and
   //                        should be applied to the key range as a whole
-  NA_EIDPROC getNextValueReturnType getNextValue(ULng32 pFRCounter,
+  getNextValueReturnType getNextValue(ULng32 pFRCounter,
 						 char *bktarget,
 						 char *ektarget,
 						 short &beginExclFlag,
 						 short &endExclFlag,
 			   FixedSizeHeapManager & mdamRefListEntryHeap);
 
-  NA_EIDPROC void reportProbeResult(char *keyData);
+  void reportProbeResult(char *keyData);
 
-  NA_EIDPROC void completeKey(char *bktarget,
+  void completeKey(char *bktarget,
                               char *ektarget,
                               short bkexcl,
                               short ekexcl);
 
-  NA_EIDPROC ULng32 getOffset() 
+  ULng32 getOffset() 
     { return columnGenInfo_->getOffset(); };
 
   // Print function.
   #ifdef NA_MDAM_EXECUTOR_DEBUG
-  NA_EIDPROC void print(const char * header = "") const;
+  void print(const char * header = "") const;
   #endif /* NA_MDAM_EXECUTOR_DEBUG */
 
 private:
-  NA_EIDPROC void setNextColumn(MdamColumn * next);
+  void setNextColumn(MdamColumn * next);
 
 
 
@@ -326,39 +326,39 @@ class keyMdamEx : public keyRangeEx
   NABoolean complementKeysBeforeReturning_;
 
 public:
-  NA_EIDPROC keyMdamEx(const keyRangeGen & tdb_key,
+  keyMdamEx(const keyRangeGen & tdb_key,
 		       const short in_version,
 		       sql_buffer_pool *pool,
 		       ex_globals *glob,
                        const ex_tcb *tcb);
  
-  NA_EIDPROC ~keyMdamEx();
+  ~keyMdamEx();
 
-  NA_EIDPROC virtual ExeErrorCode initNextKeyRange(sql_buffer_pool *pool,
+  virtual ExeErrorCode initNextKeyRange(sql_buffer_pool *pool,
 					           atp_struct * atp0);
 
-  NA_EIDPROC virtual getNextKeyRangeReturnType getNextKeyRange
+  virtual getNextKeyRangeReturnType getNextKeyRange
     (atp_struct * atp0,NABoolean fetchRangeHadRows,
      NABoolean detectNullRange = TRUE); 
 
-  NA_EIDPROC virtual void reportProbeResult(char *keyData);
+  virtual void reportProbeResult(char *keyData);
 
   // release tupp storage
-  NA_EIDPROC void release();
+  void release();
 
-  NA_EIDPROC keyMdamGen & getGenInfo()
+  keyMdamGen & getGenInfo()
   { return (keyMdamGen &)tdbKey_; };
 
 private:
   // Returns zero if memory for MdamRefListEntry's and MdamInterval's
   // is successfully acquired.  Otherwise, returns ExeErrorCode.
-  NA_EIDPROC ExeErrorCode buildNetwork(sql_buffer_pool *pool,atp_struct *atp0);
+  ExeErrorCode buildNetwork(sql_buffer_pool *pool,atp_struct *atp0);
 
-  NA_EIDPROC void destroyNetwork();
+  void destroyNetwork();
 
   // Print function.
   #ifdef NA_MDAM_EXECUTOR_DEBUG
-  NA_EIDPROC void print(const char * header = "") const;
+  void print(const char * header = "") const;
   #endif /* NA_MDAM_EXECUTOR_DEBUG */
 
 };

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_mj.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_mj.h b/core/sql/executor/ex_mj.h
index 6844df6..4d1e6ae 100644
--- a/core/sql/executor/ex_mj.h
+++ b/core/sql/executor/ex_mj.h
@@ -75,16 +75,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_mj_tdb()
+  ex_mj_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_mj_tdb()
+  virtual ~ex_mj_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -158,7 +158,7 @@ public:
   
   void freeResources();  // free resources
   
-  NA_EIDPROC virtual ex_tcb_private_state * allocatePstates(
+  virtual ex_tcb_private_state * allocatePstates(
        Lng32 &numElems,      // inout, desired/actual elements
        Lng32 &pstateLength); // out, length of one element
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_onlj.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_onlj.cpp b/core/sql/executor/ex_onlj.cpp
index 87118ec..5c5f4b6 100644
--- a/core/sql/executor/ex_onlj.cpp
+++ b/core/sql/executor/ex_onlj.cpp
@@ -43,9 +43,7 @@
 #include "str.h"
 #include "ExStats.h"
 
-#ifndef __EID
 #include "ex_exe_stmt_globals.h"
-#endif
 #include "sql_buffer_size.h"
 
 /////////////////////////////////////////////////////////////////////////
@@ -455,7 +453,6 @@ ExWorkProcRetcode ExOnljTcb::work_phase1()
           else
             {
 #ifdef TRACE_PAPA_DEQUEUE
-#ifndef __EID
               if ((pentry1->downState.numGetNextsIssued - pstate1.pushedDownGetNexts_ ) > 1)
                 {
                    cout << "ExOnljTcb::work_phase1, too many requests." 
@@ -466,7 +463,6 @@ ExWorkProcRetcode ExOnljTcb::work_phase1()
                         << endl;
                 }
 #endif
-#endif
               // Push down the GET_NEXT request
 
               if (pentry1->downState.request == ex_queue::GET_NEXT_N || pentry1->downState.request == ex_queue::GET_NEXT_N_SKIP)
@@ -681,7 +677,6 @@ ExWorkProcRetcode ExOnljTcb::work_phase2()
 	      lentry->setDiagsArea(NULL);
 	      // Adjust the rowcount in the statement globals
 	      // Subtract the rows that were "undone"
-#ifndef __EID
               //if we have already subtracted rowcount once for  this 
 	      // parent entry don't do it again. We only have to do it once per parent entry row.
 	      if (!pstate.rowAlreadyRaisedNFError_)
@@ -699,14 +694,6 @@ ExWorkProcRetcode ExOnljTcb::work_phase2()
 		  else
 		    ex_assert(g, "Rowset insert has a flow node that is not in the master executor");
 		}
-#else
-	      if (onljTdb().isRowsetIterator() && 
-		  onljTdb().isNonFatalErrorTolerated() && 
-		  onljTdb().isSetNFErrorJoin())
-		ex_assert(0, "Cannot execute in DP2");
-		  
-		
-#endif
 	    }
 	}
       // set the atp of the right child to be the same as the left atp
@@ -1429,14 +1416,7 @@ ExWorkProcRetcode ExOnljTcb::work_phase3()
 
         pstate.tgtRequestCount_++;
 
-        // If it is an EID then it is a pushdown and we should not count the number of rows
-        // coming from the right side if the right side is an MV IUD LOG
-#ifdef __EID
-        if (!isDrivingMVLogging())
-	   pstate.rowCount_ += rentry->upState.getMatchNo();
-#else
-	   pstate.rowCount_ += rentry->upState.getMatchNo();
-#endif
+        pstate.rowCount_ += rentry->upState.getMatchNo();
 
         // Be ready to null instantiate the new left row
         pstate.outerMatched_ = ExConstants::EX_FALSE;
@@ -1677,11 +1657,8 @@ ExWorkProcRetcode ExOnljTcb::work_phase3()
     // merge any diags from the upentry with any diags that may be in the 
     // parent entry diags area.
     NABoolean anyRowsAffected = FALSE;
-#ifndef __EID
     ExMasterStmtGlobals *g = getGlobals()->
       castToExExeStmtGlobals()->castToExMasterStmtGlobals();
-#endif
-    
    
     // if a  split-top is returning a diags area, 
     // set the accumulated diags in the parent entry. 
@@ -1716,7 +1693,6 @@ ExWorkProcRetcode ExOnljTcb::work_phase3()
       // Compute the rows affected and set the NF warning for any errors coming from the left or right.
       if (onljTdb().isRowsetIterator() && onljTdb().isNonFatalErrorTolerated() && onljTdb().isSetNFErrorJoin())
 	{
-#ifndef __EID	            
 	  if (g)
 	    {		 
 	      Int64 rowsAffected = g->getRowsAffected();	  
@@ -1725,7 +1701,6 @@ ExWorkProcRetcode ExOnljTcb::work_phase3()
 	    }
 	  else
 	    ex_assert(g, "Rowset insert has a flow node that is not in the master executor");
-#endif
 	  ComDiagsArea *mergedDiags = uentry->getDiagsArea();
 
 	  // if it's a diags just containing rowcount and no error/warning

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_onlj.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_onlj.h b/core/sql/executor/ex_onlj.h
index 5d7dab1..e8e68d0 100644
--- a/core/sql/executor/ex_onlj.h
+++ b/core/sql/executor/ex_onlj.h
@@ -70,16 +70,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExOnljTdb()
+  ExOnljTdb()
   {}
 
-  NA_EIDPROC virtual ~ExOnljTdb()
+  virtual ~ExOnljTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_queue.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_queue.cpp b/core/sql/executor/ex_queue.cpp
index c40377d..460aa60 100644
--- a/core/sql/executor/ex_queue.cpp
+++ b/core/sql/executor/ex_queue.cpp
@@ -676,7 +676,6 @@ void ex_queue_entry::initializeState(const ex_queue::queue_type type)
   }
 }
 
-NA_EIDPROC
 const char * NodeTypeToString(ComTdb::ex_node_type nodeType)
 {
   const char * tdbName;
@@ -823,7 +822,6 @@ void ex_queue::injectErrorOrCancel()
           {
             needsError = TRUE;
             qe->upState.status = Q_SQLERROR;
-  #if (!defined (__EID) && !defined(NA_C89))
             cerr << "Converting a Q_OK_MMORE to a Q_SQLERROR, from "
                  << NodeTypeToString(unblockSubtask_->getTcb()->getNodeType())
                  << "(" << unblockSubtask_->getTcb() << ")" 
@@ -831,7 +829,6 @@ void ex_queue::injectErrorOrCancel()
                  << NodeTypeToString(insertSubtask_->getTcb()->getNodeType())
                  << "(" << insertSubtask_->getTcb() << ")" 
                  << endl;
-  #endif
             break;
           }
         case Q_NO_DATA:
@@ -844,7 +841,6 @@ void ex_queue::injectErrorOrCancel()
               newQNODATA->upState.status  = Q_NO_DATA;
               newQNODATA->getAtp()->copyAtp(qe->getAtp());
               tail_++;
-#if (!defined (__EID) && !defined(NA_C89))
               cerr << "Injecting a Q_SQLERROR before a Q_NO_DATA, from " 
                  << NodeTypeToString(unblockSubtask_->getTcb()->getNodeType())
                  << "(" << unblockSubtask_->getTcb() << ")" 
@@ -852,7 +848,6 @@ void ex_queue::injectErrorOrCancel()
                  << NodeTypeToString(insertSubtask_->getTcb()->getNodeType())
                  << "(" << insertSubtask_->getTcb() << ")" 
                  << endl;
-#endif
             }
           break;
         default:
@@ -879,7 +874,6 @@ void ex_queue::injectErrorOrCancel()
 
 void ex_queue::logHeader()
 {
-#if (!defined (__EID) && !defined(NA_C89))
   if (upDown_ == UP_QUEUE)
     {
       cerr 
@@ -899,14 +893,11 @@ void ex_queue::logHeader()
            << "(" << insertSubtask_->getTcb() << ")" 
            ;
     }
-
-#endif  
 }
 
 void ex_queue::logRemoveHead()
 {
 #if 0  
-#if (!defined (__EID) && !defined(NA_C89))
 
     ex_queue_entry *qe = &queue_[head_ & mask_];
 
@@ -957,7 +948,6 @@ void ex_queue::logRemoveHead()
    }
   cerr << endl;
 #endif
-#endif
 }
 
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_queue.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_queue.h b/core/sql/executor/ex_queue.h
index 114176c..6e4d82a 100644
--- a/core/sql/executor/ex_queue.h
+++ b/core/sql/executor/ex_queue.h
@@ -174,7 +174,6 @@ public:
   };
 
   // Constructor for a queue
-  NA_EIDPROC
     ex_queue(const queue_type    type,
 	     queue_index         initialSize,
 	     ex_cri_desc *       criDesc,
@@ -184,7 +183,6 @@ public:
   
   // allocate ATPs for entries that don't have one already,
   // use pre-allocated ATPs if they are passed in
-  NA_EIDPROC
     NABoolean allocateAtps(CollHeap * space,
 			   atp_struct * atps = NULL,
 			   queue_index numNewAtps = 0,
@@ -195,43 +193,32 @@ public:
   // PSTATE as a sample (deprecated method, use the other method that
   // doesn't need the pstate to be passed in and that supports
   // preallocated pstates and allocation as an array)
-  NA_EIDPROC
     void allocatePstate(ex_tcb_private_state *p,
 			ex_tcb * tcb);
   // allocate PSTATE objects for queue entries that don't have a
   // PSTATE yet, using an array of pre-allocated PSTATEs if passed in
-  NA_EIDPROC
     NABoolean allocatePstate(ex_tcb * tcb,
 			     ex_tcb_private_state *pstates = NULL,
 			     queue_index numNewPstates = 0,
 			     Lng32 pstateLength = 0,
 			     NABoolean failureIsFatal = TRUE);
   
-  NA_EIDPROC
     void deallocateAtps();
-  NA_EIDPROC
     void deallocatePstate();
 
   // does this queue need its own ATPs?
-  NA_EIDPROC
   Int32 needsAtps() const                               { return needsAtps_; }
 
   // resize a queue (including the ATPs and the pstates), return new size
-  NA_EIDPROC
   NABoolean needsResize() const                     { return needsResize_; }
-  NA_EIDPROC
   Lng32 getResizeLimit() const                { return (Lng32) resizeLimit_; }
-  NA_EIDPROC
   void setResizeLimit(Lng32 l)          { resizeLimit_ = (ULng32) l; }
-  NA_EIDPROC
     queue_index resize(ex_tcb *    tcb,
 		       queue_index newSize);
 
-  NA_EIDPROC
     ex_cri_desc * getCriDesc();
   
   // destructor
-  NA_EIDPROC
     ~ex_queue();
 
   //
@@ -244,39 +231,36 @@ public:
   // gets address/index of empty queue_entry to modify it
   // (the entry is not yet inserted into the queue)
   //
-  NA_EIDPROC ex_queue_entry *  getTailEntry() const;
-  NA_EIDPROC
+  ex_queue_entry *  getTailEntry() const;
     queue_index       getTailIndex() const;
   
   // next queue_entry now becomes tail_
-  NA_EIDPROC
     void insert();
   
   //
   // Cancel a down request already inserted into the queue; cancel 
   // a request with a given value for parentIndex.
   //
-  NA_EIDPROC void cancelRequest();
-  NA_EIDPROC
+  void cancelRequest();
     void cancelRequest(const queue_index i);
-  NA_EIDPROC void cancelRequestWithParentIndex(queue_index pindex);
-  NA_EIDPROC void cancelRequestWithParentIndexRange(queue_index startPI, queue_index endPI);
+  void cancelRequestWithParentIndex(queue_index pindex);
+  void cancelRequestWithParentIndexRange(queue_index startPI, queue_index endPI);
 
   //?johannes?
-  NA_EIDPROC void getNextNRequestInit(const Lng32 tuples);
-  NA_EIDPROC void getNextNRequest(const Lng32 tuples);
+  void getNextNRequestInit(const Lng32 tuples);
+  void getNextNRequest(const Lng32 tuples);
 
-  NA_EIDPROC void getNextNMaybeWaitRequestInit(const Lng32 tuples);
-  NA_EIDPROC void getNextNMaybeWaitRequest(const Lng32 tuples);
+  void getNextNMaybeWaitRequestInit(const Lng32 tuples);
+  void getNextNMaybeWaitRequest(const Lng32 tuples);
 
-  NA_EIDPROC void getNextNSkipRequestInit(const Lng32 tuples);
-  NA_EIDPROC void getNextNSkipRequest(const Lng32 tuples);
+  void getNextNSkipRequestInit(const Lng32 tuples);
+  void getNextNSkipRequest(const Lng32 tuples);
 
-  NA_EIDPROC void getNextNMaybeWaitSkipRequestInit(const Lng32 tuples);
-  NA_EIDPROC void getNextNMaybeWaitSkipRequest(const Lng32 tuples);
+  void getNextNMaybeWaitSkipRequestInit(const Lng32 tuples);
+  void getNextNMaybeWaitSkipRequest(const Lng32 tuples);
 
-  NA_EIDPROC void getNext0MaybeWaitRequest(void);
-  NA_EIDPROC void getNext0MaybeWaitRequestInit(void);
+  void getNext0MaybeWaitRequest(void);
+  void getNext0MaybeWaitRequestInit(void);
   //?johannes??
 
   //
@@ -287,22 +271,17 @@ public:
   //
   // gets address of i-th queue-entry
   //
-  NA_EIDPROC
     ex_queue_entry *  getQueueEntry(const queue_index i) const;
-  NA_EIDPROC
     ex_queue_entry *  getHeadEntry() const;
-  NA_EIDPROC
     queue_index       getHeadIndex() const;
 
   // check whether a certain entry exists (used to loop through entries)
-  NA_EIDPROC
   inline Int32        entryExists(queue_index ix) const;
 
   void handleFullQueue();
   void handleEmptyQueue();
 
   // removes the head and it becomes empty;
-NA_EIDPROC
 #ifndef _DEBUG
 inline
 #endif
@@ -320,33 +299,28 @@ inline
   // the queue is just looking for a Q_NO_DATA. Hence these shouldnt be
   // considered for qresizing as the query has been satisfied.
 
-  NA_EIDPROC
   void deleteHeadEntry();
   // soln 10-040111-2308 end
 
   // queue the size of the queue and the number of entries in it.
-  NA_EIDPROC
     queue_index    getSize() const;  //allocated size
-  NA_EIDPROC
     queue_index inline getLength() const;  //occupied entries between 0 and size-1
-  NA_EIDPROC
     Int32 inline     isFull() const;  // returns true if queue is full
-  NA_EIDPROC
     Int32 inline     isEmpty() const;  // returns true if queue is full
 
-  NA_EIDPROC inline void setInsertSubtask(ExSubtask *insertSubtask)
+  inline void setInsertSubtask(ExSubtask *insertSubtask)
                                        { insertSubtask_ = insertSubtask; }
-  NA_EIDPROC inline void setUnblockSubtask(ExSubtask *unblockSubtask)
+  inline void setUnblockSubtask(ExSubtask *unblockSubtask)
                                      { unblockSubtask_ = unblockSubtask; }
 // warning elimination (removed "inline")
-  NA_EIDPROC void setCancelSubtask(ExSubtask *cancelSubtask)
+  void setCancelSubtask(ExSubtask *cancelSubtask)
   { ExQueueAssert(upDown_ == DOWN_QUEUE,""); cancelSubtask_ = cancelSubtask; }
-  NA_EIDPROC inline void setResizeSubtask(ExSubtask *resizeSubtask)
+  inline void setResizeSubtask(ExSubtask *resizeSubtask)
                                        { resizeSubtask_ = resizeSubtask; }
 
 //?johannes?
   // warning elimination (removed "inline")
-  NA_EIDPROC void setNextSubtask(ExSubtask *nextSubtask)
+  void setNextSubtask(ExSubtask *nextSubtask)
   { ExQueueAssert(upDown_ == DOWN_QUEUE,""); nextSubtask_ = nextSubtask; }
 //?johannes??
 
@@ -398,34 +372,27 @@ private:
   //?johannes??
 
   // is queue entry i vacant?
-  NA_EIDPROC inline Int32 isVacant(const queue_index i) const;
+  inline Int32 isVacant(const queue_index i) const;
 
-  NA_EIDPROC void injectErrorOrCancel();
+  void injectErrorOrCancel();
 
   // for debuggin'
 
-  NA_EIDPROC
  
 	void logHeader();
  
-  NA_EIDPROC
     void logCancel(queue_index i)
     {
     #if 0  
-    #if (!defined (__EID) && !defined(NA_C89))
       logHeader();
       cerr << " cancel " << i << " (" << (i  & (size_-1)) << ")" << endl;
     #endif
-    #endif
     }
 
 
-  NA_EIDPROC
     void logInsert()
     {
     #if 0  
-    #if (!defined (__EID) && !defined(NA_C89))
-
       ex_queue_entry *qe = &queue_[tail_ & (size_ - 1)];
 
       logHeader();
@@ -474,10 +441,8 @@ private:
 	}
       cerr << endl;
     #endif
-    #endif
     }
 
-  NA_EIDPROC
     void logRemoveHead();  
 
 };  // ex_queue
@@ -514,7 +479,7 @@ public:
   
   queue_index             parentIndex;
 
-  NA_EIDPROC inline NABoolean operator==(const down_state &other) const
+  inline NABoolean operator==(const down_state &other) const
   {
     return (request      == other.request) &&
            (requestValue == other.requestValue) &&
@@ -534,7 +499,7 @@ friend class SqlBufferOlt;
 friend class SqlBufferOltSmall;
 
 public:
-  NA_EIDPROC inline NABoolean operator==(const up_state &other) const
+  inline NABoolean operator==(const up_state &other) const
   {
     return (parentIndex  == other.parentIndex) &&
            (status       == other.status);
@@ -545,12 +510,12 @@ public:
   ex_queue::up_status    status; // type of entry (end-of-data, error, etc.)
 
   // accessors
-  NA_EIDPROC inline Lng32 getMatchNo(void) const;
-  NA_EIDPROC inline NABoolean getDoneNoRowsMatchNo(void) const;
+  inline Lng32 getMatchNo(void) const;
+  inline NABoolean getDoneNoRowsMatchNo(void) const;
 
   // mutators
-  NA_EIDPROC inline Lng32 setMatchNo(Int64 n);
-  NA_EIDPROC inline void setDoneNoRowsMatchNo(void);
+  inline Lng32 setMatchNo(Int64 n);
+  inline void setDoneNoRowsMatchNo(void);
 
 private:
   // matchNo is private to handle overflow situations.  There is only one
@@ -583,38 +548,36 @@ class ex_queue_entry
 
   ex_tcb_private_state * pstate;  // private (reader's) state
   
-  NA_EIDPROC 
+  
     inline ex_cri_desc *   criDesc() const;
-  NA_EIDPROC 
+  
     inline unsigned short  numTuples() const;
-  NA_EIDPROC 
+  
     inline tupp &          getTupp(Lng32 i) const;
-  NA_EIDPROC 
+  
      void            passAtp(const ex_queue_entry *from);
-  NA_EIDPROC 
+  
      void            passAtp(atp_struct *from);
-  NA_EIDPROC 
+  
     inline void            copyAtp(const ex_queue_entry *from);
-  NA_EIDPROC 
+  
     inline void            copyAtp(atp_struct *from);
-  NA_EIDPROC 
+  
     inline atp_struct *    getAtp() const;
 
   // 
   // Routines to get and set diagnostics area.
   //
-  NA_EIDPROC 
+  
     inline ComDiagsArea    *getDiagsArea() const;
-  NA_EIDPROC 
+  
     inline void            setDiagsArea(ComDiagsArea* diagsArea);
 
  private:
 
-  NA_EIDPROC
     void      initializeState (const ex_queue::queue_type type);
 
   // Used to check that an entry being inserted is intialized properly
-  NA_EIDPROC
   inline Int32 checkState(const ex_queue::queue_type type)
   {
     return (type == ex_queue::UP_QUEUE

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_root.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_root.cpp b/core/sql/executor/ex_root.cpp
index e8a116c..77ab218 100644
--- a/core/sql/executor/ex_root.cpp
+++ b/core/sql/executor/ex_root.cpp
@@ -139,8 +139,7 @@ ex_tcb * ex_root_tdb::build(CliGlobals *cliGlobals, ex_globals * glob)
   UInt32 numOfNewEspsStarted = 0; // num of new esps started by this operator.
   UInt32 numOfTotalEspsUsed = 0;  // num of total esps used by this operator.
   Int64 newprocessTime = 0;
-  if ((getCollectStatsType() == ComTdb::MEASURE_STATS) ||
-      (getCollectStatsType() == ComTdb::ACCUMULATED_STATS) ||
+  if ((getCollectStatsType() == ComTdb::ACCUMULATED_STATS) ||
       (getCollectStatsType() == ComTdb::OPERATOR_STATS) ||
       (getCollectStatsType() == ComTdb::PERTABLE_STATS))
     {
@@ -151,10 +150,9 @@ ex_tcb * ex_root_tdb::build(CliGlobals *cliGlobals, ex_globals * glob)
   rtFragTable->assignEsps(TRUE, numOfTotalEspsUsed, numOfNewEspsStarted 
                           );
 
-  if (((getCollectStatsType() == ComTdb::MEASURE_STATS) ||
-       (getCollectStatsType() == ComTdb::ACCUMULATED_STATS) ||
+  if (((getCollectStatsType() == ComTdb::ACCUMULATED_STATS) ||
        (getCollectStatsType() == ComTdb::OPERATOR_STATS) ||
-      (getCollectStatsType() == ComTdb::PERTABLE_STATS)) &&
+       (getCollectStatsType() == ComTdb::PERTABLE_STATS)) &&
       (numOfNewEspsStarted > 0))
     {
       newprocessTime = JULIANTIMESTAMP(OMIT,OMIT,OMIT,OMIT) - newprocessTime;
@@ -603,11 +601,10 @@ ExOperStats * ex_root_tcb::doAllocateStatsEntry(CollHeap *heap, ComTdb *tdb)
     if (ss != NULL)
       ((ExFragRootOperStats *)stat)->setQueryId(ss->getQueryId(), ss->getQueryIdLen());
   }
-  else if (statsType == ComTdb::MEASURE_STATS ||
-	  statsType == ComTdb::ACCUMULATED_STATS)
+  else if (statsType == ComTdb::ACCUMULATED_STATS)
   {
-    // if measure or accumulated statistics are to be collected, allocate
-    // one measure stats entry and insert it into the queue.
+    // if accumulated statistics are to be collected, allocate
+    // one stats entry and insert it into the queue.
     // All executor operators that collect stats will use this
     // entry to update stats.
     // These stats are not associated with any particular
@@ -1839,7 +1836,7 @@ Int32 ex_root_tcb::fetch(CliGlobals *cliGlobals,
 		    // Note that NA_JulianTimestamp is in micro seconds and that
 		    //  streamTimeout_ is in .01 seconds
                     Int64 wait64 = streamTimeout_; // to avoid timeout overflow
-                    // Extra time may be needed, if Measure is running for stats
+                    // Extra time may be needed
                     IpcTimeout extraTime = 0;
                     if (getGlobals()->statsEnabled())
                         extraTime = 100;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_root.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_root.h b/core/sql/executor/ex_root.h
index 88cc759..9797c9e 100644
--- a/core/sql/executor/ex_root.h
+++ b/core/sql/executor/ex_root.h
@@ -87,16 +87,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_root_tdb()
+  ex_root_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_root_tdb()
+  virtual ~ex_root_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(CliGlobals *cliGlobals, 
+  virtual ex_tcb *build(CliGlobals *cliGlobals, 
                                    ex_globals *globals);
 
 private:
@@ -303,7 +303,7 @@ public:
   void dumpCb();
 
   // Enforce query CPU limit.
-  NA_EIDPROC virtual void cpuLimitExceeded();
+  virtual void cpuLimitExceeded();
 
 private:
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_send_bottom.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_send_bottom.cpp b/core/sql/executor/ex_send_bottom.cpp
index 1717eee..3db48fb 100644
--- a/core/sql/executor/ex_send_bottom.cpp
+++ b/core/sql/executor/ex_send_bottom.cpp
@@ -199,9 +199,7 @@ ex_send_bottom_tcb::ex_send_bottom_tcb(
     Int32 otherCPU, otherPID, otherNode;
     SB_Int64_Type seqNum = 0;
     phandle.decompose2(otherCPU, otherPID, otherNode
-#ifdef SQ_PHANDLE_VERIFIER
                       , seqNum
-#endif
                       );
     
     // Seaquest Node num == old cpuNum
@@ -809,7 +807,7 @@ short ex_send_bottom_tcb::checkReply()
 	       TRUE,                // diags areas are external.
 	       isDiagsAreaToBeSent, //);// Already have a DA.
 	       defragTd_
-#if (defined (NA_LINUX) && defined(_DEBUG) && !defined(__EID))
+#if (defined(_DEBUG))
 	       ,this
 #endif
 	       );

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_send_bottom.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_send_bottom.h b/core/sql/executor/ex_send_bottom.h
index 944e42f..7a81432 100644
--- a/core/sql/executor/ex_send_bottom.h
+++ b/core/sql/executor/ex_send_bottom.h
@@ -81,16 +81,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_send_bottom_tdb()
+  ex_send_bottom_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_send_bottom_tdb()
+  virtual ~ex_send_bottom_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
   // allocate one node to communicate with a particular parent instance
   virtual ex_send_bottom_tcb * buildInstance(ExExeStmtGlobals * glob,
@@ -190,7 +190,7 @@ public:
 
   IpcConnection * getClient();
 
-  virtual NA_EIDPROC ExOperStats *doAllocateStatsEntry(CollHeap *heap,
+  virtual ExOperStats *doAllocateStatsEntry(CollHeap *heap,
                                                        ComTdb *tdb);
 
   void setExtractConsumerFlag(NABoolean b) { isExtractConsumer_ = b; }

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_send_top.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_send_top.cpp b/core/sql/executor/ex_send_top.cpp
index e0862c8..c4a1ec9 100644
--- a/core/sql/executor/ex_send_top.cpp
+++ b/core/sql/executor/ex_send_top.cpp
@@ -358,9 +358,7 @@ Int32 ex_send_top_tcb::fixup()
     Int32 otherCPU, otherPID, otherNode;
     SB_Int64_Type seqNum = 0;
     phandle.decompose2(otherCPU, otherPID, otherNode
-#ifdef SQ_PHANDLE_VERIFIER
                        , seqNum
-#endif
                       );
 
     // Store SeaMonster information in the TCB and in IPC objects

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_send_top.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_send_top.h b/core/sql/executor/ex_send_top.h
index c00ddf1..c4da720 100644
--- a/core/sql/executor/ex_send_top.h
+++ b/core/sql/executor/ex_send_top.h
@@ -79,16 +79,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_send_top_tdb()
+  ex_send_top_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_send_top_tdb()
+  virtual ~ex_send_top_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
   // ---------------------------------------------------------------------
   // send top nodes are usually built such that many tcbs exist for a
@@ -188,7 +188,7 @@ public:
 
   virtual const ex_tcb* getChild(Int32 pos) const;
 
-  virtual NA_EIDPROC ExOperStats *doAllocateStatsEntry(CollHeap *heap,
+  virtual ExOperStats *doAllocateStatsEntry(CollHeap *heap,
                                                        ComTdb *tdb);
 
                   // Tell the server that we lost interest in a request

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_sort.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_sort.cpp b/core/sql/executor/ex_sort.cpp
index c92a38e..de9a2c7 100644
--- a/core/sql/executor/ex_sort.cpp
+++ b/core/sql/executor/ex_sort.cpp
@@ -66,9 +66,10 @@ const char *ExSortTcb::SortPhaseStr[] = {
 NABoolean ExSortTcb::needStatsEntry()
 {
   ComTdb::CollectStatsType statsType = getGlobals()->getStatsArea()->getCollectStatsType();
-  // stats are collected for ALL and MEASURE options.
-  if (statsType == ComTdb::MEASURE_STATS || statsType == ComTdb::ALL_STATS || 
-    statsType == ComTdb::OPERATOR_STATS)
+
+  // stats are collected for ALL or OPERATOR options.
+  if (statsType == ComTdb::ALL_STATS || 
+      statsType == ComTdb::OPERATOR_STATS)
     return TRUE;
   else
     return FALSE;
@@ -80,11 +81,11 @@ ExOperStats * ExSortTcb::doAllocateStatsEntry(CollHeap *heap,
   ExBMOStats *stat;
 
   ComTdb::CollectStatsType statsType = getGlobals()->getStatsArea()->getCollectStatsType();
-  if (statsType == ComTdb::MEASURE_STATS)
+  if (statsType == ComTdb::ACCUMULATED_STATS)
   {
-    // measure or accum stats
+    // accum stats
     ex_assert(getGlobals()->getStatsArea()->numEntries() == 1,
-	      "Must have one and only one entry for measure/accum stats case");
+	      "Must have one and only one entry for accum stats case");
     getGlobals()->getStatsArea()->position();
     setStatsEntry(getGlobals()->getStatsArea()->getNext());
     return NULL;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_sort.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_sort.h b/core/sql/executor/ex_sort.h
index aa09b8f..8352672 100644
--- a/core/sql/executor/ex_sort.h
+++ b/core/sql/executor/ex_sort.h
@@ -73,16 +73,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExSortTdb()
+  ExSortTdb()
   {}
 
-  NA_EIDPROC virtual ~ExSortTdb()
+  virtual ~ExSortTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -304,7 +304,7 @@ public:
   virtual ExOperStats *doAllocateStatsEntry(CollHeap *heap,
 					    ComTdb *tdb);
 
-  NA_EIDPROC virtual ex_tcb_private_state * allocatePstates(
+  virtual ex_tcb_private_state * allocatePstates(
        Lng32 &numElems,      // inout, desired/actual elements
        Lng32 &pstateLength); // out, length of one element
 };
@@ -348,7 +348,7 @@ public:
 
   virtual void registerSubtasks();  // register work procedures with scheduler
 
-  NA_EIDPROC virtual ex_tcb_private_state * allocatePstates(
+  virtual ex_tcb_private_state * allocatePstates(
        Lng32 &numElems,      // inout, desired/actual elements
        Lng32 &pstateLength); // out, length of one element
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_sort_grby.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_sort_grby.h b/core/sql/executor/ex_sort_grby.h
index 63fa075..879d1af 100644
--- a/core/sql/executor/ex_sort_grby.h
+++ b/core/sql/executor/ex_sort_grby.h
@@ -72,16 +72,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_sort_grby_tdb()
+  ex_sort_grby_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_sort_grby_tdb()
+  virtual ~ex_sort_grby_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -135,13 +135,11 @@ protected:
 
 public:
   // Constructor
-NA_EIDPROC
   ex_sort_grby_tcb(const ex_sort_grby_tdb & sort_grby_tdb,    
 		   const ex_tcb &    child_tcb , // child queue pair
 		   ex_globals * glob
 		   );
   
-NA_EIDPROC
   ~ex_sort_grby_tcb();  
   
   enum sort_grby_step {
@@ -175,7 +173,6 @@ NA_EIDPROC
 
   // return a pair of queue pointers to the parent node. Needed only during
   // construction of nodes.
-  NA_EIDPROC
   ex_queue_pair getParentQueue() const
   {
     return (qparent_);
@@ -272,8 +269,8 @@ class ex_sort_grby_private_state : public ex_tcb_private_state
   
 public:
 
-  NA_EIDPROC ex_sort_grby_private_state();
-  NA_EIDPROC ~ex_sort_grby_private_state();
+  ex_sort_grby_private_state();
+  ~ex_sort_grby_private_state();
 
 private:
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_split_bottom.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_split_bottom.cpp b/core/sql/executor/ex_split_bottom.cpp
index 6dd35aa..c1a2360 100644
--- a/core/sql/executor/ex_split_bottom.cpp
+++ b/core/sql/executor/ex_split_bottom.cpp
@@ -461,11 +461,10 @@ ExOperStats * ex_split_bottom_tcb::doAllocateStatsEntry(CollHeap *heap,
       if (ss != NULL)
         ((ExFragRootOperStats *)stat)->setQueryId(ss->getQueryId(), ss->getQueryIdLen());
     }
-    else if ((statsType == ComTdb::MEASURE_STATS) ||
-	   (statsType == ComTdb::ACCUMULATED_STATS))
+  else if (statsType == ComTdb::ACCUMULATED_STATS)
     {
-      // if measure or accumulated statistics are to be collected, allocate
-      // one measure stats entry and insert it into the queue.
+      // if accumulated statistics are to be collected, allocate
+      // one stats entry and insert it into the queue.
       // All executor operators that collect stats will use this
       // entry to update stats.
       // These stats are not associated with any particular

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_split_bottom.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_split_bottom.h b/core/sql/executor/ex_split_bottom.h
index 717777c..417dab8 100644
--- a/core/sql/executor/ex_split_bottom.h
+++ b/core/sql/executor/ex_split_bottom.h
@@ -85,16 +85,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_split_bottom_tdb()
+  ex_split_bottom_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_split_bottom_tdb()
+  virtual ~ex_split_bottom_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
   ex_split_bottom_tcb *buildESPTcbTree(ExExeStmtGlobals * glob,
                                        ExEspFragInstanceDir *espInstanceDir,
@@ -201,7 +201,7 @@ public:
   void setLocalSendBottom(CollIndex s);
 
   // Enforce query CPU limit.
-  NA_EIDPROC virtual void cpuLimitExceeded();
+  virtual void cpuLimitExceeded();
 
 private:
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_split_top.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_split_top.h b/core/sql/executor/ex_split_top.h
index 1c4bb6a..26a98cc 100644
--- a/core/sql/executor/ex_split_top.h
+++ b/core/sql/executor/ex_split_top.h
@@ -84,16 +84,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_split_top_tdb()
+  ex_split_top_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_split_top_tdb()
+  virtual ~ex_split_top_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -245,7 +245,7 @@ public:
   virtual Int32 numChildren() const;
   virtual const ex_tcb* getChild(Int32 pos) const;
 
-  virtual NA_EIDPROC ExOperStats *doAllocateStatsEntry(CollHeap *heap,
+  virtual ExOperStats *doAllocateStatsEntry(CollHeap *heap,
                                                        ComTdb *tdb);
 
 private:

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_stored_proc.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_stored_proc.h b/core/sql/executor/ex_stored_proc.h
index a4db173..22f032f 100644
--- a/core/sql/executor/ex_stored_proc.h
+++ b/core/sql/executor/ex_stored_proc.h
@@ -66,16 +66,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExStoredProcTdb()
+  ExStoredProcTdb()
   {}
 
-  NA_EIDPROC virtual ~ExStoredProcTdb()
+  virtual ~ExStoredProcTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_tcb.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_tcb.h b/core/sql/executor/ex_tcb.h
index 3f744a9..c3ae5ba 100644
--- a/core/sql/executor/ex_tcb.h
+++ b/core/sql/executor/ex_tcb.h
@@ -62,33 +62,33 @@ class ex_tcb : public ExGod
 {
 public:
 
-  NA_EIDPROC ex_tcb(const ComTdb & tdb,
+  ex_tcb(const ComTdb & tdb,
                     const short in_version,
                     ex_globals * g);    // constructor
   
-  NA_EIDPROC virtual ~ex_tcb(); // destroy
+  virtual ~ex_tcb(); // destroy
   
-  NA_EIDPROC virtual void freeResources() = 0;  // free resources
+  virtual void freeResources() = 0;  // free resources
 
   // register subtasks with scheduler
-  NA_EIDPROC virtual void registerSubtasks();
+  virtual void registerSubtasks();
 
-  NA_EIDPROC virtual ex_queue_pair getParentQueue() const = 0;
+  virtual ex_queue_pair getParentQueue() const = 0;
   
-  NA_EIDPROC inline short getVersion() const { return version_; }
+  inline short getVersion() const { return version_; }
 
   // access child TCBs via virtual methods
-  NA_EIDPROC virtual const ex_tcb* getChild(Int32 pos) const = 0;
-  NA_EIDPROC virtual Int32 numChildren() const = 0;
+  virtual const ex_tcb* getChild(Int32 pos) const = 0;
+  virtual Int32 numChildren() const = 0;
 
-  NA_EIDPROC virtual Int32 fixup();
+  virtual Int32 fixup();
 
   // return of TRUE means error, FALSE means all Ok.
-  NA_EIDPROC virtual NABoolean reOpenTables();
-  NA_EIDPROC virtual NABoolean closeTables();
+  virtual NABoolean reOpenTables();
+  virtual NABoolean closeTables();
 
   // this method is called to rollback to a previously set savepoint.
-  NA_EIDPROC virtual Int32 rollbackSavepoint();
+  virtual Int32 rollbackSavepoint();
 
   // Three officially supported work methods: work, cancel, and resize.
   // The default implementations make use of these work methods. Individual
@@ -96,45 +96,45 @@ public:
   // to redefine some more virtual functions, such as registerSubtasks.
   // The work() method is a pure virtual method, the other two have
   // default implementations that may be sufficient for most TCBs.
-  NA_EIDPROC virtual ExWorkProcRetcode work() = 0;
+  virtual ExWorkProcRetcode work() = 0;
   // default static work proc for scheduler
 // warning elimination (removed "inline")
-  NA_EIDPROC static ExWorkProcRetcode sWork(ex_tcb *tcb)
+  static ExWorkProcRetcode sWork(ex_tcb *tcb)
                                                    { return tcb->work(); }
-  NA_EIDPROC virtual ExWorkProcRetcode workCancel();
+  virtual ExWorkProcRetcode workCancel();
   // default static work proc for scheduler
 
-  NA_EIDPROC static ExWorkProcRetcode sCancel(ex_tcb *tcb)
+  static ExWorkProcRetcode sCancel(ex_tcb *tcb)
                                              { return tcb->workCancel(); }
   // methods to resize the parent up/down queues
-  NA_EIDPROC virtual ExWorkProcRetcode workResize();
+  virtual ExWorkProcRetcode workResize();
   // the static version
-  NA_EIDPROC static  ExWorkProcRetcode sResize(ex_tcb *tcb)
+  static  ExWorkProcRetcode sResize(ex_tcb *tcb)
                                              { return tcb->workResize(); }
   
-  NA_EIDPROC virtual void display() const {};
+  virtual void display() const {};
   
-  NA_EIDPROC inline const ComTdb * getTdb() const         { return &tdb; }
-  NA_EIDPROC inline ex_globals * getGlobals() const { return globals_; }
+  inline const ComTdb * getTdb() const         { return &tdb; }
+  inline ex_globals * getGlobals() const { return globals_; }
 
-  NA_EIDPROC unsigned short getExpressionMode() const;
-  NA_EIDPROC inline Space * getSpace() {return globals_->getSpace();}
-  NA_EIDPROC inline CollHeap * getHeap() {return globals_->getDefaultHeap();}
+  unsigned short getExpressionMode() const;
+  inline Space * getSpace() {return globals_->getSpace();}
+  inline CollHeap * getHeap() {return globals_->getDefaultHeap();}
 
   // helper methods to allocate parent queues and register queue resize tasks
-  NA_EIDPROC void allocateParentQueues(ex_queue_pair &parentQueues,
+  void allocateParentQueues(ex_queue_pair &parentQueues,
 				       NABoolean allocatePstate = TRUE);
-  NA_EIDPROC void registerResizeSubtasks();
+  void registerResizeSubtasks();
   
-  NA_EIDPROC virtual ex_tcb_private_state * allocatePstates(
+  virtual ex_tcb_private_state * allocatePstates(
        Lng32 &numElems,      // inout, desired/actual elements
        Lng32 &pstateLength); // out, length of one element
 
-  NA_EIDPROC void setStatsEntry(ExOperStats * statsEntry) {
+  void setStatsEntry(ExOperStats * statsEntry) {
     statsEntry_ = statsEntry; }
 
   // return stats entry, if stats are enabled.
-  NA_EIDPROC ExOperStats * getStatsEntry()
+  ExOperStats * getStatsEntry()
   { 
     return (getGlobals()->statsEnabled() ? statsEntry_ : NULL); 
   }
@@ -142,26 +142,26 @@ public:
   // this method find the first set of children in the child tree
   // that have a valid stats area and sets their parent id to the
   // input tdb id.
-  NA_EIDPROC void propagateTdbIdForStats(Lng32 tdbId);
+  void propagateTdbIdForStats(Lng32 tdbId);
 
-  NA_EIDPROC void allocateStatsEntry(CollHeap * heap = NULL);
+  void allocateStatsEntry(CollHeap * heap = NULL);
 
-  NA_EIDPROC virtual ExOperStats * doAllocateStatsEntry(CollHeap *heap,
+  virtual ExOperStats * doAllocateStatsEntry(CollHeap *heap,
                                                         ComTdb *tdb);
 
-  NA_EIDPROC sql_buffer_pool * getPool() { return pool_; }
+  sql_buffer_pool * getPool() { return pool_; }
 
-  NA_EIDPROC virtual NABoolean resizePoolInfo() { return FALSE; }
+  virtual NABoolean resizePoolInfo() { return FALSE; }
 
-  NA_EIDPROC virtual void computeNeededPoolInfo(
+  virtual void computeNeededPoolInfo(
        Int32 &numBuffs, 
        UInt32 &bufferSize, 
        UInt32 &poolSize);
 
-  NA_EIDPROC Lng32 getTotalPoolSize()
+  Lng32 getTotalPoolSize()
   { return pool_->getTotalMemorySize();};
 
-  NA_EIDPROC virtual void cleanup();
+  virtual void cleanup();
   // ****  information for GUI  *** -------------
 
   Int32 objectId;
@@ -175,22 +175,20 @@ public:
   Int32 getObjectId() const { return objectId; }
 #endif
 
-  NA_EIDPROC ComTdb::ex_node_type getNodeType() const { return nodeType_; }
+  ComTdb::ex_node_type getNodeType() const { return nodeType_; }
 
   // QSTUFF
-  NA_EIDPROC NABoolean isHoldable() const { return holdable_; }
+  NABoolean isHoldable() const { return holdable_; }
   // setHoldable is redefined by the partition access tcb
-  NA_EIDPROC virtual void      setHoldable(NABoolean h) { holdable_ = h;}
-  NA_EIDPROC void      propagateHoldable(NABoolean h);
+  virtual void      setHoldable(NABoolean h) { holdable_ = h;}
+  void      propagateHoldable(NABoolean h);
   // QSTUFF
   
-  NA_EIDPROC virtual NABoolean needStatsEntry();
-#ifndef __EID
-  NA_EIDPROC void mergeStats(ExStatisticsArea *otherStats);
-#endif
+  virtual NABoolean needStatsEntry();
+  void mergeStats(ExStatisticsArea *otherStats);
 
-  NA_EIDPROC virtual void cpuLimitExceeded();
-  NA_EIDPROC inline char * getEyeCatcher()
+  virtual void cpuLimitExceeded();
+  inline char * getEyeCatcher()
                       { return eyeCatcher_.name_for_sun_compiler; }
 
   virtual short moveRowToUpQueue(
@@ -241,7 +239,7 @@ template <class T> class PstateAllocator
 public:
   
 #pragma nowarn(1103)   // warning elimination 
-  NA_EIDPROC ex_tcb_private_state *allocatePstates(
+  ex_tcb_private_state *allocatePstates(
 #pragma warn(1103)  // warning elimination 
        ex_tcb *tcb, 
        Lng32   &numElems,      // inout, desired/actual elements
@@ -257,7 +255,6 @@ public:
     // __vec_new() in the executor, because it is part of the C++
     // Runtime library.
 
-//SQ_LINUX #if defined(NA_HSC)
 //  Arguments do not match with any function 'new []'.
     result = new(tcb->getSpace()/*,FALSE*/) T[numElems];
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_tcb_private.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_tcb_private.h b/core/sql/executor/ex_tcb_private.h
index 6e1861f..6ab98ae 100644
--- a/core/sql/executor/ex_tcb_private.h
+++ b/core/sql/executor/ex_tcb_private.h
@@ -65,16 +65,11 @@ class ex_tcb_private_state : public ExGod
   Lng32 errorCode_;
 
 public:
-NA_EIDPROC
   ex_tcb_private_state();
-NA_EIDPROC
   virtual ex_tcb_private_state * allocate_new(const ex_tcb * tcb);
-NA_EIDPROC
   virtual ~ex_tcb_private_state();
 
-NA_EIDPROC
   inline Lng32 getErrorCode(){return errorCode_;}
-NA_EIDPROC
   inline void setErrorCode(Lng32 error_code){errorCode_ = error_code;}
 
 };

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_timeout.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_timeout.h b/core/sql/executor/ex_timeout.h
index 5bb6c7f..8c5d95c 100644
--- a/core/sql/executor/ex_timeout.h
+++ b/core/sql/executor/ex_timeout.h
@@ -72,14 +72,14 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExTimeoutTdb() {}
+  ExTimeoutTdb() {}
 
-  NA_EIDPROC virtual ~ExTimeoutTdb() {}
+  virtual ~ExTimeoutTdb() {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_transaction.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_transaction.cpp b/core/sql/executor/ex_transaction.cpp
index 5b27ad6..437170b 100644
--- a/core/sql/executor/ex_transaction.cpp
+++ b/core/sql/executor/ex_transaction.cpp
@@ -54,16 +54,8 @@
 #include  "ex_error.h"
 #include  "ExSqlComp.h"
 
-#ifdef NA_CMPDLL
 #include  "CmpContext.h"
-#endif // NA_CMPDLL
-
-
-
 #include "ExCextdecs.h"
-
-
-
 #include "dtm/tm.h"
 
 ExTransaction::ExTransaction(CliGlobals * cliGlob, CollHeap *heap)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_transaction.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_transaction.h b/core/sql/executor/ex_transaction.h
index 702ce91..8c5ed61 100644
--- a/core/sql/executor/ex_transaction.h
+++ b/core/sql/executor/ex_transaction.h
@@ -335,16 +335,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExTransTdb()
+  ExTransTdb()
   {}
 
-  NA_EIDPROC virtual ~ExTransTdb()
+  virtual ~ExTransTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_tuple.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_tuple.cpp b/core/sql/executor/ex_tuple.cpp
index 55ea114..3f8b9b2 100644
--- a/core/sql/executor/ex_tuple.cpp
+++ b/core/sql/executor/ex_tuple.cpp
@@ -171,7 +171,7 @@ ExWorkProcRetcode ExTupleLeafTcb::work()
   if (qparent.down->isEmpty())
     return WORK_OK;
 
-#ifdef NA_DEBUG_C_RUNTIME
+#ifdef _DEBUG
   //
   // This block of code is for UDR testing only. It lets us create a 
   // situation where a non-UDR node in the dataflow tree returns
@@ -181,7 +181,7 @@ ExWorkProcRetcode ExTupleLeafTcb::work()
   {
     return WORK_BAD_ERROR;
   }
-#endif // NA_DEBUG_C_RUNTIME
+#endif // _DEBUG
 
   ex_queue_entry * pentry_down = qparent.down->getHeadEntry();
   ExTuplePrivateState *  pstate 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_tuple.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_tuple.h b/core/sql/executor/ex_tuple.h
index 08822f6..3a64db6 100644
--- a/core/sql/executor/ex_tuple.h
+++ b/core/sql/executor/ex_tuple.h
@@ -65,16 +65,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExTupleLeafTdb()
+  ExTupleLeafTdb()
   {}
 
-  NA_EIDPROC virtual ~ExTupleLeafTdb()
+  virtual ~ExTupleLeafTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -117,16 +117,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExTupleNonLeafTdb()
+  ExTupleNonLeafTdb()
   {}
 
-  NA_EIDPROC virtual ~ExTupleNonLeafTdb()
+  virtual ~ExTupleNonLeafTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -178,38 +178,32 @@ public:
     HANDLE_SQLERROR
   };
 
-NA_EIDPROC  
+ 
   ExTupleTcb(const ComTdbTuple & tupleTdb,
 	     ex_globals * glob);
  
-NA_EIDPROC
   ~ExTupleTcb();
 
-NA_EIDPROC
   virtual short work();
 
-NA_EIDPROC
   void freeResources();
 
-NA_EIDPROC
   ex_queue_pair getParentQueue() const
   { 
     return (qparent);
   }
 
-NA_EIDPROC
   virtual ex_tcb_private_state * allocatePstates(
        Lng32 &numElems,      // inout, desired/actual elements
        Lng32 &pstateLength); // out, length of one element
 
-NA_EIDPROC
   Int32 orderedQueueProtocol() const
   { 
     return ((const ComTdbTuple &)tdb).orderedQueueProtocol();
   };
   
-  NA_EIDPROC virtual Int32 numChildren() const { return 0;};
-  NA_EIDPROC virtual const ex_tcb* getChild(Int32 pos) const { return NULL;}; //LCOV_EXCL_LINE
+  virtual Int32 numChildren() const { return 0;};
+  virtual const ex_tcb* getChild(Int32 pos) const { return NULL;}; //LCOV_EXCL_LINE
 
 protected:
   ex_queue_pair qparent;
@@ -219,13 +213,11 @@ protected:
   // Atp and buffers to build expressions
   atp_struct * workAtp_;
 
-NA_EIDPROC
   ComTdbTuple & tupleTdb() const
   { 
     return (ComTdbTuple &) tdb;
   };
 
-NA_EIDPROC
   Queue * tupleExprList() const { return tupleTdb().tupleExprList_; };
 };
 
@@ -235,11 +227,9 @@ NA_EIDPROC
 class ExTupleLeafTcb : public ExTupleTcb
 {
 public:
-NA_EIDPROC
   ExTupleLeafTcb(const ExTupleLeafTdb & tupleTdb,
 		 ex_globals * glob = 0);
 
-NA_EIDPROC
   ExWorkProcRetcode work();  
 };
 
@@ -252,16 +242,14 @@ NA_EIDPROC
 class ExTupleNonLeafTcb : public ExTupleTcb
 {
 public:
-NA_EIDPROC
   ExTupleNonLeafTcb(const ExTupleNonLeafTdb & tupleTdb,
 		    const ex_tcb & tcbChild,
 		    ex_globals * glob = 0);
 
-NA_EIDPROC
   ExWorkProcRetcode work();  
 
-  NA_EIDPROC virtual Int32 numChildren() const { return 1;};
-  NA_EIDPROC virtual const ex_tcb* getChild(Int32 pos) const
+  virtual Int32 numChildren() const { return 1;};
+  virtual const ex_tcb* getChild(Int32 pos) const
   {
     ex_assert((pos >= 0), ""); 
     if (pos == 0)
@@ -289,9 +277,7 @@ class ExTuplePrivateState : public ex_tcb_private_state
 
   ExTupleTcb::TupleStep step_;	// step in processing this parent row
 public:	
-NA_EIDPROC
   ExTuplePrivateState(); //constructor
-NA_EIDPROC
   ~ExTuplePrivateState();	// destructor
 };
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_tuple_flow.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_tuple_flow.cpp b/core/sql/executor/ex_tuple_flow.cpp
index 4ef87de..a568a5c 100644
--- a/core/sql/executor/ex_tuple_flow.cpp
+++ b/core/sql/executor/ex_tuple_flow.cpp
@@ -45,10 +45,7 @@
 #include "str.h"
 #include "ExStats.h"
 #include "ExpError.h"
-#ifndef __EID
 #include "cli_stdh.h"
-#endif
-
 
 /////////////////////////////////////////////////////////////////////////
 //

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_tuple_flow.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_tuple_flow.h b/core/sql/executor/ex_tuple_flow.h
index b84584d..a4b1674 100644
--- a/core/sql/executor/ex_tuple_flow.h
+++ b/core/sql/executor/ex_tuple_flow.h
@@ -63,16 +63,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ExTupleFlowTdb()
+  ExTupleFlowTdb()
   {}
 
-  NA_EIDPROC virtual ~ExTupleFlowTdb()
+  virtual ~ExTupleFlowTdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/ex_union.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/ex_union.h b/core/sql/executor/ex_union.h
index 9460157..279ff07 100644
--- a/core/sql/executor/ex_union.h
+++ b/core/sql/executor/ex_union.h
@@ -72,16 +72,16 @@ public:
   // retrieval of the virtual table function pointer of the class while
   // unpacking. An empty constructor is enough.
   // ---------------------------------------------------------------------
-  NA_EIDPROC ex_union_tdb()
+  ex_union_tdb()
   {}
 
-  NA_EIDPROC virtual ~ex_union_tdb()
+  virtual ~ex_union_tdb()
   {}
 
   // ---------------------------------------------------------------------
   // Build a TCB for this TDB. Redefined in the Executor project.
   // ---------------------------------------------------------------------
-  NA_EIDPROC virtual ex_tcb *build(ex_globals *globals);
+  virtual ex_tcb *build(ex_globals *globals);
 
 private:
   // ---------------------------------------------------------------------
@@ -133,35 +133,27 @@ public:
   };
 
   // Constructor
-NA_EIDPROC
   ex_union_tcb(const ex_union_tdb &  union_tdb,    // 
 	       const ex_tcb *    left_tcb,    // left queue pair
 	       const ex_tcb *    right_tcb,   // right queue pair
 	       ex_globals *glob
 	       );
         
-NA_EIDPROC
   ~ex_union_tcb();  
 
-NA_EIDPROC
   void        freeResources();  // free resources
-NA_EIDPROC
   virtual void  registerSubtasks();
 
-NA_EIDPROC
   ExWorkProcRetcode work();            // not used for this TCB
-NA_EIDPROC
   ExWorkProcRetcode workDown();        // pass requests down to child
-NA_EIDPROC
   ExWorkProcRetcode workUp();          // pass results up to parent
 
-NA_EIDPROC 
+
   static  ExWorkProcRetcode sWorkUp(ex_tcb *tcb)
                            { return ((ex_union_tcb *) tcb)->workUp(); }
-NA_EIDPROC
   static ExWorkProcRetcode sWorkDown(ex_tcb *tcb)
                          { return ((ex_union_tcb *) tcb)->workDown(); }
-NA_EIDPROC 
+
   static ExWorkProcRetcode sCancel(ex_tcb *tcb)
                     { return ((ex_union_tcb *) tcb)->processCancel(); }
   
@@ -191,22 +183,16 @@ virtual const ex_tcb* getChild(Int32 pos) const
       return NULL;
 }
 
-NA_EIDPROC
   inline ex_expr * moveExpr(Int32 i)
   { return (i == 0 ? union_tdb().leftExpr_ : union_tdb().rightExpr_); }
 
-NA_EIDPROC
   inline ex_expr * mergeExpr() const { return union_tdb().mergeExpr_; }
 
-NA_EIDPROC
   inline ex_expr * condExpr() const { return union_tdb().condExpr_; }
 
-NA_EIDPROC
   inline ex_expr * trigExceptExpr() const { return union_tdb().trigExceptExpr_;}
 
-NA_EIDPROC
   virtual Int32 numChildren() const { return union_tdb().numChildren(); }
-//NA_EIDPROC
 //  virtual const ex_tcb* getChild(int pos) const;
   virtual Int32 hasNoOutputs() const {return FALSE;};
 protected:
@@ -219,13 +205,9 @@ protected:
 
   queue_index   processedInputs_;    // next parent down queue entry to process
 
-NA_EIDPROC
   virtual void start();		     // send next request down to children
-NA_EIDPROC
   virtual void stop();		     // send EOD to parent
-NA_EIDPROC
   virtual ExWorkProcRetcode processCancel(); // check for cancelled request
-NA_EIDPROC
   virtual void processError(ex_union_private_state &pstate, Int32 &endOfData,
                             atp_struct* atp);
 
@@ -235,7 +217,6 @@ NA_EIDPROC
   // no the method returns whether the current request is at end of
   // data (EOD entries in both child queues) or not. The procedure
   // also needs to set pstate.childStates_[i] to DONE_, if appropriate.
-NA_EIDPROC
   virtual Int32 whichSide(ex_union_private_state &  pstate,
 			Int32 &side,
 			Int32 &endOfData);
@@ -249,14 +230,12 @@ class ex_m_union_tcb : public ex_union_tcb
 {
 public:
   // Constructor
-NA_EIDPROC
   ex_m_union_tcb(const ex_union_tdb &  union_tdb,    // 
 		 const ex_tcb *    left_tcb,    // left queue pair
 		 const ex_tcb *    right_tcb,   // right queue pair
 		 ex_globals *glob
 		 );
         
-NA_EIDPROC
   virtual Int32 whichSide(ex_union_private_state &  pstate,
 			Int32 &side,
 			Int32 &endOfData);
@@ -270,7 +249,6 @@ class ex_o_union_tcb : public ex_union_tcb
 {
 public:
   // Constructor
-NA_EIDPROC
   ex_o_union_tcb(const ex_union_tdb &  union_tdb,    // 
 		 const ex_tcb *    left_tcb,    // left queue pair
 		 const ex_tcb *    right_tcb,   // right queue pair
@@ -279,52 +257,40 @@ NA_EIDPROC
 		 Int32 hasNoOutputs
 		 );
         
-NA_EIDPROC
   virtual Int32 whichSide(ex_union_private_state &  pstate,
 			Int32 &side,
 			Int32 &endOfData);
   
-NA_EIDPROC
   ExWorkProcRetcode workDownLeft();        // pass requests down to child
 
   ExWorkProcRetcode workDownBlockedLeft();        // pass requests down to child
   
-NA_EIDPROC
   ExWorkProcRetcode workDownRight();        // pass requests down to child
 
-NA_EIDPROC
   virtual ExWorkProcRetcode processCancel();     // Cancel request 
 
-NA_EIDPROC
   static ExWorkProcRetcode sWorkPhase1(ex_tcb *tcb)
                          { return ((ex_o_union_tcb *) tcb)->workDownLeft(); }
 
-NA_EIDPROC
   static ExWorkProcRetcode sWorkBlockedPhase1(ex_tcb *tcb)
                          { return ((ex_o_union_tcb *) tcb)->workDownBlockedLeft(); }
 
-NA_EIDPROC
   static ExWorkProcRetcode sWorkPhase2(ex_tcb *tcb)
                          { return ((ex_o_union_tcb *) tcb)->workDownRight(); }
 
-NA_EIDPROC
   static ExWorkProcRetcode sCancel(ex_tcb *tcb)
                          { return ((ex_o_union_tcb *) tcb)->processCancel(); }
 
-NA_EIDPROC
   virtual void  registerSubtasks();
 
   virtual Int32 hasNoOutputs() const {return hasNoOutputs_;};
 
 private:
-NA_EIDPROC
   void startLeftchild();
-NA_EIDPROC
   void startRightchild();
 
   // Helper to determine which child's (left or right) parent is farther 
   // from the parent down ex_queue's head_.
-NA_EIDPROC
   queue_index whichSideParentIndex();
 
   short rightRequestCnt_;  // a counter for pipelining requests to right child
@@ -360,42 +326,32 @@ NA_EIDPROC
 class ex_c_union_tcb : public ex_union_tcb
 {
 public:
-NA_EIDPROC
   ex_c_union_tcb(const ex_union_tdb &union_tdb,    
 		 const ex_tcb *left_tcb, 
 		 const ex_tcb *right_tcb,
 		 ex_globals *glob);
         
-NA_EIDPROC
   virtual void registerSubtasks();
 
-NA_EIDPROC
   ExWorkProcRetcode condWorkDown();
 
-NA_EIDPROC
   static ExWorkProcRetcode sCondWorkDown(ex_tcb *tcb)
                          { return ((ex_c_union_tcb *) tcb)->condWorkDown(); }
 
 //issue a EXE_CS_EOD or a EXE_CS_EOD_ROLLBACK_ERROR type error/warning for
 //conditional union
-NA_EIDPROC
   void processEODErrorOrWarning(NABoolean isWarning) ;
 
 protected:
 
-NA_EIDPROC
   virtual void start();		  
-NA_EIDPROC
   virtual void stop();		
 
-NA_EIDPROC
   virtual Int32 whichSide(ex_union_private_state &pstate,
 			Int32 &side,
 			Int32 &endOfData);
 
-NA_EIDPROC
   virtual ExWorkProcRetcode processCancel(); 
-NA_EIDPROC
   virtual void processError(ex_union_private_state &pstate, Int32 &endOfData,
                             atp_struct* atp);
 
@@ -427,19 +383,14 @@ class ex_union_private_state : public ex_tcb_private_state
   Int32 whichChild_; // which side of conditional union to execute.
 
 
-NA_EIDPROC
   void           init();        // initialize state
 
 public:
 
-NA_EIDPROC
   ex_union_private_state(const ex_union_tcb * tcb); //constructor
-NA_EIDPROC
   ex_tcb_private_state * allocate_new(const ex_tcb * tcb);
-NA_EIDPROC
   ~ex_union_private_state();  // destructor
 
-NA_EIDPROC
   Int32 validChild() const {return whichChild_ >= 0 && whichChild_ <=1; }
 
 };

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/hash_table.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/hash_table.cpp b/core/sql/executor/hash_table.cpp
index 884355e..d2baf63 100644
--- a/core/sql/executor/hash_table.cpp
+++ b/core/sql/executor/hash_table.cpp
@@ -34,7 +34,6 @@
 #include "hash_table.h"
 
 void HashRow::print(ULng32 rowlength) {
-#ifndef __EID
   printf("\tHashValue: %6d\n\tData: ", hashValue_);
   unsigned char * data = (unsigned char *)this;
   ULng32 i = 0;
@@ -50,7 +49,6 @@ void HashRow::print(ULng32 rowlength) {
     else
       printf ("%1d0", i/10);
   printf ("\n");
-#endif
 }
 
 HashTableCursor::HashTableCursor() {
@@ -87,10 +85,8 @@ HashTable::HashTable(ULng32 headerCount,
     singleChainLastRow_(NULL) {
 
 #ifdef _DEBUG
-#ifndef __EID
   if ( getenv("ALLOW_HV_DUPS" ) ) noHashValueDups_ = FALSE; // for testing
 #endif
-#endif
   
   headerCount_ *= 2; // the first iteration below would divide it back
 
@@ -292,9 +288,6 @@ ULng32 HashTable::resize(NABoolean enoughMemory) {
   return memAdded ;
 }
 
-#ifndef __EID
-// this is only used by Hash Join, so does not need to be in EID code
-
 // HashTable::insertUniq()
 // An insert method used by UniqueHashJoin.
 // Assumes input is unique and so does not need to check for
@@ -340,7 +333,6 @@ void HashTable::insertUniq(HashRow *newRow)
   return;
   
 }
-#endif
 
 ///////////////////////////////////////////////////////////////////
 // Add a row to the end of the first hash header.  The purpose
@@ -539,9 +531,6 @@ void HashTable::position(HashTableCursor * cursor,
   cursor->init();
 }
 
-#ifndef __EID
-// this is only used by Hash Join, so does not need to be in EID code
-
 // HashTable::positionUniq()
 // A position method used by UniqueHashJoin.
 // Assumes entries are unique and so does not need to check for
@@ -600,7 +589,6 @@ ex_expr::exp_return_type HashTable::positionUniq(HashRow **currRow,
   // Not found
   return ex_expr::EXPR_FALSE;
 }
-#endif
 
 /////////////////////////////////////////////////////////
 // positions to the first entry in the hash table.

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/hash_table.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/hash_table.h b/core/sql/executor/hash_table.h
index 5819168..371d32e 100644
--- a/core/sql/executor/hash_table.h
+++ b/core/sql/executor/hash_table.h
@@ -70,18 +70,14 @@ class HashTableCursor : public NABasicObject {
   ULng32 currHeader_;
 
 public:
-NA_EIDPROC
   HashTableCursor();
-NA_EIDPROC
   ~HashTableCursor();
-NA_EIDPROC
   void init() {
     beginRow_ =
       endRow_ =
       currRow_ = NULL;
     currHeader_ = 0;
   };
-NA_EIDPROC
   inline HashRow * getBeginRow() {return beginRow_;};
 };
 
@@ -91,11 +87,8 @@ NA_EIDPROC
 class HashTableHeader {
   friend class HashTable;
 public:
-NA_EIDPROC
   HashTableHeader();
-NA_EIDPROC
   inline ~HashTableHeader() {};
-NA_EIDPROC
   void init();
 private:
   // for now we disable the rowCount_. This cuts the size of the hash table
@@ -139,20 +132,16 @@ public:
   //   doResize: If TRUE (HGB) then this table is resizable - when the table
   //             becomes %75 full, then allocate a new one of twice the
   //             previous size, move the entries and deallocate the old one.
-NA_EIDPROC
   HashTable(ULng32 headerCount,
 	    NABoolean evenFactor,
 	    ULng32 primeFactor,
 	    NABoolean noHVDups = TRUE,
 	    NABoolean doResize = FALSE
 	    ); 
-NA_EIDPROC
   ~HashTable();
 
-NA_EIDPROC
   void init();
 
-NA_EIDPROC
   void insert(atp_struct * workAtp,
 	      HashRow * newRow,
               tupp& workAtpTupp1,
@@ -160,38 +149,26 @@ NA_EIDPROC
 	      ex_expr * searchExpr);
 
   // Used only by Hash-Groupby; return TRUE is HT need be resized
-NA_EIDPROC
   NABoolean insert(HashRow * newRow);
 
   // Used only by Hash-Groupby; resize the HT (only if enough memory)
-NA_EIDPROC
   ULng32 resize(NABoolean enoughMemory);
 
-#ifndef __EID
-  // this is only used by Hash Join, so does not need to be in EID code
-
   // An insert method used by UniqueHashJoin.
   // Assumes input is unique and so does not need to check for
   // duplicates.
   // Entries are inserted in HashValue order.
   //
-  NA_EIDPROC
   void insertUniq(HashRow *newRow);
-#endif
 
-NA_EIDPROC
   void insertSingleChain(HashRow * newRow);
 
-NA_EIDPROC
   void convertToOffsets();
 
-NA_EIDPROC
   HashRow * getNext(HashTableCursor * cursor);
 
-NA_EIDPROC
   void position(HashTableCursor * cursor);
 
-NA_EIDPROC
   void position(HashTableCursor * cursor,
 		atp_struct * rowAtp,
 		atp_struct * workAtp,
@@ -202,43 +179,32 @@ NA_EIDPROC
                                                   // (anti)semi-joins.
 		NABoolean returnOrdered = FALSE );
 
-#ifndef __EID
-  // this is only used by Hash Join, so does not need to be in EID code
-
   // A position method used by UniqueHashJoin.
   // Assumes entries are unique and so does not need to check for
   // duplicates.
   // Returns first match found.
   //
-  NA_EIDPROC
   ex_expr::exp_return_type positionUniq(HashRow **currRow,
                                         atp_struct * leftRowAtp,
                                         atp_struct * workAtp,
                                         short rightRowAtpIndex,
                                         ex_expr * searchExpr,
                                         SimpleHashValue hashValue);
-#endif
 
-NA_EIDPROC
   void positionSingleChain(HashTableCursor * cursor);
 
-NA_EIDPROC
   inline ULng32 getHeaderCount() const {
   return headerCount_;
 };
 
-NA_EIDPROC
   ULng32 getChainSize(ULng32 i);
 
   // In case the object was created, but not enough memory for the actual HT
-NA_EIDPROC
   inline NABoolean noTableAllocated() { return header_ == NULL ; };
 
   // Return the size the HT would be resized-to (used to check mem availability)
-NA_EIDPROC
   ULng32 resizeTo() { return headerCount_ * HT_RESIZE_FACTOR ; };
 
-NA_EIDPROC
   inline NABoolean originalSize() { return originalSize_ ; };
 
 private:

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/key_range.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/key_range.h b/core/sql/executor/key_range.h
index f7d0f5e..e493d58 100644
--- a/core/sql/executor/key_range.h
+++ b/core/sql/executor/key_range.h
@@ -95,21 +95,21 @@ protected:
 
 public:
 
-  NA_EIDPROC keyRangeEx(const keyRangeGen & tdb_key,
+  keyRangeEx(const keyRangeGen & tdb_key,
 		   ex_globals * globals,
 		   const short in_version,
 		   sql_buffer_pool *pool);
 
-  NA_EIDPROC virtual ~keyRangeEx();
+  virtual ~keyRangeEx();
 
-  NA_EIDPROC virtual void freeResources();	// free resources
+  virtual void freeResources();	// free resources
 
-  NA_EIDPROC virtual void release(); // release
+  virtual void release(); // release
 
-  NA_EIDPROC virtual void display() const {}; // LCOV_EXCL_LINE
+  virtual void display() const {}; // LCOV_EXCL_LINE
 
   // key range iterator methods
-  NA_EIDPROC virtual ExeErrorCode initNextKeyRange(sql_buffer_pool *pool,
+  virtual ExeErrorCode initNextKeyRange(sql_buffer_pool *pool,
 				        	   atp_struct *atp0) = 0;
 
   enum getNextKeyRangeReturnType { NO_MORE_RANGES,
@@ -117,14 +117,14 @@ public:
 				   PROBE_RANGE,
 				   EXPRESSION_ERROR };
 
-  NA_EIDPROC virtual getNextKeyRangeReturnType getNextKeyRange(
+  virtual getNextKeyRangeReturnType getNextKeyRange(
        atp_struct *atp0,NABoolean fetchRangeHadRows,
        NABoolean detectNullRange = TRUE) = 0;
 
   // on the next method, we pass in NULL if a probe resulted in no
   // data; we pass in the encoded key value if data was obtained
 // LCOV_EXCL_START
-  NA_EIDPROC virtual void reportProbeResult(char *)
+  virtual void reportProbeResult(char *)
   { 
     ex_assert(0,"reportProbeResult() was called when it shouldn't have been");
   };
@@ -133,19 +133,19 @@ public:
   // when getNextKeyRange() returns FETCH_RANGE or PROBE_RANGE, the
   // caller should call the next four methods to get its hands on the
   // key values
-  NA_EIDPROC tupp & getBkData()
+  tupp & getBkData()
   { return bkData_; };
 
-  NA_EIDPROC tupp & getEkData()
+  tupp & getEkData()
   { return ekData_; };
 
-  NA_EIDPROC short getBkExcludeFlag()
+  short getBkExcludeFlag()
   { return bkExcludeFlag_; };
 
-  NA_EIDPROC short getEkExcludeFlag()
+  short getEkExcludeFlag()
   { return ekExcludeFlag_; };
 
-  NA_EIDPROC ULng32 getKeyLength()
+  ULng32 getKeyLength()
   { return tdbKey_.getKeyLength(); };
 
 };

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/key_single_subset.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/key_single_subset.h b/core/sql/executor/key_single_subset.h
index 370c9aa..7c90165 100644
--- a/core/sql/executor/key_single_subset.h
+++ b/core/sql/executor/key_single_subset.h
@@ -73,7 +73,7 @@ private:
 
 public:
 
-  NA_EIDPROC keySingleSubsetEx(const keyRangeGen & tdb_key,
+  keySingleSubsetEx(const keyRangeGen & tdb_key,
 			       const short in_version,
 			       sql_buffer_pool *pool,
 			       ex_globals *g,
@@ -81,42 +81,42 @@ public:
                                const ex_tcb * tcb);
 				  
 
-  NA_EIDPROC virtual ~keySingleSubsetEx();
+  virtual ~keySingleSubsetEx();
 
-  //  NA_EIDPROC virtual void freeResources(); -- just inherit from base class
+  //  virtual void freeResources(); -- just inherit from base class
 
-  NA_EIDPROC virtual void display() const {};
+  virtual void display() const {};
 
   // key range iterator methods
-  NA_EIDPROC virtual ExeErrorCode initNextKeyRange(sql_buffer_pool *pool,
+  virtual ExeErrorCode initNextKeyRange(sql_buffer_pool *pool,
 			        		   atp_struct *atp0);
-  NA_EIDPROC virtual getNextKeyRangeReturnType getNextKeyRange(
+  virtual getNextKeyRangeReturnType getNextKeyRange(
        atp_struct *atp0,NABoolean fetchRangeHadRows,
        NABoolean detectNullRange = TRUE);  
 
   // inlines to save some typing
-  NA_EIDPROC inline keySingleSubsetGen & tdbBeginEndKey() const
+  inline keySingleSubsetGen & tdbBeginEndKey() const
     { return (keySingleSubsetGen &)tdbKey_; } 
 
-  NA_EIDPROC inline ex_expr * bkPred() const
+  inline ex_expr * bkPred() const
     { return tdbBeginEndKey().bkPred(); };
 
-  NA_EIDPROC inline ex_expr * ekPred() const
+  inline ex_expr * ekPred() const
     { return tdbBeginEndKey().ekPred(); };
 
-  NA_EIDPROC inline ex_expr * bkExcludedExpr() const
+  inline ex_expr * bkExcludedExpr() const
     { return tdbBeginEndKey().bkExcludedExpr(); }
 
-  NA_EIDPROC inline ex_expr * ekExcludedExpr() const
+  inline ex_expr * ekExcludedExpr() const
     { return tdbBeginEndKey().ekExcludedExpr(); }
 
-  NA_EIDPROC inline short isBkeyExcluded() const 
+  inline short isBkeyExcluded() const 
     { return tdbBeginEndKey().isBkeyExcluded();}
 
-  NA_EIDPROC inline short isEkeyExcluded() const 
+  inline short isEkeyExcluded() const 
     { return tdbBeginEndKey().isEkeyExcluded();}
 
-  NA_EIDPROC inline Lng32 getExcludeFlagValue() const 
+  inline Lng32 getExcludeFlagValue() const 
     { return excludeFlag_; }
 };
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/1522c8cd/core/sql/executor/rcb.h
----------------------------------------------------------------------
diff --git a/core/sql/executor/rcb.h b/core/sql/executor/rcb.h
index 698e027..178ea35 100644
--- a/core/sql/executor/rcb.h
+++ b/core/sql/executor/rcb.h
@@ -18,53 +18,3 @@
 // under the License.
 //
 // @@@ END COPYRIGHT @@@
-struct field_struct
-{
-  char flags;
-  char type;
-  
-  short char_len;
-  
-  short exploded_offset;
-  short offset_ix;
-  
-  short default_offset;
-  
-};
-
-
-
-struct rcb_struct
-{
-  short eye_catcher;
-  short rcblen;
-  short fcbnum;
-  short kcbnum;
-  
-  short vsn[3];
-  
-  short kfield_off;
-  
-  short last_index_col_ix;
-  
-  short signed_kfield_off;
-  
-  char signed_kfield_max;
-  char unsigned_dec_kfield_flg;
-  
-  short flags2;
-  
-  short sect_len;
-  
-  short ttag;
-  short tflags;
-  
-  short max_packed_reclen;
-  
-  short max_exp_reclen;
-  short flags;
-  short default_area_len;
-  short num_entries;
-  
-  field_struct field[1];
-}; // rcb_struct