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/25 23:43:01 UTC

[07/14] incubator-trafodion git commit: lcov: commit #1

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ControlDB.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ControlDB.cpp b/core/sql/optimizer/ControlDB.cpp
index f8e2f1b..4af0d81 100644
--- a/core/sql/optimizer/ControlDB.cpp
+++ b/core/sql/optimizer/ControlDB.cpp
@@ -272,7 +272,6 @@ void ControlDB::setControlDefault(ControlQueryDefault *def)
 
   if (def->getAttrEnum() == NSK_DBG_LOG_FILE)
   {
-    // LCOV_EXCL_START
     DefaultConstants attrEnum = def->getAttrEnum();
     const char * optDbgLog =
       ActiveSchemaDB()->getDefaults().getValue(attrEnum);
@@ -293,7 +292,6 @@ void ControlDB::setControlDefault(ControlQueryDefault *def)
 
     CURRCONTEXT_OPTDEBUG->openLog(logFileName);
 
-    // LCOV_EXCL_STOP
   }
 
   if (def->getAttrEnum() == NSK_DBG_COMPILE_INSTANCE)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/Cost.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Cost.cpp b/core/sql/optimizer/Cost.cpp
index dc6d701..35c51eb 100644
--- a/core/sql/optimizer/Cost.cpp
+++ b/core/sql/optimizer/Cost.cpp
@@ -60,13 +60,11 @@ extern Cost* rollUpUnaryNonBlocking(const Cost& ,
 // -----------------------------------------------------------------------
 // global display methods (to be invoked from Objectcenter)
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 // excluded for coverage because it's a debug code
 void displayCost (const Cost & cost)
 {
   cost.print();
 }
-// LCOV_EXCL_STOP
 
 //<pb>
 
@@ -300,7 +298,6 @@ operator/(const SimpleCostVector &vector, const CostScalar &scalar)
 //  Sum of v1 and v2 using blocking vector addition.
 //
 //==============================================================================
-// LCOV_EXCL_START :cnu -- OCM code
 SimpleCostVector
 blockingAdd(const SimpleCostVector &v1,
             const SimpleCostVector &v2,
@@ -753,7 +750,6 @@ isLowerBound(const SimpleCostVector &v1, const SimpleCostVector &v2)
 
 } // isLowerBound()
 //<pb>
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // methods for class SimpleCostVector used in SCM.
@@ -893,7 +889,6 @@ void SimpleCostVector::print(FILE* ofd) const
 }
 */
 
-// LCOV_EXCL_START
 // excluded for coverage because it's a debug code
 void SimpleCostVector::print(FILE* pfp) const
 {
@@ -914,7 +909,6 @@ void SimpleCostVector::print(FILE* pfp) const
   fprintf(pfp,"\n");
 }
 
-// LCOV_EXCL_STOP
 //<pb>
 
 //<pb>
@@ -923,7 +917,6 @@ void SimpleCostVector::print(FILE* pfp) const
 // The argument ownline indicates if the cost components need to be in their
 // own lines.
 // The argument prefix optionally gives a prefix string to be printed
-// LCOV_EXCL_START
 // This gets called only when internal CQD EXPLAIN_DETAIL_COST_FOR_CALIBRATION
 // is ON for debugging purpose. So, exclude for coverage
 const NAString SimpleCostVector::getDetailDesc(const DefaultToken ownline,
@@ -971,7 +964,6 @@ const NAString SimpleCostVector::getDetailDesc(const DefaultToken ownline,
   dtlDesc = detail;
   return dtlDesc;
 } // SimpleCostVector::getDetailDesc()
-// LCOV_EXCL_STOP
 
 //<pb>
 // NCM specific method.
@@ -1157,7 +1149,6 @@ SimpleCostVector::getNormalizedVersion(const CostScalar & factor) const
 //  Accumulated vector using overlapped addition.
 //
 //==============================================================================
-// LCOV_EXCL_START :cnu -- OCM code
 const SimpleCostVector&
 SimpleCostVector::overlappedAdd(const SimpleCostVector& other)
 {
@@ -1255,7 +1246,6 @@ SimpleCostVector::repeatedOverlappedAdd(const Lng32 times)
   return *this;
 
 } //SimpleCostVector::repeatedOverlappedAdd()
-// LCOV_EXCL_STOP
 //<pb>
 // -----------------------------------------------------------------------
 // scaleUpByNumProbes() scales up a simple cost vector by its number of
@@ -1417,7 +1407,6 @@ const SimpleCostVector& SimpleCostVector::reset()
 //  TRUE if this is a zero vector; FALSE otherwise.
 //
 //==============================================================================
-// LCOV_EXCL_START
 // This method is no longer used, isZeroVectorWithProbes is used instead.
 // So hide it from coverage
 NABoolean
@@ -1442,7 +1431,6 @@ SimpleCostVector::isZeroVector() const
   return TRUE;
 
 } // SimpleCostVector::isZero
-// LCOV_EXCL_STOP
 
 // This method needs to be used instead of isZeroVector for checking
 // blocking components of Cost Object: cpbcTotal and cpbc1.
@@ -1954,7 +1942,6 @@ ElapsedTime Cost::convertToElapsedTime(
   ElapsedTime et ( csZero );
   CostScalar etBlock = cpbcTotal_.getElapsedTime(*pfg);
 
-  // LCOV_EXCL_START
   // FirstRow optimization is a disabled feature, hide from coverage
   if(pfg->isOptimizeForFirstRow())
   {
@@ -1962,7 +1949,6 @@ ElapsedTime Cost::convertToElapsedTime(
     const CostScalar etFR = cpfr_.getElapsedTime(*pfg) + etBlock;
     et = ElapsedTime( etFR );
   }
-  // LCOV_EXCL_STOP
   else if(pfg->isOptimizeForLastRow())
   {
     // cpbcTotal_ is a per-probe average cost.
@@ -1973,7 +1959,6 @@ ElapsedTime Cost::convertToElapsedTime(
     etLRPlusBlk = etLR + etBlock * cpbcTotal_.getNumProbes();
     et = ElapsedTime( etLRPlusBlk );
   }
-  // LCOV_EXCL_START
   // total resource consumption is a disabled feature, hide from coverage
   else if (pfg->isOptimizeForResourceConsumption())
   {
@@ -1988,7 +1973,6 @@ ElapsedTime Cost::convertToElapsedTime(
     etLRPlusBlk = etLR + etBlock * cpbcTotal_.getNumProbes();
     et = ElapsedTime( etLRPlusBlk );
   }
-  // LCOV_EXCL_STOP
   return et;
 
 } // Cost::convertToElapsedTime()
@@ -2055,7 +2039,6 @@ const NAString Cost::getDetailDesc() const
               "TC_PROC: %g TC_PROD: %g TC_SENT: %g IO_SEQ: %g IO_RAND: %g ",
               tcProc, tcProd, tcSent, ioSeq, ioRand);
 
-      // LCOV_EXCL_START :dpm
       NABoolean scmDebugOn = (CmpCommon::getDefault(NCM_PRINT_ROWSIZE) == DF_ON);
       if (scmDebugOn == TRUE)
       {
@@ -2069,7 +2052,6 @@ const NAString Cost::getDetailDesc() const
         // Does strcat truncate??
         strcat(line, rowsizeInfo);
       }
-      // LCOV_EXCL_STOP
     }
   }
   dtlDesc = line;
@@ -2148,7 +2130,6 @@ void Cost::getExternalCostAttr(double &cpuTime, double &ioTime,
 // simple cost vector depending on the cost model in effect. This is expected
 // to be used by callers like Explain etc. to display the cost details.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START :cnu -- OCM code
 void Cost::getOcmCostAttr(double &cpu, double &io,
                           double &msg, double &idleTime,
                           Lng32 &probes) const
@@ -2168,14 +2149,12 @@ void Cost::getOcmCostAttr(double &cpu, double &io,
   CostScalar tmpProbe = cplr_.getNumProbes();
   probes =  Lng32(tmpProbe.getValue());
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // The cost detail description consists of the individual components of the
 // simple cost vector depending on the cost model in effect. This is expected
 // to be used by callers like Explain etc. to display the cost details.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 // called only when internal debugging CQD NCM_PRINT_ROWSIZE is ON.
 // So hide from coverage
 void Cost::getScmCostAttr(double &tcProc, double &tcProd,
@@ -2195,7 +2174,6 @@ void Cost::getScmCostAttr(double &tcProc, double &tcProd,
   CostScalar tmpProbe = cpScmlr_.getNumProbes();
   probes = Lng32(tmpProbe.getValue());
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // The cost detail description consists of the individual components of the
@@ -2441,7 +2419,6 @@ Cost::computePlanPriority( RelExpr* op,
 }
 
 
-// LCOV_EXCL_START
 // excluded for coverage because it's a debug code
 void Cost::print(FILE * pfp, const char * , const char *) const
 {
@@ -2468,7 +2445,6 @@ void Cost::display() const
   print(); 
 }
 
-// LCOV_EXCL_STOP
 
 //<pb>
 //==============================================================================
@@ -2505,7 +2481,6 @@ void Cost::display() const
 //  none.
 //
 //==============================================================================
-// LCOV_EXCL_START :cnu -- OCM code
 HashJoinCost::HashJoinCost(const SimpleCostVector* currentProcessFirstRowCost,
                            const SimpleCostVector* currentProcessLastRowCost,
                            const SimpleCostVector* currentProcessBlockingCost,
@@ -2574,7 +2549,6 @@ HashJoinCost::HashJoinCost(const SimpleCostVector* currentProcessFirstRowCost,
     }
 
 } // HashJoinCost constructor.
-// LCOV_EXCL_STOP
 //<pb>
 //==============================================================================
 //  Effectively a virtual constructor for a hash join cost object.
@@ -2899,7 +2873,6 @@ CostScalar ResourceConsumptionWeight::operator[] (Lng32 ix) const
 // -----------------------------------------------------------------------
 // methods for class CostLimit
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START :cnu -- OCM code
 ElapsedTimeCostLimit* CostLimit::castToElapsedTimeCostLimit() const
 {
   return NULL; // sorry, wrong number
@@ -3523,7 +3496,6 @@ ElapsedTimeCostLimit::unilaterallyReduce(const ElapsedTime & timeReduction)
   cachedValue_ = 0.0;
 
 } //ElapsedTimeCostLimit::unilaterallyReduce()
-// LCOV_EXCL_STOP
 //<pb>
 
 // ***********************************************************************
@@ -3884,7 +3856,6 @@ ScmElapsedTimeCostLimit::unilaterallyReduce(const ElapsedTime & timeReduction)
 // ---------------------------------------------------------------------------
 // methods for class CostPrimitives
 // ---------------------------------------------------------------------------
-// LCOV_EXCL_START :cnu -- OCM code
 
 double CostPrimitives::cpuCostForCopySet(const ValueIdSet & vidset)
 {
@@ -3981,5 +3952,4 @@ double CostPrimitives::getBasicCostFactor(Lng32 id)
     return 1.0;
   return CmpCommon::getDefaultNumeric((DefaultConstants)id);
 }
-// LCOV_EXCL_STOP
 // eof

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/EncodedValue.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/EncodedValue.cpp b/core/sql/optimizer/EncodedValue.cpp
index 98ca526..0e769ef 100644
--- a/core/sql/optimizer/EncodedValue.cpp
+++ b/core/sql/optimizer/EncodedValue.cpp
@@ -250,7 +250,6 @@ NormValue::NormValue(const ConstValue * constant, NABoolean negate)
   isNullFlag_ = FALSE;
 }
 
-// LCOV_EXCL_START :dpm
 void NormValue::display (FILE *f, const char * prefix, const char * suffix,
                          CollHeap *c, char *buf) const
 {
@@ -273,7 +272,6 @@ void NormValue::display (FILE *f, const char * prefix, const char * suffix,
     PRINTIT(f, c, space, buf, mybuf);
   }
 }
-// LCOV_EXCL_STOP
 
 NormValueList::NormValueList(const NormValueList & nvl, NAMemory *h)
   :NAArray<NormValue>(h ? h : CmpCommon::statementHeap(),nvl.entries()),
@@ -1034,7 +1032,6 @@ COMPARE_RESULT EncodedValue::compare (const EncodedValue &other) const
   return result;
 }
 
-// LCOV_EXCL_START :dpm
 void EncodedValue::display (FILE *f, const char * prefix, const char * suffix,
                             CollHeap *c, char *buf) const
 {
@@ -1061,7 +1058,6 @@ void EncodedValue::display (FILE *f, const char * prefix, const char * suffix,
   snprintf(mybuf, sizeof(mybuf), " )%s", suffix);
   PRINTIT(f, c, space, buf, mybuf);
 }
-// LCOV_EXCL_STOP
 
 const NAString EncodedValue::getText(NABoolean parenthesized, NABoolean showFractionalPart) const
 {

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/EstLogProp.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/EstLogProp.cpp b/core/sql/optimizer/EstLogProp.cpp
index c30631d..58199cf 100644
--- a/core/sql/optimizer/EstLogProp.cpp
+++ b/core/sql/optimizer/EstLogProp.cpp
@@ -129,7 +129,6 @@ EstLogProp::~EstLogProp()
   (*counter_).decrementCounter();
 }
 
-// LCOV_EXCL_START :cnu
 NABoolean EstLogProp::reconcile(const EstLogProp &other)
 {
   // simple logic for now: merge unresolved preds lists,
@@ -142,7 +141,6 @@ NABoolean EstLogProp::reconcile(const EstLogProp &other)
   resultCardinality_ = (resultCardinality_ + other.resultCardinality_) / 2;
 
 } // EstLogProp::reconcile
-// LCOV_EXCL_STOP
 
 COMPARE_RESULT EstLogProp::compareEstLogProp (const EstLogPropSharedPtr &other) const
 {
@@ -437,11 +435,9 @@ EstLogProp::getCardOfBusiestStream(const PartitioningFunction* partFunc,
 
 } // EstLogProp::getCardOfBusiestStream
 
-// LCOV_EXCL_START :dpm
 void EstLogProp::print(FILE* ofd, const char* prefix, const char *suffix) const
 {
 } // EstLogProp::print()
-// LCOV_EXCL_STOP
 
 NABoolean EstLogProp::operator == (const EstLogProp & other) const
 {

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/EstLogProp.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/EstLogProp.h b/core/sql/optimizer/EstLogProp.h
index 775ac0d..959a3fa 100644
--- a/core/sql/optimizer/EstLogProp.h
+++ b/core/sql/optimizer/EstLogProp.h
@@ -105,7 +105,7 @@ public:
     v.round();
     v.minCsOne();
     if ( v.getValue() > COSTSCALAR_MAX )
-      resultCardinality_ = COSTSCALAR_MAX; // LCOV_EXCL_LINE :rfi
+      resultCardinality_ = COSTSCALAR_MAX;
     else
       resultCardinality_ = v; 
   }   
@@ -124,7 +124,7 @@ public:
   void setMaxCardEst(CostScalar v)
     { //CCMPASSERT (v >= 0) ; 
       if ( v.getValue() > COSTSCALAR_MAX )
-        maxCardinality_ = COSTSCALAR_MAX; // LCOV_EXCL_LINE :rfi
+        maxCardinality_ = COSTSCALAR_MAX;
       else
         maxCardinality_ = v; 
     }   

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/GroupAttr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/GroupAttr.cpp b/core/sql/optimizer/GroupAttr.cpp
index 6007a4e..7e87bb6 100644
--- a/core/sql/optimizer/GroupAttr.cpp
+++ b/core/sql/optimizer/GroupAttr.cpp
@@ -367,7 +367,7 @@ void GroupAttributes::addConstraint(ItemExpr *c)
       break;
 
     case ITM_UNIQUE_CONSTRAINT:
-      DCMPASSERT("Wrong constraint type used in GA" == 0); // LCOV_EXCL_LINE
+      DCMPASSERT("Wrong constraint type used in GA" == 0);
       break;
 
     default:
@@ -502,7 +502,6 @@ NABoolean GroupAttributes::hasCardConstraint(Cardinality &minNumOfRows,
   return found;
 }
 
-// LCOV_EXCL_START
 NABoolean GroupAttributes::hasConstraintOfType(OperatorTypeEnum constraintType) const
 {
   for (ValueId x= constraints_.init();
@@ -527,7 +526,6 @@ void GroupAttributes::getConstraintsOfType(OperatorTypeEnum constraintType,
 	  vidSet.insert(x);
     }
 }
-// LCOV_EXCL_STOP
 
 // This method is used flow RefOpt constraints (optimizer version of foreign key
 // side of a RI constraint) up the query tree. The input argument is typically
@@ -782,7 +780,7 @@ void GroupAttributes::lomerge (GroupAttributes &other, NABoolean mergeCIO)
     {
       if (NOT (requiredInputs_ == other.requiredInputs_) OR
                NOT (requiredOutputs_ == other.requiredOutputs_))
-        ABORT("Internal error, merging incompatible group attributes"); // LCOV_EXCL_LINE
+        ABORT("Internal error, merging incompatible group attributes");
     }
 
   // To add the constraints from the other group to this one, we
@@ -2496,7 +2494,6 @@ NABoolean GroupAttributes::addInputOutputLogProp (const EstLogPropSharedPtr& inp
 } //GroupAttributes::addInputOutputLogProp
 
 
-// LCOV_EXCL_START
 // this method is used by the GUI debugger for displaying the
 // estimated logical properties which are cached by the ASM
 
@@ -2561,7 +2558,6 @@ SHPTR_LIST(EstLogPropSharedPtr) * GroupAttributes::getCachedStatsList()
   }
   return statsList;
 }
-// LCOV_EXCL_STOP
 
 ColStatsSharedPtr GroupAttributes::getColStatsForSkewDetection(
                                               const ValueId vId,
@@ -2623,7 +2619,6 @@ CostScalar GroupAttributes::getSkewnessFactor(const ValueId vId,
 } // GroupAttributes::getSkewnessFactor
 
 
-// LCOV_EXCL_START
 
 SkewedValueList* GroupAttributes::getSkewedValues(const ValueId& vId,
                                               double threshold,
@@ -2884,7 +2879,6 @@ GroupAttributes::setEssentialCharacteristicOutputs(const ValueIdSet & vset)
   CMPASSERT(NOT misMatchFound);
   requiredEssentialOutputs_ = vset;
 }
-// LCOV_EXCL_STOP
 
 void 
 GroupAttributes::addEssentialCharacteristicOutputs(const ValueIdSet & vset)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ImplRule.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ImplRule.cpp b/core/sql/optimizer/ImplRule.cpp
index 1fb854c..38c9ff0 100644
--- a/core/sql/optimizer/ImplRule.cpp
+++ b/core/sql/optimizer/ImplRule.cpp
@@ -730,7 +730,7 @@ void copyCommonDeleteFields(Delete *result,
 // methods for class FileScanRule
 // -----------------------------------------------------------------------
 
-FileScanRule::~FileScanRule() {} // LCOV_EXCL_LINE 
+FileScanRule::~FileScanRule() {} 
 
 /**************************************************************************
 * Input : list of indexes of the same table
@@ -875,7 +875,6 @@ IndexDesc * findMostPartitionedIndex(const LIST(IndexProperty *)& indexes,CollIn
 * plan.
 ***************************************************************************/
 // This function is never code in the code base (checked in M5):1064
-// LCOV_EXCL_START
 NABoolean oneViableIndexJoin(const LIST(IndexProperty *) & indexes)
 {
   CollIndex ixCount = indexes.entries();
@@ -888,7 +887,6 @@ NABoolean oneViableIndexJoin(const LIST(IndexProperty *) & indexes)
   }
   return FALSE;
 }
-// LCOV_EXCL_STOP
 
 
 /**************************************************************************
@@ -1629,7 +1627,7 @@ RelExpr * FileScanRule::nextSubstitute(RelExpr * before,
 // methods for class HbaseScanRule
 // -----------------------------------------------------------------------
 
-HbaseScanRule::~HbaseScanRule() {} // LCOV_EXCL_LINE 
+HbaseScanRule::~HbaseScanRule() {} 
 
 NABoolean HbaseScanRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -1667,7 +1665,7 @@ RelExpr * HbaseScanRule::nextSubstitute(RelExpr * before,
 // methods for class UnionRule
 // -----------------------------------------------------------------------
 
-UnionRule::~UnionRule() {} // LCOV_EXCL_LINE 
+UnionRule::~UnionRule() {} 
 
 NABoolean UnionRule::topMatch(RelExpr * relExpr, Context * context)
 {
@@ -1736,7 +1734,7 @@ RelExpr * UnionRule::nextSubstitute(RelExpr * before,
 // methods for class SortGroupByRule
 // -----------------------------------------------------------------------
 
-SortGroupByRule::~SortGroupByRule() {} // LCOV_EXCL_LINE 
+SortGroupByRule::~SortGroupByRule() {} 
 
 NABoolean SortGroupByRule::topMatch (RelExpr *relExpr,
                                      Context *context)
@@ -1859,7 +1857,7 @@ RelExpr * SortGroupByRule::nextSubstitute(RelExpr * before,
 // -----------------------------------------------------------------------
 // methods for class AggregateRule
 // -----------------------------------------------------------------------
-AggregateRule::~AggregateRule() {} // LCOV_EXCL_LINE 
+AggregateRule::~AggregateRule() {} 
 
 NABoolean AggregateRule::topMatch (RelExpr *relExpr,
                                    Context *context)
@@ -1921,7 +1919,7 @@ NABoolean AggregateRule::topMatch (RelExpr *relExpr,
 // methods for class PhysShortCutGroupByRule
 // -----------------------------------------------------------------------
 
-PhysShortCutGroupByRule::~PhysShortCutGroupByRule() {} // LCOV_EXCL_LINE 
+PhysShortCutGroupByRule::~PhysShortCutGroupByRule() {} 
 
 NABoolean PhysShortCutGroupByRule::topMatch (RelExpr *relExpr,
                                              Context *context)
@@ -1997,7 +1995,7 @@ RelExpr * PhysShortCutGroupByRule::nextSubstitute(RelExpr * before,
 // methods for class HashGroupByRule
 // -----------------------------------------------------------------------
 
-HashGroupByRule::~HashGroupByRule() {} // LCOV_EXCL_LINE 
+HashGroupByRule::~HashGroupByRule() {} 
 
 NABoolean HashGroupByRule::topMatch (RelExpr *relExpr,
                                      Context *context)
@@ -2139,7 +2137,7 @@ NABoolean Insert::isDataSorted(Insert *bef, const Context *context)
 // methods for class HbaseDeleteRule
 // -----------------------------------------------------------------------
 
-HbaseDeleteRule::~HbaseDeleteRule() {} // LCOV_EXCL_LINE 
+HbaseDeleteRule::~HbaseDeleteRule() {} 
 
 NABoolean HbaseDeleteRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -2244,7 +2242,7 @@ RelExpr * HbaseDeleteRule::nextSubstitute(RelExpr * before,
 // methods for class HbaseDeleteCursorRule
 // -----------------------------------------------------------------------
 
-HbaseDeleteCursorRule::~HbaseDeleteCursorRule() {} // LCOV_EXCL_LINE 
+HbaseDeleteCursorRule::~HbaseDeleteCursorRule() {} 
 
 NABoolean HbaseDeleteCursorRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -2322,7 +2320,7 @@ RelExpr * HbaseDeleteCursorRule::nextSubstitute(RelExpr * before,
 // methods for class HbaseUpdateRule
 // -----------------------------------------------------------------------
 
-HbaseUpdateRule::~HbaseUpdateRule() {} // LCOV_EXCL_LINE 
+HbaseUpdateRule::~HbaseUpdateRule() {} 
 
 NABoolean HbaseUpdateRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -2429,7 +2427,7 @@ RelExpr * HbaseUpdateRule::nextSubstitute(RelExpr * before,
 // methods for class HbaseUpdateCursorRule
 // -----------------------------------------------------------------------
 
-HbaseUpdateCursorRule::~HbaseUpdateCursorRule() {} // LCOV_EXCL_LINE 
+HbaseUpdateCursorRule::~HbaseUpdateCursorRule() {} 
 
 NABoolean HbaseUpdateCursorRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -2506,7 +2504,7 @@ RelExpr * HbaseUpdateCursorRule::nextSubstitute(RelExpr * before,
 // -----------------------------------------------------------------------
 // methods for class HiveInsertRule
 // -----------------------------------------------------------------------
-HiveInsertRule::~HiveInsertRule() {} // LCOV_EXCL_LINE 
+HiveInsertRule::~HiveInsertRule() {} 
 
 NABoolean HiveInsertRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -2598,7 +2596,7 @@ RelExpr * HiveInsertRule::nextSubstitute(RelExpr * before,
 // -----------------------------------------------------------------------
 // methods for class HbaseInsertRule
 // -----------------------------------------------------------------------
-HbaseInsertRule::~HbaseInsertRule() {} // LCOV_EXCL_LINE 
+HbaseInsertRule::~HbaseInsertRule() {} 
 
 NABoolean HbaseInsertRule::topMatch(RelExpr * relExpr, Context *context)
 {
@@ -2704,7 +2702,7 @@ RelExpr * HbaseInsertRule::nextSubstitute(RelExpr * before,
 // methods for class NestedJoinRule
 // -----------------------------------------------------------------------
 
-NestedJoinRule::~NestedJoinRule() {} // LCOV_EXCL_LINE 
+NestedJoinRule::~NestedJoinRule() {} 
 
 NABoolean NestedJoinRule::topMatch(RelExpr * relExpr,
                                    Context * context)
@@ -3000,7 +2998,7 @@ NABoolean NestedJoinRule::canBePruned(RelExpr * relExpr) const
 // methods for class NestedJoinFlowRule
 // -----------------------------------------------------------------------
 
-NestedJoinFlowRule::~NestedJoinFlowRule() {} // LCOV_EXCL_LINE 
+NestedJoinFlowRule::~NestedJoinFlowRule() {} 
 
 NABoolean NestedJoinFlowRule::topMatch (RelExpr *relExpr,
                                         Context *context)
@@ -3097,7 +3095,7 @@ RelExpr * NestedJoinFlowRule::nextSubstitute(RelExpr * before,
 // methods for class HashJoinRule
 // -----------------------------------------------------------------------
 
-HashJoinRule::~HashJoinRule() {} // LCOV_EXCL_LINE 
+HashJoinRule::~HashJoinRule() {} 
 
 NABoolean HashJoinRule::topMatch (RelExpr * relExpr,
                                   Context * context)
@@ -3530,7 +3528,6 @@ RelExpr * HashJoinRule::nextSubstitute(RelExpr * before,
 
   // The following block of code is old and contains bugs.
   // Mask the block out for code coverage.
-  // LCOV_EXCL_START
 
   // Check if this is a BMO
   NABoolean isBMO = result->isBigMemoryOperatorSetRatio(context, 0, bmoFactor);
@@ -3606,7 +3603,6 @@ RelExpr * HashJoinRule::nextSubstitute(RelExpr * before,
   return setResult(result,bef,useOrderedHashJoin, FALSE);
   //end Heuristics
 
-  // LCOV_EXCL_STOP
 
 } // HashJoinRule::nextSubstitute()
 
@@ -3614,7 +3610,7 @@ RelExpr * HashJoinRule::nextSubstitute(RelExpr * before,
 // methods for class MergeJoinRule
 // -----------------------------------------------------------------------
 
-MergeJoinRule::~MergeJoinRule() {} // LCOV_EXCL_LINE 
+MergeJoinRule::~MergeJoinRule() {} 
 
 NABoolean MergeJoinRule::topMatch (RelExpr *relExpr,
                                    Context * context)
@@ -3860,7 +3856,7 @@ RelExpr *PhysCompoundStmtRule::nextSubstitute(
 // methods for class PhysicalMapValueIdsRule
 // -----------------------------------------------------------------------
 
-PhysicalMapValueIdsRule::~PhysicalMapValueIdsRule() {} // LCOV_EXCL_LINE 
+PhysicalMapValueIdsRule::~PhysicalMapValueIdsRule() {} 
 
 // This rule is context sensitive
 NABoolean PhysicalMapValueIdsRule::isContextSensitive() const
@@ -3913,7 +3909,7 @@ NABoolean PhysicalMapValueIdsRule::canMatchPattern (const RelExpr *) const
 // methods for class PhysicalRelRootRule
 // -----------------------------------------------------------------------
 
-PhysicalRelRootRule::~PhysicalRelRootRule() {} // LCOV_EXCL_LINE 
+PhysicalRelRootRule::~PhysicalRelRootRule() {} 
 
 RelExpr * PhysicalRelRootRule::nextSubstitute(RelExpr * before,
                                               Context * /*context*/,
@@ -3938,7 +3934,7 @@ RelExpr * PhysicalRelRootRule::nextSubstitute(RelExpr * before,
 // methods for class PhysicalTupleRule
 // -----------------------------------------------------------------------
 
-PhysicalTupleRule::~PhysicalTupleRule() {} // LCOV_EXCL_LINE 
+PhysicalTupleRule::~PhysicalTupleRule() {} 
 
 NABoolean PhysicalTupleRule::topMatch (RelExpr *relExpr,
                                        Context *context)
@@ -3986,7 +3982,7 @@ RelExpr * PhysicalTupleRule::nextSubstitute(RelExpr * before,
 // -----------------------------------------------------------------------
 // methods for class PhysicalTupleListRule
 // -----------------------------------------------------------------------
-PhysicalTupleListRule::~PhysicalTupleListRule() {} // LCOV_EXCL_LINE 
+PhysicalTupleListRule::~PhysicalTupleListRule() {} 
 
 NABoolean PhysicalTupleListRule::topMatch (RelExpr *relExpr,
                                            Context *context)
@@ -4032,7 +4028,7 @@ RelExpr * PhysicalTupleListRule::nextSubstitute(RelExpr * before,
 // methods for class PhysicalExplainRule
 // -----------------------------------------------------------------------
 
-PhysicalExplainRule::~PhysicalExplainRule() {} // LCOV_EXCL_LINE 
+PhysicalExplainRule::~PhysicalExplainRule() {} 
 
 RelExpr * PhysicalExplainRule::nextSubstitute(RelExpr * before,
                                               Context * /*context*/,
@@ -4057,7 +4053,7 @@ RelExpr * PhysicalExplainRule::nextSubstitute(RelExpr * before,
 // methods for class PhysicalHiveMDRule
 // -----------------------------------------------------------------------
 
-PhysicalHiveMDRule::~PhysicalHiveMDRule() {} // LCOV_EXCL_LINE 
+PhysicalHiveMDRule::~PhysicalHiveMDRule() {} 
 
 RelExpr * PhysicalHiveMDRule::nextSubstitute(RelExpr * before,
                                               Context * /*context*/,
@@ -4083,7 +4079,7 @@ RelExpr * PhysicalHiveMDRule::nextSubstitute(RelExpr * before,
 // -----------------------------------------------------------------------
 
 // Destructor.
-PhysicalPackRule::~PhysicalPackRule() // LCOV_EXCL_LINE 
+PhysicalPackRule::~PhysicalPackRule()
 {
 }
 
@@ -4247,7 +4243,7 @@ NABoolean PhysicalPackRule::canMatchPattern (const RelExpr *) const
 
 // Destructor for the PhysicalTransposeRule
 //
-PhysicalTransposeRule::~PhysicalTransposeRule() {} // LCOV_EXCL_LINE 
+PhysicalTransposeRule::~PhysicalTransposeRule() {} 
 
 // PhysicalTransposeRule::topMatch() -------------------------------------
 // The method is used to determine if a rule should fire.  If
@@ -4413,7 +4409,7 @@ RelExpr * PhysicalTransposeRule::nextSubstitute(RelExpr * before,
 
 // Destructor for the PhysicalUnPackRowsRule
 //
-PhysicalUnPackRowsRule::~PhysicalUnPackRowsRule() {} // LCOV_EXCL_LINE 
+PhysicalUnPackRowsRule::~PhysicalUnPackRowsRule() {} 
 
 // PhysicalUnPackRowsRule::topMatch() -------------------------------------
 // The method is used to determine if a rule should fire.  If
@@ -4633,7 +4629,7 @@ NABoolean PhysicalUnPackRowsRule::canMatchPattern (const RelExpr *) const
 // methods for class SortEnforcerRule
 // -----------------------------------------------------------------------
 
-SortEnforcerRule::~SortEnforcerRule() {} // LCOV_EXCL_LINE 
+SortEnforcerRule::~SortEnforcerRule() {} 
 
 NABoolean SortEnforcerRule::topMatch (RelExpr *  /* relExpr */,
                                       Context *context)
@@ -4728,7 +4724,7 @@ Int32 SortEnforcerRule::promiseForOptimization(RelExpr *,
 // methods for class ExchangeEnforcerRule
 // -----------------------------------------------------------------------
 
-ExchangeEnforcerRule::~ExchangeEnforcerRule() {} // LCOV_EXCL_LINE 
+ExchangeEnforcerRule::~ExchangeEnforcerRule() {} 
 
 NABoolean ExchangeEnforcerRule::topMatch(RelExpr *  /* relExpr */,
                                          Context *context)
@@ -4777,7 +4773,7 @@ Int32 ExchangeEnforcerRule::promiseForOptimization(RelExpr *,
 // -----------------------------------------------------------------------
 // Destructor for the PhysicalSequenceRule
 //
-PhysicalSequenceRule::~PhysicalSequenceRule() {} // LCOV_EXCL_LINE 
+PhysicalSequenceRule::~PhysicalSequenceRule() {} 
 
 // PhysicalSequenceRule::topMatch() ----------------------------------
 // The method is used to determine if a rule should fire.  If
@@ -4937,7 +4933,7 @@ RelExpr * PhysicalSequenceRule::nextSubstitute(RelExpr * before,
 
 // Destructor for the PhysicalSampleRule
 //
-PhysicalSampleRule::~PhysicalSampleRule() {} // LCOV_EXCL_LINE 
+PhysicalSampleRule::~PhysicalSampleRule() {} 
 
 // PhysicalSampleRule::topMatch() -------------------------------------
 // The method is used to determine if a rule should fire.  If
@@ -5108,7 +5104,7 @@ RelExpr * PhysicalSampleRule::nextSubstitute(RelExpr * before,
 // -----------------------------------------------------------------------
 // methods for class PhysicalSPProxyFuncRule
 // -----------------------------------------------------------------------
-PhysicalSPProxyFuncRule::~PhysicalSPProxyFuncRule() // LCOV_EXCL_LINE 
+PhysicalSPProxyFuncRule::~PhysicalSPProxyFuncRule()
 {}
 
 NABoolean PhysicalSPProxyFuncRule::topMatch(RelExpr *relExpr,
@@ -5141,7 +5137,7 @@ RelExpr *PhysicalSPProxyFuncRule::nextSubstitute(RelExpr *before,
 // -----------------------------------------------------------------------
 // methods for class PhysicalExtractSourceRule
 // -----------------------------------------------------------------------
-PhysicalExtractSourceRule::~PhysicalExtractSourceRule() {} // LCOV_EXCL_LINE 
+PhysicalExtractSourceRule::~PhysicalExtractSourceRule() {} 
 
 NABoolean PhysicalExtractSourceRule::topMatch(RelExpr *relExpr,
                                               Context *context)
@@ -5168,7 +5164,7 @@ RelExpr *PhysicalExtractSourceRule::nextSubstitute(RelExpr *before,
   return (RelExpr *) result;
 }
 
-PhysicalIsolatedScalarUDFRule::~PhysicalIsolatedScalarUDFRule() {} // LCOV_EXCL_LINE 
+PhysicalIsolatedScalarUDFRule::~PhysicalIsolatedScalarUDFRule() {} 
 
 NABoolean PhysicalIsolatedScalarUDFRule::topMatch (RelExpr *relExpr,
                                                 Context *context)
@@ -5217,7 +5213,7 @@ RelExpr * PhysicalIsolatedScalarUDFRule::nextSubstitute(RelExpr * before,
   return result;
 }
 
-PhysicalTMUDFRule::~PhysicalTMUDFRule() {} // LCOV_EXCL_LINE 
+PhysicalTMUDFRule::~PhysicalTMUDFRule() {} 
 
 NABoolean PhysicalTMUDFRule::topMatch (RelExpr *relExpr,
                                        Context *context)
@@ -5279,7 +5275,7 @@ NABoolean PhysicalTMUDFRule::canMatchPattern (const RelExpr *pattern) const
     }
 }
 
-PhysicalFastExtractRule::~PhysicalFastExtractRule() {} // LCOV_EXCL_LINE
+PhysicalFastExtractRule::~PhysicalFastExtractRule() {}
 
 NABoolean PhysicalFastExtractRule::topMatch (RelExpr *relExpr,
                                                 Context *context)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/Inlining.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Inlining.cpp b/core/sql/optimizer/Inlining.cpp
index f90a560..6b7ebd2 100644
--- a/core/sql/optimizer/Inlining.cpp
+++ b/core/sql/optimizer/Inlining.cpp
@@ -1563,7 +1563,6 @@ RelExpr *GenericUpdate::createTentativeSubTree(BindWA *bindWA,
 // child classes only.
 //////////////////////////////////////////////////////////////////////////////
 // we are not supposed to get here
-// LCOV_EXCL_START
 RelExpr *GenericUpdate::createEffectiveGU(BindWA   *bindWA, 
 					  CollHeap *heap, 
 					  TriggersTempTable& tempTableObj,
@@ -1573,7 +1572,6 @@ RelExpr *GenericUpdate::createEffectiveGU(BindWA   *bindWA,
   CMPASSERT(FALSE); // Not supposed to get here !!!
   return NULL;
 }
-// LCOV_EXCL_STOP
 
 //////////////////////////////////////////////////////////////////////////////
 // Create an Insert node that inserts the NEW@ values into the subject table.
@@ -2829,7 +2827,6 @@ void GenericUpdate::prepareForMvLogging(BindWA   *bindWA,
   if (getOperatorType() == REL_UNARY_INSERT &&
       getTableDesc()->getNATable()->getMvAttributeBitmap().getAutomaticRangeLoggingRequired())
   {
-    // LCOV_EXCL_START
     // dead code, range logging is not supported
     ItemExpr *rowType  = new(heap) GenericUpdateOutputFunction(ITM_VSBBROWTYPE);
     ItemExpr *rowCount = new(heap) GenericUpdateOutputFunction(ITM_VSBBROWCOUNT);
@@ -2837,7 +2834,6 @@ void GenericUpdate::prepareForMvLogging(BindWA   *bindWA,
       addVirtualColumn(bindWA, rowType, InliningInfo::getRowTypeVirtualColName(), heap);
     rowCountId = 
       addVirtualColumn(bindWA, rowCount, InliningInfo::getRowCountVirtualColName(), heap);
-    // LCOV_EXCL_STOP
   }
 
   ItemExpr *tsOutExpr = new (heap) 
@@ -2895,7 +2891,6 @@ RelExpr *GenericUpdate::createMvLogInsert(BindWA   *bindWA,
   RelExpr *topNode = insertNode;
   if (logTableObj.needsRangeLogging() && projectMidRangeRows)
   {
-    // LCOV_EXCL_START
     // dead code, range logging is not supported
     RelRoot *rootNode = new (heap) RelRoot(insertNode);
     rootNode->setEmptySelectList();
@@ -2918,7 +2913,6 @@ RelExpr *GenericUpdate::createMvLogInsert(BindWA   *bindWA,
     ifNode->setCondUnary();
 
     topNode = ifNode;
-    // LCOV_EXCL_STOP
   }
 
   RelRoot *rootNode = new (heap) RelRoot(topNode);
@@ -3115,7 +3109,6 @@ GenericUpdate::getTriggeredMvs(BindWA                 *bindWA,
 //////////////////////////////////////////////////////////////////////////////
 
 // we are not supposed to get here
-// LCOV_EXCL_START
 void GenericUpdate::insertMvToTriggerList(BeforeAndAfterTriggers *list,
 					  BindWA                 *bindWA,
 					  CollHeap               *heap,
@@ -3126,7 +3119,6 @@ void GenericUpdate::insertMvToTriggerList(BeforeAndAfterTriggers *list,
 {
   CMPASSERT(false); // not implemented in GenericUpdate
 }
-// LCOV_EXCL_STOP
 
 //////////////////////////////////////////////////////////////////////////////
 //////////////////////////////////////////////////////////////////////////////

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/Inlining.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Inlining.h b/core/sql/optimizer/Inlining.h
index 2a84175..d3e56ba 100644
--- a/core/sql/optimizer/Inlining.h
+++ b/core/sql/optimizer/Inlining.h
@@ -244,11 +244,9 @@ public:
   static const char *getEpochVirtualColName()    { return epochVirtualColName_; }
   static const char *getMvLogTsColName()         { return mvLogTsColName_; }
 
-  // LCOV_EXCL_START
   // only used for range logging which is a not supported feature
   static const char *getRowTypeVirtualColName()  { return rowtypeVirtualColName_; }
   static const char *getRowCountVirtualColName() { return rowcountVirtualColName_; }
-  // LCOV_EXCL_STOP
   
   // Mutators
   inline void setFlags(Int64 flags)                {flags_ |= flags;}
@@ -301,7 +299,7 @@ public:
   // copy Ctor
   ForceCardinalityInfo(const ForceCardinalityInfo &other);
 
-  virtual ~ForceCardinalityInfo() {}; // LCOV_EXCL_LINE
+  virtual ~ForceCardinalityInfo() {};
 
   // This value is used to force the cardinality.
   // It will be set to 0 when it should be ignored
@@ -331,7 +329,7 @@ public:
   // copy Ctor
   TriggerBindInfo(const TriggerBindInfo &other);
 
-  virtual ~TriggerBindInfo() {}; // LCOV_EXCL_LINE
+  virtual ~TriggerBindInfo() {};
 
   // forwards definition
   typedef UniqueExecuteId *UniqueExecuteIdPtr ;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItemArith.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemArith.h b/core/sql/optimizer/ItemArith.h
index e0f0591..5278f51 100644
--- a/core/sql/optimizer/ItemArith.h
+++ b/core/sql/optimizer/ItemArith.h
@@ -82,7 +82,7 @@ public:
   void setStandardNormalization()	                { normalizeFlags_ = LAST_DAY_ON_ERR; }
 
   NABoolean isKeepLastDay() const 		{ return normalizeFlags_ == LAST_DAY_OF_MONTH_FLAG; }
-  void setKeepLastDay()	                { normalizeFlags_ = LAST_DAY_OF_MONTH_FLAG; } // LCOV_EXCL_LINE
+  void setKeepLastDay()	                { normalizeFlags_ = LAST_DAY_OF_MONTH_FLAG; }
   NABoolean isDateMathFunction() const  { return (isStandardNormalization() || isKeepLastDay()); }
 
   const NAType* getIntervalQualifier() const 	{ return intervalQualifier_; }

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItemColRef.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemColRef.h b/core/sql/optimizer/ItemColRef.h
index 9b0c403..6a96370 100644
--- a/core/sql/optimizer/ItemColRef.h
+++ b/core/sql/optimizer/ItemColRef.h
@@ -564,7 +564,7 @@ public:
 
   // provide an interface to the SB and MB strings prepared by the parser.
   // Use with caution! At least need to check the null-ness.
-  NAString* getLocaleString() { return locale_strval; }; // LCOV_EXCL_LINE
+  NAString* getLocaleString() { return locale_strval; };
   NAWString* getLocaleWString() { return locale_wstrval; };
   virtual NABoolean hasEquivalentProperties(ItemExpr * other) { return TRUE;}
 
@@ -723,12 +723,10 @@ public:
   virtual ItemExpr * copyTopNode(ItemExpr *derivedNode = NULL,
 				 CollHeap* outHeap = 0);
 
-  // LCOV_EXCL_START
   // Safety net -- these methods should never be called because we should
   // never get so far as to use them.
   virtual const NAType * synthesizeType()    { CMPASSERT(FALSE); return NULL; }
   short codeGen(Generator*)		     { CMPASSERT(FALSE); return -1; }
-  // LCOV_EXCL_STOP
 
   const NAString getText() const	     { return "DEFAULT"; }
 
@@ -830,7 +828,7 @@ public:
   void setIsEnvVar(NABoolean isEV = TRUE)  { isEnvVar_ = isEV; }
 
   NABoolean isDefine() const		   { return isDefine_; }
-  void setIsDefine(NABoolean isDef = TRUE)  { isDefine_ = isDef; } // LCOV_EXCL_LINE
+  void setIsDefine(NABoolean isDef = TRUE)  { isDefine_ = isDef; }
 
   NABoolean isParam() const		   { return isParam_; }
   void setIsParam(NABoolean isParam = TRUE)  { isParam_ = isParam; }
@@ -842,7 +840,7 @@ public:
   NABoolean isSystemGeneratedOutputHV() const;
 
   NAString& getPrototypeValue() 	   { return prototypeValue_; }
-  const NAString& getPrototypeValue() const { return prototypeValue_; } // LCOV_EXCL_LINE
+  const NAString& getPrototypeValue() const { return prototypeValue_; }
   NABoolean hasPrototypeValue() const	   { return !prototypeValue_.isNull(); }
   void setPrototypeValue(const NAString &s){ prototypeValue_ = s; }
 
@@ -966,7 +964,6 @@ public:
 				    Int32 ordinalPosition,
 				    Int32 index);
 
-  // LCOV_EXCL_START
   // Param heading and tablename needed here for JDBC/WLI, when dynamic rowsets are used.
   const NAString &getParamHeading() const {  return heading_; }
 
@@ -981,7 +978,6 @@ public:
   { 
     tablename_ = tablename; 
   }
-  // LCOV_EXCL_STOP
 
 private:
 
@@ -1112,7 +1108,7 @@ class ConstantParameter : public Parameter
   virtual ItemExpr * copyTopNode(ItemExpr *derivedNode = NULL,
                                  CollHeap* outHeap = 0);
 
-  virtual ConstantParameter *castToConstantParameter() { return this; } // LCOV_EXCL_LINE
+  virtual ConstantParameter *castToConstantParameter() { return this; }
 
   NABoolean matches(ConstValue *val) const;
 
@@ -1446,7 +1442,6 @@ private:
 // A fake parameter used to represent the routines formal intputs and
 // actual output
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 class RoutineParam : public Parameter
 {
 
@@ -1477,7 +1472,6 @@ public:
       memset(argumentType_, 0, sizeof(argumentType_));
   }
 
-  // LCOV_EXCL_STOP
   RoutineParam(const NAString & paramName, const NAType *type, Lng32 pos, 
       ComColumnDirection direction, RoutineDesc *rdesc, CollHeap * h=0) 
     : Parameter(ITM_ROUTINE_PARAM), paramName_(paramName, h),

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItemConstr.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemConstr.h b/core/sql/optimizer/ItemConstr.h
index 25ee914..9d21aa8 100644
--- a/core/sql/optimizer/ItemConstr.h
+++ b/core/sql/optimizer/ItemConstr.h
@@ -205,7 +205,7 @@ public:
   const NAString &getConstraintText() const { return constraintText_; }
 
   NABoolean isViewWithCheckOption() const   { return isViewWithCheckOption_; }
-  void setViewWithCheckOption(NABoolean t)  { isViewWithCheckOption_ = t; } // LCOV_EXCL_LINE
+  void setViewWithCheckOption(NABoolean t)  { isViewWithCheckOption_ = t; }
   const QualifiedName &getCascadingViewName() const { return cascadingView_; }
   NABoolean isTheCascadingView() const 	    { return isViewWithCheckOption_ &&
   						getConstraintName() ==

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItemExpr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemExpr.cpp b/core/sql/optimizer/ItemExpr.cpp
index 565f6bf..31b8e58 100644
--- a/core/sql/optimizer/ItemExpr.cpp
+++ b/core/sql/optimizer/ItemExpr.cpp
@@ -165,12 +165,10 @@ NABoolean ExprValueId::operator== (const ItemExpr *other) const
 {
   return getPtr() == other;
 }
- // LCOV_EXCL_START
 NABoolean ExprValueId::operator== (const ValueId &other) const
 {
   return (getValueId() == other);
 }
- // LCOV_EXCL_STOP
 
 ValueId ExprValueId::getValueId() const
 {
@@ -182,7 +180,6 @@ ValueId ExprValueId::getValueId() const
   else
     return exprId_;
 }
- // LCOV_EXCL_START
 void ExprValueId::convertToMemoized()
 {
   // set this mode to prevent updates to it: a MEMOIZED object cannot
@@ -194,7 +191,6 @@ void ExprValueId::convertToStandalone()
 {
   exprMode_ = STANDALONE;
 }
- // LCOV_EXCL_STOP
 
 ItemExpr * ExprValueId::getPtr() const
 {
@@ -274,7 +270,6 @@ ItemExpr::~ItemExpr()
   (*counter_).decrementCounter();
 }
 
- // LCOV_EXCL_START
 void ItemExpr::transformToRelExpr(NormWA & normWARef,
                             ExprValueId & locationOfPointerToMe,
                             ExprGroupId & introduceSemiJoinHere,
@@ -284,7 +279,6 @@ void ItemExpr::transformToRelExpr(NormWA & normWARef,
    locationOfPointerToMe = this;
 
 }
- // LCOV_EXCL_STOP
 
 // operator[] is used to access the children of a tree
 ExprValueId & ItemExpr::operator[] (Lng32 index)
@@ -303,7 +297,6 @@ NABoolean ItemExpr::operator== (const ItemExpr& other) const	// virtual meth
 {
   return (getValueId() == other.getValueId());
 }
- // LCOV_EXCL_START
 void ItemExpr::deleteInstance()
 {
   Int32 nc = getArity();
@@ -311,7 +304,6 @@ void ItemExpr::deleteInstance()
     inputs_[i] = NULL;
   delete this;
 } // ItemExpr::deleteInstance()
- // LCOV_EXCL_STOP
 
 
 void ItemExpr::setChild(Lng32 index, ExprNode * newChild)
@@ -425,7 +417,7 @@ NABoolean ItemExpr::referencesTheGivenValue(const ValueId & vid,
       InstantiateNull *inst = (InstantiateNull *)nie->castToItemExpr();
 
       if (doNotDigInsideInstNulls)
-        return FALSE; // LCOV_EXCL_LINE
+        return FALSE;
       else
       {
         // Need to dig underneath the instantiate null to check if
@@ -808,12 +800,10 @@ ItemExpr * ItemExpr::createMirrorPred(ItemExpr *compColPtr,
             }
           else
             { // XXX print warning for now.
-              // LCOV_EXCL_START
 #ifdef DEBUG
               fprintf(stderr, "ItemExpr::createMirrorPred(): Didn't find any references to valueId: %d\n", tempV);
 #endif
               return NULL; 
-              // LCOV_EXCL_STOP
             }
           // now we want to replace the reference to the key column in the compExpr with the keyColExpr
 
@@ -1269,7 +1259,7 @@ ItemExpr * ItemExpr::copyTopNode(ItemExpr *derivedNode,
 
   if (derivedNode == NULL)
     {
-      ABORT("encountered an instantiation of an ItemExpr object"); // LCOV_EXCL_LINE
+      ABORT("encountered an instantiation of an ItemExpr object");
     }
   else
     result = derivedNode;
@@ -1557,7 +1547,6 @@ Lng32 ItemExpr::getTreeSize(Lng32& maxDepth, NABoolean giveUpThreshold)
   return currentSize;
 }
 
-// LCOV_EXCL_START : cnu
 // Find all eqaulity columns in an item expression tree.
 void ItemExpr::findEqualityCols(ValueIdSet& result)
 {
@@ -1594,7 +1583,6 @@ void ItemExpr::findEqualityCols(ValueIdSet& result)
     child(1)->findEqualityCols(result);
   }
 }
-// LCOV_EXCL_STOP
 
 ItemExpr * ItemExpr::treeWalk(ItemTreeWalkFunc f,
                               CollHeap *outHeap,
@@ -1742,7 +1730,6 @@ ValueId ItemExpr::mapAndRewriteCommon(ValueIdMap &map, NABoolean mapDownwards)
   return result;
 } // ItemExpr::mapAndRewriteCommon
 
-// LCOV_EXCL_START : cnu
 ItemExpr * ItemExpr::foldConstants(ComDiagsArea *diagsArea,
 				   NABoolean newTypeSynthesis)
 {
@@ -1779,7 +1766,6 @@ ItemExpr * ItemExpr::foldConstants(ComDiagsArea *diagsArea,
 
   return result;
 }
- // LCOV_EXCL_STOP
 
 ItemExpr * ItemExpr::applyInverseDistributivityLaw(
      OperatorTypeEnum backboneType,
@@ -1915,11 +1901,9 @@ ItemExpr * ItemExpr::connect2(OperatorTypeEnum op,
     case ITM_AND:
     case ITM_OR:
       return new(CmpCommon::statementHeap()) BiLogic(op, op1, op2);
-// LCOV_EXCL_START : cnu
     default:
       CMPASSERT("Operator type not supported by connect2" == 0);
       return NULL;
-// LCOV_EXCL_STOP
     }
 }
 
@@ -2248,7 +2232,6 @@ NABoolean ItemExpr::maxSelectivitySameAsSelectivity() const
     }
   return FALSE; 
 }
-// LCOV_EXCL_START
 void ItemExpr::print(FILE * f,
 		     const char * prefix,
 		     const char * suffix) const
@@ -2286,7 +2269,6 @@ void ItemExpr::display()
   unparse(result, PARSER_PHASE, USER_FORMAT_DELUXE);
   fprintf(stdout, "%s\n", result.data());
 }
-// LCOV_EXCL_STOP
 
 
 //
@@ -2661,7 +2643,7 @@ void ItemExpr::unparse(NAString &result,
           if (child(0))
             child(0)->unparse(result, phase,form, tabId);
           else
-            result += "NULL"; // LCOV_EXCL_LINE
+            result += "NULL";
 
           if (operatorType == ITM_POSITION)
             result += " IN ";
@@ -2671,7 +2653,7 @@ void ItemExpr::unparse(NAString &result,
           if (child(1))
             child(1)->unparse(result, phase, form, tabId);
           else
-            result += "NULL"; // LCOV_EXCL_LINE
+            result += "NULL";
           result += ")";
           break;
         } // STDDEV, MOD, VARIANCE

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItemExpr.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemExpr.h b/core/sql/optimizer/ItemExpr.h
index 6e5e57a..992a12a 100644
--- a/core/sql/optimizer/ItemExpr.h
+++ b/core/sql/optimizer/ItemExpr.h
@@ -106,10 +106,8 @@ public:
 
   // compare an ExprValueId with another ExprValueId or ItemExpr * or ValueId
   NABoolean operator == (const ExprValueId &other) const;
-  // LCOV_EXCL_START
   inline NABoolean operator != (const ExprValueId &other) const
                                            { return NOT operator == (other); }
-  //LCOV_EXCL_STOP
 
   NABoolean operator == (const ItemExpr *other) const;
   inline NABoolean operator != (const ItemExpr *other) const
@@ -411,10 +409,8 @@ public:
   // sure the expression is not used elsewhere.
   void unBind() { markAsUnBound(); setValueId(NULL_VALUE_ID); }
 
- // LCOV_EXCL_START
   virtual NABoolean isTypeComplete(const NAType*) { return TRUE; };
   virtual void reportTypeIsIncomplete() {};
- // LCOV_EXCL_STOP
 
   void bindChildren(BindWA *bindWA); // a method for binding the children
   void bindSelf(BindWA *bindWA); // a method for binding the children and self
@@ -1123,12 +1119,10 @@ public:
 
   virtual ConstantParameter *castToConstantParameter() { return NULL; }
 
-  // LCOV_EXCL_START
   // perform a safe type cast to RandomNum (return NULL ptr for illegal casts)
   virtual RandomNum *castToRandomNum() { return NULL; }
 
   virtual const SelParameter *castToSelParameter() const { return NULL; }
- // LCOV_EXCL_STOP
 
   // does this entire ItemExpr qualify query to be cacheable after this phase?
   virtual NABoolean isCacheableExpr(CacheWA& cwa);
@@ -1173,7 +1167,7 @@ public:
 // warning elimination (removed "inline")
   virtual void setPMOrdPosAndIndex( ComColumnDirection paramMode,
 					   Int32 ordinalPosition,
-                                    Int32 index) { CMPASSERT (0);} // LCOV_EXCL_LINE
+                                    Int32 index) { CMPASSERT (0);}
 
   NABoolean isARangePredicate() const;
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItmBitMuxFunction.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItmBitMuxFunction.cpp b/core/sql/optimizer/ItmBitMuxFunction.cpp
index d51bcee..6a77ec8 100644
--- a/core/sql/optimizer/ItmBitMuxFunction.cpp
+++ b/core/sql/optimizer/ItmBitMuxFunction.cpp
@@ -21,7 +21,6 @@
 // @@@ END COPYRIGHT @@@
 **********************************************************************/
 
-// LCOV_EXCL_START
 // This class is obsolete in the sense 
 // that it had been added long time ago during the data
 // mining days (late 90s) but is not used anymore
@@ -63,4 +62,3 @@ ItemExpr *ItmBitMuxFunction::copyTopNode(ItemExpr *derivedNode,
   return BuiltinFunction::copyTopNode(result, outHeap);
 };
 #pragma warn(770)  // warning elimination 
-// LCOV_EXCL_STOP

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItmBitMuxFunction.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItmBitMuxFunction.h b/core/sql/optimizer/ItmBitMuxFunction.h
index 28d8548..d2e5617 100644
--- a/core/sql/optimizer/ItmBitMuxFunction.h
+++ b/core/sql/optimizer/ItmBitMuxFunction.h
@@ -21,7 +21,6 @@
 #ifndef BitMuxFunction_h
 #define BitMuxFunction_h
 
-// LCOV_EXCL_START
 // This class is obsolete in the sense
 // that it had been added long time ago during the data
 // mining days (late 90s) but is not used anymore
@@ -54,7 +53,6 @@ public:
   ItemExpr *copyTopNode(ItemExpr *derivedNode =NULL,
 			NAMemory *outHeap =0);
 };
-// LCOV_EXCL_STOP
 
 #endif
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ItmFlowControlFunction.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItmFlowControlFunction.cpp b/core/sql/optimizer/ItmFlowControlFunction.cpp
index 09e4fa2..fc9a974 100644
--- a/core/sql/optimizer/ItmFlowControlFunction.cpp
+++ b/core/sql/optimizer/ItmFlowControlFunction.cpp
@@ -36,7 +36,6 @@ const NAType *ItmDoWhileFunction::synthesizeType() {
   return &child(0)->castToItemExpr()->getValueId().getType();
 };
 
-// LCOV_EXCL_START :dd
 // copyTopNode
 //
 #pragma nowarn(770)   // warning elimination 
@@ -53,7 +52,6 @@ ItemExpr *ItmDoWhileFunction::copyTopNode(ItemExpr *derivedNode,
   return BuiltinFunction::copyTopNode(result, outHeap);
 };
 #pragma warn(770)  // warning elimination 
-// LCOV_EXCL_STOP
 
 
 //
@@ -68,7 +66,6 @@ const NAType *ItmBlockFunction::synthesizeType() {
   return &child(1)->castToItemExpr()->getValueId().getType();
 };
 
-// LCOV_EXCL_START :dd
 // copyTopNode
 //
 #pragma nowarn(770)   // warning elimination 
@@ -85,7 +82,6 @@ ItemExpr *ItmBlockFunction::copyTopNode(ItemExpr *derivedNode,
   return BuiltinFunction::copyTopNode(result, outHeap);
 };
 #pragma warn(770)  // warning elimination 
-// LCOV_EXCL_STOP
 
 //
 // ItmWhile
@@ -97,7 +93,6 @@ const NAType *ItmWhileFunction::synthesizeType() {
   return &child(0)->castToItemExpr()->getValueId().getType();
 };
 
-// LCOV_EXCL_START :dd
 // copyTopNode
 //
 #pragma nowarn(770)   // warning elimination 
@@ -114,7 +109,6 @@ ItemExpr *ItmWhileFunction::copyTopNode(ItemExpr *derivedNode,
   return BuiltinFunction::copyTopNode(derivedNode, outHeap);
 };
 #pragma warn(770)  // warning elimination 
-// LCOV_EXCL_STOP
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/LargeScopeRules.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/LargeScopeRules.cpp b/core/sql/optimizer/LargeScopeRules.cpp
index 0e1c0e3..30cf4d2 100644
--- a/core/sql/optimizer/LargeScopeRules.cpp
+++ b/core/sql/optimizer/LargeScopeRules.cpp
@@ -48,7 +48,6 @@ extern THREAD_P NAUnsigned              MJStarJoinIRuleNumber;
 extern THREAD_P NAUnsigned              MJStarJoinIIRuleNumber;
 extern THREAD_P NAUnsigned              RoutineJoinToTSJRuleNumber;
 
-// LCOV_EXCL_START
 // Excluding MJExpandRule related code since it is there for testing purposes
 // MJExpandRule is not exercised during normal execution
 // -----------------------------------------------------------------------
@@ -113,7 +112,6 @@ Int32 MJExpandRule::promiseForOptimization (RelExpr * expr,
   // should be higher than the promise for MJEnumRule
   return DefaultTransRulePromise + 1;
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // methods for MVQRRule
@@ -435,7 +433,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
     // is there are jbbc that provides an equalizing join
     NABoolean guaranteedEqualizerPresent = FALSE;
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
     if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
          CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -444,7 +441,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
       CURRCONTEXT_OPTDEBUG->stream() << "Level " << mjoin->getArity() << ": " << childrenFlow.value() << endl;
     }
 #endif
-// LCOV_EXCL_STOP
 
     // allow cross product control if:
     // 1) cross_product_control is active AND
@@ -546,7 +542,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
 
       if ((newSubgraphs > mySubgraphs) && allowCrossProductControl)
       {
-// LCOV_EXCL_START
 #ifdef _DEBUG
         if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
              CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -554,7 +549,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
           CURRCONTEXT_OPTDEBUG->stream() << " Unnecessary Cross Product when joining right child" << (CollIndex) i << endl;
         }
 #endif
-// LCOV_EXCL_STOP
         continue;
       }
 
@@ -600,7 +594,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
 
       substituteRightChild[numSubstitutes] = i;
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
         if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
              CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -611,7 +604,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
           " is "<< substituteMetric2[numSubstitutes].value() << endl;
         }
 #endif
-// LCOV_EXCL_STOP
 
       // Remembering the substitutes with min metric
       if ((substituteMetric[numSubstitutes] < minSubstituteMetric) ||
@@ -781,7 +773,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
           (CURRSTMT_OPTDEFAULTS->optimizerHeuristic5()) && // Data Flow Optimization
           (substituteMetric[childIter] > DATA_FLOW_FACTOR_1 * minSubstituteMetric + DATA_FLOW_FACTOR_2))
       {
-// LCOV_EXCL_START
 #ifdef _DEBUG
         if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
              CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -792,7 +783,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
             << " >> "<< minSubstituteMetric.value() << endl;
         }
 #endif
-// LCOV_EXCL_STOP
         potentialSubstitutes[childIter] = NULL;
         numPrunedSubstitutes++;
         continue;
@@ -808,7 +798,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
 
         if (mjoin->getArity() > 2)
         {
-// LCOV_EXCL_START
 #ifdef _DEBUG
           if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
                CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -820,7 +809,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
                << " ---- "<< minSubstituteMetric2.value() << endl;
           }
 #endif
-// LCOV_EXCL_STOP
           potentialSubstitutes[childIter] = NULL;
           numPrunedSubstitutes++;
           continue;
@@ -958,7 +946,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
     {
       RelExpr* substitute = resultPotentialSubstitutes[childIter];
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
         if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
              CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -969,7 +956,6 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
             << " ~~ "<< minSubstituteMetric.value() << endl;
         }
 #endif
-// LCOV_EXCL_STOP
       Int32 combinedPotential = groupPotential + potential;
 
       substitute->updatePotential(potential);
@@ -1064,7 +1050,6 @@ NABoolean MJStarJoinIRule::topMatch (RelExpr * expr,
      (!mjoin->scheduledLSRs().contains(MJStarJoinIRuleNumber)))
     return FALSE;
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -1074,7 +1059,6 @@ NABoolean MJStarJoinIRule::topMatch (RelExpr * expr,
     CURRCONTEXT_OPTDEBUG->stream() << "Superset is : " << mjoin->getJBBSubset().getJBB()->getMainJBBSubset().getText() << endl;
   }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
 
   // get a handle to the JBBSubset Analysis for the JBBSubset
   // represented by this MultiJoin (i.e. mjoin)
@@ -1086,7 +1070,6 @@ NABoolean MJStarJoinIRule::topMatch (RelExpr * expr,
 
   if (mjoinAnalysis->starJoinTypeIFeasible())
   {
-// LCOV_EXCL_START
 #ifdef _DEBUG
     if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
          CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -1095,12 +1078,10 @@ NABoolean MJStarJoinIRule::topMatch (RelExpr * expr,
       CURRCONTEXT_OPTDEBUG->stream() << "MJStarJoinIRule_TopMatch_End" <<endl;
     }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
     return TRUE;
   }
   else {
     mjoin->scheduledLSRs() += MJStarJoinIIRuleNumber;
-// LCOV_EXCL_START
 #ifdef _DEBUG
     if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
          CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -1110,12 +1091,10 @@ NABoolean MJStarJoinIRule::topMatch (RelExpr * expr,
       CURRCONTEXT_OPTDEBUG->stream() << "MJStarJoinIRule_TopMatch_End" <<endl;
     }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
   }
   return FALSE;
 }
 
-// LCOV_EXCL_START
 // the old topMatch method of MJStarJoinIRule, 
 // not used anymore this code is OFF by default
 NABoolean MJStarJoinIRule::topMatch_Old (RelExpr * expr,
@@ -1286,7 +1265,6 @@ NABoolean MJStarJoinIRule::topMatch_Old (RelExpr * expr,
 
   return TRUE;
 }
-// LCOV_EXCL_STOP
 
 RelExpr * MJStarJoinIRule::nextSubstitute(RelExpr * before,
                                           Context * context,
@@ -1295,7 +1273,6 @@ RelExpr * MJStarJoinIRule::nextSubstitute(RelExpr * before,
   if (CmpCommon::getDefault(COMP_BOOL_115) == DF_ON)
     return nextSubstitute_Old(before, context, memory);
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -1303,7 +1280,6 @@ RelExpr * MJStarJoinIRule::nextSubstitute(RelExpr * before,
     CURRCONTEXT_OPTDEBUG->stream() << "MJStarJoinIRule_nextSubstitute_Begin" <<endl;
   }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
 
   MultiJoin * mjoin = (MultiJoin *) before;
 
@@ -1411,7 +1387,6 @@ RelExpr * MJStarJoinIRule::nextSubstitute(RelExpr * before,
   RelExpr * result = mjoin->createLeftLinearJoinTree(leftDeepJoinSequence,
                                                      &joinDirectives);
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -1419,12 +1394,10 @@ RelExpr * MJStarJoinIRule::nextSubstitute(RelExpr * before,
     CURRCONTEXT_OPTDEBUG->stream() << "MJStarJoinIRule_nextSubstitute_End" <<endl;
   }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
 
   return result;
 }
 
-// LCOV_EXCL_START
 // This is old code, most of this work in now done during
 // analysis. This functionality was moved to the analysis
 // phase as part of Adaptive Segmentation. Since we need
@@ -2870,7 +2843,6 @@ void MJStarJoinIRule::sortMJJBBCs(NAList<CANodeId> &sortedJBBCs,const MultiJoin
   }
 
 };//MJStarJoinIRule::sortMJJBBCs
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // methods for MJStarJoinIIRule
@@ -2896,7 +2868,6 @@ NABoolean MJStarJoinIIRule::topMatch (RelExpr * expr,
   if(!mjoin->scheduledLSRs().contains(MJStarJoinIIRuleNumber))
     return FALSE;
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -2906,7 +2877,6 @@ NABoolean MJStarJoinIIRule::topMatch (RelExpr * expr,
     CURRCONTEXT_OPTDEBUG->stream() << "Superset is : " << mjoin->getJBBSubset().getJBB()->getMainJBBSubset().getText() << endl;
   }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
 
   // get a handle to the JBBSubset Analysis for the JBBSubset
   // represented by this MultiJoin (i.e. mjoin)
@@ -2916,7 +2886,6 @@ NABoolean MJStarJoinIIRule::topMatch (RelExpr * expr,
 
   mjoinAnalysis->analyzeInitialPlan();
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -2924,7 +2893,6 @@ NABoolean MJStarJoinIIRule::topMatch (RelExpr * expr,
     CURRCONTEXT_OPTDEBUG->stream() << "MJStarJoinIIRule_TopMatch_End" <<endl;
   }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
 
   return TRUE;
 }
@@ -2936,7 +2904,6 @@ RelExpr * MJStarJoinIIRule::nextSubstitute(RelExpr * before,
   if (CmpCommon::getDefault(COMP_BOOL_115) == DF_ON)
     return nextSubstitute_Old(before, context, memory);
 
-// LCOV_EXCL_START
 #ifdef _DEBUG
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
@@ -2944,7 +2911,6 @@ RelExpr * MJStarJoinIIRule::nextSubstitute(RelExpr * before,
     CURRCONTEXT_OPTDEBUG->stream() << "MJStarJoinIIRule_nextSubstitute_Begin" <<endl;
   }
 #endif //_DEBUG
-// LCOV_EXCL_STOP
 
   MultiJoin * mjoin = (MultiJoin *) before;
 
@@ -3031,7 +2997,6 @@ RelExpr * MJStarJoinIIRule::nextSubstitute(RelExpr * before,
                                          &joinDirectives);
 }
 
-// LCOV_EXCL_START
 // Below is the old nextSubstitute. The code is not exercised any more
 RelExpr * MJStarJoinIIRule::nextSubstitute_Old(RelExpr * before,
                                                Context * context,
@@ -3321,9 +3286,7 @@ RelExpr * MJStarJoinIIRule::nextSubstitute_Old(RelExpr * before,
   return mjoin->createLeftLinearJoinTree(&leftDeepJoinSequence,
                                          &joinDirectives);
 }
-// LCOV_EXCL_STOP
 
-// LCOV_EXCL_START
 // This class was used by old code, that is not exercised anymore
 MJRulesWA::MJRulesWA(JBBSubsetAnalysis * analysis)
 {
@@ -3344,4 +3307,3 @@ MJRulesWA::MJRulesWA(JBBSubsetAnalysis * analysis)
   largestTable_ = NULL_CA_ID;
   largestNode_ = NULL_CA_ID;
 }
-// LCOV_EXCL_STOP

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MVCandidates.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVCandidates.cpp b/core/sql/optimizer/MVCandidates.cpp
index c11f4de..64e224b 100644
--- a/core/sql/optimizer/MVCandidates.cpp
+++ b/core/sql/optimizer/MVCandidates.cpp
@@ -55,7 +55,6 @@ MVCandidates::MVCandidates(RelRoot* root,
     bjScanHash_(bjScanHashFn, 17, TRUE, QueryAnalysis::Instance()->outHeap())
 {}
 
-// LCOV_EXCL_START :cnu
 Int32 MVCandidates::nodeCount(ExprNode* node)
 {
   // Recurse for each child, and add one for the current node.
@@ -67,7 +66,6 @@ Int32 MVCandidates::nodeCount(ExprNode* node)
 
   return nodes + 1;
 }
-// LCOV_EXCL_STOP
 
 // extract the list of candidate MVs from the value of the MVQR_REWRITE_CANDIDATES CQD
 void MVCandidates::buildFavoritesList (CollHeap* heap)
@@ -135,7 +133,7 @@ GroupByAgg* MVCandidates::getGroupByAggNode(RelExpr* childNode,
                                        	 candidate->getMVName()->getMVName(),
                                          heap));
       else
-        assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                            FALSE, MVCandidateException,
 			   "Unexpected element type for grouping item -- %d",
 			   elemType)
@@ -326,7 +324,7 @@ ItemExpr* MVCandidates::rewriteItemExpr(const ElementPtrList& mvColumns,
                 break;
 
               default:
-                assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+                assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                                    FALSE, MVCandidateException,
                                    "rewriteItemExpr() not ready for element of type %d",
                                    mvColumns[i]->getElementType());
@@ -444,7 +442,7 @@ static OperatorTypeEnum determineAggForRollup(QRMVColumnPtr mvCol)
 	    break;
 
           default: 
-            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                               FALSE, MVCandidateException,
                                "Can't rewrite this agg func for rollup: %d",
                                itemExpr->getOperatorType());
@@ -548,7 +546,7 @@ void MVCandidates::rewriteRangePreds(QRCandidatePtr candidate,
                                                heap);
               }
             else
-              assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+              assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                                  FALSE, MVCandidateException,
                                  "Not ready for range item with element type %d",
                                  rangeItem->getElementType())
@@ -567,7 +565,7 @@ void MVCandidates::rewriteRangePreds(QRCandidatePtr candidate,
             break;
 
           default:
-            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL, 
                                FALSE, MVCandidateException,
                                "Unknown value for result attribute -- %d",
                                rangePred->getResult());
@@ -685,7 +683,7 @@ void MVCandidates::rewriteResidPreds(QRCandidatePtr candidate,
             break;
 
           default:
-            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL, 
                                FALSE, MVCandidateException,
                                "Unknown value for result attribute -- %d",
                                residPred->getResult());
@@ -733,7 +731,7 @@ ColRefName* MVCandidates::getColRefName(QRCandidatePtr candidate,
     }
   else
     throw QRDescriptorException("getColRefName() cannot be called for element %s",
-                                elem->getElementName());  // LCOV_EXCL_LINE :rfi
+                                elem->getElementName());
 
   return returnVal;
 } // getColRefName()
@@ -871,7 +869,7 @@ void MVCandidates::buildOutputExprs(QRCandidatePtr candidate,
             break;
 
           default:
-            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+            assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                                FALSE, MVCandidateException,
                                "Unknown value for result attribute -- %d",
                                output->getResult());
@@ -947,7 +945,6 @@ void MVCandidates::analyzeCandidateMVs(QRJbbSubsetPtr qrJbbSubset)
                            rewriteSingleNode,
                            jbbNodeSet, heap);
         }
-      // LCOV_EXCL_START :rfi
       catch (MVCandidateException&)
         {
           // Throwers of this exception should use one of the macros that logs the
@@ -957,7 +954,6 @@ void MVCandidates::analyzeCandidateMVs(QRJbbSubsetPtr qrJbbSubset)
             "Skipping candidate MV %s due to exception",
                       candidate->getMVName()->getMVName().data());
         }
-      // LCOV_EXCL_STOP
     }
 
   delete actualJbbSubset;
@@ -977,7 +973,7 @@ ValueId MVCandidates::getRewriteVid(RETDesc* retDesc,
         return retDesc->getValueId(i);
     }
     
-  assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+  assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                     FALSE, MVCandidateException,
                     "Column in <Output> element of result descriptor not found "
                     "in column descriptor list");
@@ -1020,7 +1016,7 @@ ValueId MVCandidates::getBaseColValueId(QRElementPtr referencingElem)
       someMemberId.getItemExpr()->getOperatorType() == ITM_BASECOLUMN) 
     return someMemberId;
 
-  assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+  assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                      FALSE, MVCandidateException,
                      "No base column found in vegref referenced by %s",
                      ref.data());
@@ -1109,7 +1105,7 @@ void MVCandidates::populateOneVidMap(RelExpr* root,
               vidMap.addMapEntry(vegrefVid, ie->getValueId());
             }
           else
-            assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+            assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                               FALSE, MVCandidateException,
                               "Unable to get vegref for map value id lower value")
           baseColVid = getBaseColValueId(elem);
@@ -1119,7 +1115,7 @@ void MVCandidates::populateOneVidMap(RelExpr* root,
   }
   else
   {
-     assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+     assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                        FALSE, MVCandidateException,
                        "Expecting a base column while constructing map value id lower value")
   }
@@ -1151,7 +1147,6 @@ void MVCandidates::populateVidMap(RelExpr* root,
       else if (elemType == ET_Expr)
         {
           expr = elem->downCastToQRExpr();
-          // LCOV_EXCL_START :rfi
           if (expr->getExprRoot()->isAnAggregate())
             {
               // These have already been taken care of and shouldn't be in the
@@ -1160,7 +1155,6 @@ void MVCandidates::populateVidMap(RelExpr* root,
                                 FALSE, MVCandidateException,
                                 "Aggregate function found in top value list");
             }
-          // LCOV_EXCL_STOP
           else
             {
               const ElementPtrList& colsUsed = expr->getInputColumns(heap, FALSE);
@@ -1172,7 +1166,7 @@ void MVCandidates::populateVidMap(RelExpr* root,
             }
         }
       else
-        assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                           FALSE, MVCandidateException,
                           "Output item is neither Column, MVColumn nor expression")
     }
@@ -1327,13 +1321,11 @@ ItemExpr* MVCandidates::getIGBJoinCondOp(QRElementPtr elem,
                                          NABoolean& fromFactTable,
                                          CollHeap* heap)
 {
-  // LCOV_EXCL_START :rfi
   if (elem->getElementType() != ET_Column)
     assertLogAndThrow1(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                        FALSE, MVCandidateException,
                        "Can only handle column join condition operands, not %d",
                        elem->getElementType());
-  // LCOV_EXCL_STOP
 
   QRElementPtr outputItem;
   QRColumnPtr col = elem->getReferencedElement()->downCastToQRColumn();
@@ -1358,7 +1350,7 @@ ItemExpr* MVCandidates::getIGBJoinCondOp(QRElementPtr elem,
                                                             mvCol, heap));
             }
         }
-      assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+      assertLogAndThrow(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
                         FALSE, MVCandidateException,
                         "Could not find join operand from fact table for "
                         "indirect Group By query");
@@ -1701,7 +1693,6 @@ void MVCandidates::analyzeCandidate(QRCandidatePtr candidate,
   // Bind the replacement tree.
   marker = CmpCommon::diags()->mark();
   RelExpr* boundRoot = root->bindNode(bindWA_);
-  // LCOV_EXCL_START :rfi
   if (bindWA_->errStatus())
   {
     QRLogger::log(CAT_SQL_COMP_MVCAND, LL_MVQR_FAIL,
@@ -1720,7 +1711,6 @@ void MVCandidates::analyzeCandidate(QRCandidatePtr candidate,
     deletePtr(match);
     return;
   }
-  // LCOV_EXCL_STOP
 
   // queryRoot_->getStoiList().insert(scan->getOptStoi());
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MVCandidates.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVCandidates.h b/core/sql/optimizer/MVCandidates.h
index c1d793e..9b8b0ad 100644
--- a/core/sql/optimizer/MVCandidates.h
+++ b/core/sql/optimizer/MVCandidates.h
@@ -64,7 +64,6 @@ typedef NAHashDictionary<CollIndex, Scan> NodeIdScanHash;
  * file.
  */
 
-// LCOV_EXCL_START :rfi
 /**
  * Exception thrown when a candidate in the result descriptor must be discarded
  * because an internal error occurred when processing it, or it requires a
@@ -95,7 +94,6 @@ class MVCandidateException : public QRException
     {}
 
 }; //MVCandidateException
-// LCOV_EXCL_STOP
 
 /**
  * Class used to analyze the result descriptor corresponding to a match

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MVInfo.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVInfo.cpp b/core/sql/optimizer/MVInfo.cpp
index 4cc3e70..515a70f 100644
--- a/core/sql/optimizer/MVInfo.cpp
+++ b/core/sql/optimizer/MVInfo.cpp
@@ -346,7 +346,6 @@ NABoolean ViewColumnConnection::operator==(const ViewColumnConnection &other) co
 //============================================================================
 // ViewColumnConnection and ViewTableConnection classes ignored from coverage
 // testing until MV on view is supported.
-// LCOV_EXCL_START
 
 //----------------------------------------------------------------------------
 ViewTableConnection::~ViewTableConnection()
@@ -637,7 +636,6 @@ void ViewColumnGraph::display() const
 
 #endif
 
-// LCOV_EXCL_STOP
 
 //============================================================================
 //=======================  class MVVegPredicateColumn ========================
@@ -673,7 +671,6 @@ MVVegPredicateColumn::MVVegPredicateColumn(const BaseColumn  *baseCol,
 //////////////////////////////////////////////////////////////////////////////
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVVegPredicateColumn::print(FILE* ofd, const char* indent, const char* title) const
 {
   NAString tableText =  getTableName().getQualifiedNameAsString();
@@ -700,7 +697,6 @@ void MVVegPredicateColumn::display() const
 {
   print();
 }
-// LCOV_EXCL_STOP
 #endif
 
 //============================================================================
@@ -1000,7 +996,6 @@ void MVVegPredicate::insert(const MVVegPredicateColumn *newCol)
 //////////////////////////////////////////////////////////////////////////////
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVVegPredicate::print(FILE* ofd, const char* indent, const char* title) const
 {
   fprintf(ofd, "\tVegPredicate:");
@@ -1017,7 +1012,6 @@ void MVVegPredicate::display() const
 {
   print();
 }
-// LCOV_EXCL_STOP
 #endif
 
 //============================================================================
@@ -1217,7 +1211,6 @@ NABoolean MVUsedObjectInfo::processSelectionPredicates(ValueIdSet&  expr,
 // ---------------------------------------------------------------------
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVUsedObjectInfo::print( FILE* ofd,	  // = stdout,
 			      const char* indent, // = DEFAULT_INDENT,
 			      const char* title   // = "MVInfo"
@@ -1266,7 +1259,6 @@ void MVUsedObjectInfo::display() const
 { 
   print(); 
 }
-// LCOV_EXCL_STOP
 #endif
 
 //============================================================================
@@ -2220,7 +2212,6 @@ NABoolean MVColumnInfo::isNonRepeatableExpressionUsed(BindWA *bindWA)
 // ---------------------------------------------------------------------
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVColumnInfo::print( FILE* ofd,          //  = stdout,
 			  const char* indent, // = DEFAULT_INDENT,
 			  const char* title
@@ -2280,7 +2271,6 @@ void MVColumnInfo::display() const
 { 
   print(); 
 }
-// LCOV_EXCL_STOP
 #endif
 
 //============================================================================
@@ -2524,7 +2514,6 @@ void MVColumns::setNewColumnName(MVColumnInfo *colInfo, const NAString& newName)
 //////////////////////////////////////////////////////////////////////////////
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVColumns::print( FILE* ofd,          //  = stdout,
 		       const char* indent, // = DEFAULT_INDENT,
 		       const char* title
@@ -2547,7 +2536,6 @@ void MVColumns::display() const
 { 
   print(); 
 }
-// LCOV_EXCL_STOP
 #endif
 
 //============================================================================
@@ -2960,7 +2948,6 @@ NABoolean MVInfo::addTableNamesToList(BindWA        *bindWA,
 //////////////////////////////////////////////////////////////////////////////
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVInfo::print( FILE* ofd,		// = stdout,
 		    const char* indent, // = DEFAULT_INDENT,
 		    const char* title   // = "MVInfo"
@@ -3020,7 +3007,6 @@ void MVInfo::display() const
 { 
   print(); 
 }
-// LCOV_EXCL_STOP
 #endif
 
 // - functions used in showddl
@@ -4750,7 +4736,6 @@ void MVInfoForDDL::setColAsIndirectUpdate(MVColumnInfo *colInfo)
 //////////////////////////////////////////////////////////////////////////////
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVInfoForDDL::print( FILE* ofd,	      // = stdout,
 			  const char* indent, // = DEFAULT_INDENT,
 			  const char* title   // = "MVInfo"
@@ -4773,7 +4758,6 @@ void MVInfoForDDL::print( FILE* ofd,	      // = stdout,
   }
   fprintf(ofd,"\n");
 } // MVInfoForDDL::print()
-// LCOV_EXCL_STOP
 #endif
 
 //============================================================================
@@ -4981,7 +4965,6 @@ const MVUsedObjectInfo *MVInfoForDML::findUsedInfoForTable(const QualifiedName&
 //////////////////////////////////////////////////////////////////////////////
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MVInfoForDML::print( FILE* ofd,	      // = stdout,
 			  const char* indent, // = DEFAULT_INDENT,
 			  const char* title   // = "MVInfo"
@@ -4992,7 +4975,6 @@ void MVInfoForDML::print( FILE* ofd,	      // = stdout,
 
   if (strcmp(title, "")) fprintf(ofd,"\n");
 } // MVInfoForDDL::print()
-// LCOV_EXCL_STOP
 #endif
 
 //----------------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MjvBuilder.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MjvBuilder.cpp b/core/sql/optimizer/MjvBuilder.cpp
index 96c394c..f3bd522 100644
--- a/core/sql/optimizer/MjvBuilder.cpp
+++ b/core/sql/optimizer/MjvBuilder.cpp
@@ -1223,7 +1223,6 @@ ItemExpr *MjvOnRequestBuilder::buildSelectionListForScanOnIudLog() const
 // by the INDIRECT predicate.
 //----------------------------------------------------------------------------
 // Exclude from coverge testing - used only for range logging
-// LCOV_EXCL_START
 RelRoot *MjvOnRequestBuilder::buildRootOverIUDLog(RelExpr *topNode) const
 {
   ItemExpr *OperationTypeCol = new(heap_) 
@@ -1239,7 +1238,6 @@ RelRoot *MjvOnRequestBuilder::buildRootOverIUDLog(RelExpr *topNode) const
   result->addCompExprTree(IndirectCol);
   return result;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // We get here when we need to read from the Range log.
@@ -1248,7 +1246,6 @@ RelRoot *MjvOnRequestBuilder::buildRootOverIUDLog(RelExpr *topNode) const
 // by the INDIRECT predicate.
 //----------------------------------------------------------------------------
 // Exclude from coverge testing - used only for range logging
-// LCOV_EXCL_START
 RelRoot *MjvOnRequestBuilder::buildRootOverRangeBlock(RelExpr *topNode) const
 {
   ItemExpr *OperationTypeCol = new(heap_) 
@@ -1264,7 +1261,6 @@ RelRoot *MjvOnRequestBuilder::buildRootOverRangeBlock(RelExpr *topNode) const
   result->addCompExprTree(IndirectCol);
   return result;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Have a uniform select list over the logs
@@ -1274,7 +1270,6 @@ RelRoot *MjvOnRequestBuilder::buildRootOverRangeBlock(RelExpr *topNode) const
 // We do get here for the insertion part, where we must not have @OP.
 //----------------------------------------------------------------------------
 // Exclude from coverge testing - used only for range logging
-// LCOV_EXCL_START
 RelRoot *MjvOnRequestBuilder::buildRootWithUniformSelectList(RelExpr *topNode,
 							  ItemExpr *opExpr,
 							  const CorrName *nameOverride) const
@@ -1288,7 +1283,6 @@ RelRoot *MjvOnRequestBuilder::buildRootWithUniformSelectList(RelExpr *topNode,
 
   return new(heap_) RelRoot(topNode, REL_ROOT, rootSelectList);
 }
-// LCOV_EXCL_STOP
 
 
 // ===========================================================================

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MultiJoin.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MultiJoin.cpp b/core/sql/optimizer/MultiJoin.cpp
index dc8bbce..7eae8f3 100644
--- a/core/sql/optimizer/MultiJoin.cpp
+++ b/core/sql/optimizer/MultiJoin.cpp
@@ -73,7 +73,6 @@ MultiJoin::MultiJoin(const JBBSubset & jbbSubset,
 #pragma warning (default : 4018)  //warning elimination
 }
 
-// LCOV_EXCL_START  - cnu
 NABoolean MultiJoin::isSymmetricMultiJoin() const
 {
   // now all are inners non semi
@@ -89,7 +88,6 @@ void MultiJoin::pushdownCoveredExpr(const ValueIdSet & outputExpr,
 {
   CMPASSERT(0);
 } // MultiJoin::pushdownCoveredExpr
-// LCOV_EXCL_STOP
 
 void MultiJoin::getPotentialOutputValues(ValueIdSet & outputValues) const
 {
@@ -112,12 +110,10 @@ void MultiJoin::getPotentialOutputValues(ValueIdSet & outputValues) const
   }
 } // MultiJoin::getPotentialOutputValues()
 
-// LCOV_EXCL_START  - dpm
 const NAString MultiJoin::getText() const
 {
   return NAString("multi_join");
 } // MultiJoin::getText()
-// LCOV_EXCL_STOP
 
 HashValue MultiJoin::topHash()
 {
@@ -638,10 +634,8 @@ Join* MultiJoin::createLeftLinearJoinTree
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
   {
-// LCOV_EXCL_START - dpm
     CURRCONTEXT_OPTDEBUG->stream() << "Following is left deep join sequence: " << endl;
     CURRCONTEXT_OPTDEBUG->stream() << endl;
-// LCOV_EXCL_STOP
   }
 #endif
 
@@ -665,7 +659,7 @@ Join* MultiJoin::createLeftLinearJoinTree
     if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
     {
-      CURRCONTEXT_OPTDEBUG->stream() << ((*leftDeepJoinSequence)[i]).getText() << endl; // LCOV_EXCL_LINE - dpm
+      CURRCONTEXT_OPTDEBUG->stream() << ((*leftDeepJoinSequence)[i]).getText() << endl;
     }
 #endif
     //Get JBBSubset for left side of join
@@ -704,10 +698,8 @@ Join* MultiJoin::createLeftLinearJoinTree
   if ( CmpCommon::getDefault( NSK_DBG ) == DF_ON  &&
        CmpCommon::getDefault( NSK_DBG_MJRULES_TRACKING ) == DF_ON )
   {
-// LCOV_EXCL_START  - dpm
     CURRCONTEXT_OPTDEBUG->stream() << ((*leftDeepJoinSequence)[(numJoinChildren-1)]).getText() << endl;
     CURRCONTEXT_OPTDEBUG->stream() << endl;
-// LCOV_EXCL_STOP
   }
 #endif
 
@@ -734,7 +726,6 @@ Join* MultiJoin::createLeftLinearJoinTree
 // method for testing purpose right now.
 // Uses left linearize for expanding
 // ----------------------------------------------------------------
-// LCOV_EXCL_START - cnu
 RelExpr* MultiJoin::expandMultiJoinSubtree()
 {
   // Use default implementation to invoke call on children
@@ -744,7 +735,6 @@ RelExpr* MultiJoin::expandMultiJoinSubtree()
   Join* result = leftLinearize();
   return result;
 }
-// LCOV_EXCL_STOP
 
 // Methods for class MJJoinDirective
 MJJoinDirective::MJJoinDirective(CollHeap *outHeap):
@@ -807,12 +797,10 @@ const ExprGroupId &
       return array_[i]->getExprGroupId();
     }
   }
-  // LCOV_EXCL_START 
   // Assert on invalid request
   CMPASSERT(FALSE);
   ExprGroupId* dummyResult = new(CmpCommon::statementHeap()) ExprGroupId;
   return *dummyResult;
-  // LCOV_EXCL_STOP
 }
 
 // ---------------------------------------------------------------
@@ -1015,7 +1003,6 @@ void MultiJoin::synthLogPropWithMJReuse(NormWA * normWAPtr)
 // synthEstLogProp
 // -----------------------------------------------------------------------
 
-// LCOV_EXCL_START 
 // Used for other RelExpr but not MultiJoin
 void MultiJoin::synthEstLogProp(const EstLogPropSharedPtr& inputEstLogProp)
 {
@@ -1030,7 +1017,6 @@ void MultiJoin::synthEstLogProp(const EstLogPropSharedPtr& inputEstLogProp)
   
   getGroupAttr()->addInputOutputLogProp (inputEstLogProp, myEstLogProp, NULL);
 } // MultiJoin::synthEstLogProp
-// LCOV_EXCL_STOP
 
 
 void MultiJoin::addLocalExpr(LIST(ExprNode *) &xlist,
@@ -1124,7 +1110,6 @@ void MultiJoin::analyzeInitialPlan()
 // ---------------------------------------------------------------------
 // MultiJoinTester methods
 // ---------------------------------------------------------------------
-// LCOV_EXCL_START - cnu
 NABoolean MultiJoinTester::Test1(RelExpr* originalNonMultiJoinTree, RelExpr* treeConvertedToMultiJoin)
 {
   RelExpr* treeCopy = treeConvertedToMultiJoin->copyRelExprTree(CmpCommon::statementHeap());
@@ -1135,4 +1120,3 @@ NABoolean MultiJoinTester::Test1(RelExpr* originalNonMultiJoinTree, RelExpr* tre
   CMPASSERT(originalNonMultiJoinTree->duplicateMatch(*treeCopy));
   return TRUE;
 }
-// LCOV_EXCL_STOP