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:00 UTC

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

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MultiJoin.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MultiJoin.h b/core/sql/optimizer/MultiJoin.h
index 9e9f6df..1e539b2 100644
--- a/core/sql/optimizer/MultiJoin.h
+++ b/core/sql/optimizer/MultiJoin.h
@@ -62,11 +62,9 @@ public:
     heap_(outHeap)
   {}
 
-// LCOV_EXCL_START :dd
   // Destructor
   ~JBBCExprGroupEntry()
   {}
-// LCOV_EXCL_STOP
 
   ExprGroupId & getExprGroupId()
   {
@@ -305,14 +303,12 @@ public:
     return jbbSubset_;
   }
 
-  // LCOV_EXCL_START 
   // code no longer used. Used to be called from LargeScopeRules.cpp method
   // MJStarJoinIRule::computeCostForFactTable but this code is no longer used
   ExprGroupId getChildFromJBBCId(CANodeId jbbc) const
   {
     return childrenMap_.getExprGroupIdOfJBBC(jbbc);
   }
-  // LCOV_EXCL_STOP
 
   Join * getPreferredJoin();
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MvLog.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvLog.cpp b/core/sql/optimizer/MvLog.cpp
index c648853..bc99cad 100644
--- a/core/sql/optimizer/MvLog.cpp
+++ b/core/sql/optimizer/MvLog.cpp
@@ -48,7 +48,6 @@
 #include "ComMvAttributeBitmap.h"
 
 // MVLOG command is not supported
-// LCOV_EXCL_START
 
 #pragma nowarn(1000)   // warning elimination 
 const MvLogInternalNames MvLog::internalNames_;
@@ -1409,4 +1408,3 @@ void MvLog::appendToExprList(ItemExprList&            toAddto,
 				emptyCorrName_);
 }
 
-// LCOV_EXCL_STOP

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MvLog.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvLog.h b/core/sql/optimizer/MvLog.h
index 3054d28..ed9314c 100644
--- a/core/sql/optimizer/MvLog.h
+++ b/core/sql/optimizer/MvLog.h
@@ -39,7 +39,6 @@
 #include "RelMisc.h"
 
 // MVLOG command is not supported
-// LCOV_EXCL_START
 
 class MvLogInternalNames;
 
@@ -248,6 +247,5 @@ private:
   static const char simpleRangeTuple_[];
 };  // class MvLogInternalNames
 
-// LCOV_EXCL_STOP
 
 #endif // MVLOG_H

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvMultiTxnMavBuilder.cpp b/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
index 20bd4c4..0ae276f 100644
--- a/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
+++ b/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
@@ -315,7 +315,6 @@ RelExpr *MvMultiTxnMavBuilder::buildReadIudLogBlock()
 // Ofcourse that sorting the range log records is must cheaper then sorting 
 // the table records after the join.
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 Union *MvMultiTxnMavBuilder::buildUnionBetweenRangeAndIudBlocks(RelExpr *scanIUDLogBlock,
 							      RelExpr *scanRangeLogBlock) const
 {
@@ -324,16 +323,13 @@ Union *MvMultiTxnMavBuilder::buildUnionBetweenRangeAndIudBlocks(RelExpr *scanIUD
 
   return unionNode;
 }  // MvMultiTxnMavBuilder::buildUnionBetweenRangeAndIudBlocks()
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 NABoolean MvMultiTxnMavBuilder::needAlternateCIorder() const
 {
   return TRUE;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 ItemExpr *MvMultiTxnMavBuilder::buildSelectionListForScanOnIudLog() const
@@ -688,7 +684,6 @@ RelExpr *MvMultiTxnMavBuilder::buildInsertContextNode()
 // b) Catchup predicates
 // c) Phase1 predicates
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvMultiTxnMavBuilder::buildSelectionPredicateForScanOnRangeLog() const
 {
   // a)
@@ -728,7 +723,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildSelectionPredicateForScanOnRangeLog() const
  
   return result;
 }
-// LCOV_EXCL_STOP
 
 //////////////////////////////////////////////////////////////////////////////
 // Add the following selection predicate to the Scan of the range log for 
@@ -737,7 +731,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildSelectionPredicateForScanOnRangeLog() const
 //
 // Predicate a) is only added for Catchup activations.
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvMultiTxnMavBuilder::buildCatchupSelectionPredicateForScanOnRangeLog() const
 {
   // a)
@@ -757,7 +750,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildCatchupSelectionPredicateForScanOnRangeLog(
   return predA;
 
 } // MvMultiTxnMavBuilder::buildCatchupSelectionPredicateForScanOnRangeLog()
-// LCOV_EXCL_STOP
 
 //////////////////////////////////////////////////////////////////////////////
 // Add the following selection predicate to the Scan of the range log for 
@@ -773,7 +765,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildCatchupSelectionPredicateForScanOnRangeLog(
 // range type. When the upper boundary of the range is closed, the condition
 // is >=, otherwise it is >.
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvMultiTxnMavBuilder::buildPhase1SelectionPredicateForScanOnRangeLog() const
 {
   // a)
@@ -813,7 +804,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildPhase1SelectionPredicateForScanOnRangeLog()
   return new(heap_) BiLogic(ITM_AND, predB, predC);
 
 }  // MvMultiTxnMavBuilder::buildPhase1SelectionPredicateForScanOnRangeLog()
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // For multi transactional refresh, there are two additional predicates to
@@ -824,7 +814,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildPhase1SelectionPredicateForScanOnRangeLog()
 // When Catchup
 //    EndCtx.CI   >  BASE_TABLE.CI DIRECTEDBY <direction-vector>
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvMultiTxnMavBuilder::buildRangeLogJoinPredicate() const
 {
   // Call the base class for the normal predicate.
@@ -880,7 +869,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildRangeLogJoinPredicate() const
 
   return predicate;
 }  // MvMultiTxnMavBuilder::buildRangeLogJoinPredicate()
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Do not use unions when their are too many epochs because it will blow the
@@ -909,7 +897,6 @@ NABoolean MvMultiTxnMavBuilder::useUnionBakeboneToMergeEpochs() const
 // ===========================================================================
 
 // Exclude from coverage testing - used only with range loggiing
-// LCOV_EXCL_START
 
 // This class performs a single rows vs. ranges duplicate elimination algorithm 
 // in the internal refresh delta computation block.
@@ -1626,4 +1613,3 @@ RelExpr *MultiTxnDEMavBuilder::buildReadRangeLogBlock() const
   return topNode;
 }  // MultiTxnDEMavBuilder::buildReadRangeLogBlock()
 
-// LCOV_EXCL_STOP

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MvRefreshBuilder.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvRefreshBuilder.cpp b/core/sql/optimizer/MvRefreshBuilder.cpp
index d70d9eb..d1f508f 100644
--- a/core/sql/optimizer/MvRefreshBuilder.cpp
+++ b/core/sql/optimizer/MvRefreshBuilder.cpp
@@ -390,7 +390,6 @@ RelExpr *MvRefreshBuilder::buildLogsScanningBlock(const QualifiedName& baseTable
 
 //----------------------------------------------------------------------------
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 Union *MvRefreshBuilder::buildUnionBetweenRangeAndIudBlocks(RelExpr *scanIUDLogBlock,
 							    RelExpr *scanRangeLogBlock) const
 {
@@ -415,20 +414,16 @@ Union *MvRefreshBuilder::buildUnionBetweenRangeAndIudBlocks(RelExpr *scanIUDLogB
 
   return unionNode;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 NABoolean MvRefreshBuilder::needAlternateCIorder() const
 {
   return isGroupByAprefixOfTableCKeyColumns();
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvRefreshBuilder::buildAlternateCIorder(ItemExpr *ciColumns, const CorrName &tableNameCorr) const
 {
   const NAString endRangePrefix(COMMV_ENDRANGE_PREFIX);
@@ -452,7 +447,6 @@ ItemExpr *MvRefreshBuilder::buildAlternateCIorder(ItemExpr *ciColumns, const Cor
 
   return alternateOrderVector.convertToItemExpr();
 }
-// LCOV_EXCL_STOP
 
 //////////////////////////////////////////////////////////////////////////////
 // Construct the expression for @Op, according to the value of the ROW_TYPE
@@ -493,7 +487,6 @@ ItemExpr *MvRefreshBuilder::constructOpExpression() const
 //----------------------------------------------------------------------------
 // Build a vector of clustering index columns with @BR_ prefix
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvRefreshBuilder::buildBeginRangeVector() const
 {
   const NAString beginRangePrefix(COMMV_BEGINRANGE_PREFIX);
@@ -506,12 +499,10 @@ ItemExpr *MvRefreshBuilder::buildBeginRangeVector() const
 					       getLogsInfo().getBaseTableDirectionVector(),						
 					       &beginRangePrefix);
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Build a vector of clustering index columns with @ER_ prefix
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvRefreshBuilder::buildEndRangeVector() const
 {
   const NAString endRangePrefix(COMMV_ENDRANGE_PREFIX);
@@ -524,7 +515,6 @@ ItemExpr *MvRefreshBuilder::buildEndRangeVector() const
 					getLogsInfo().getBaseTableDirectionVector(),
 					&endRangePrefix);
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // The Join predicate between the Range log and the base table on the 
@@ -535,7 +525,6 @@ ItemExpr *MvRefreshBuilder::buildEndRangeVector() const
 // For multi transactional refresh, this method is overridden and two 
 // additional predicates are added.
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvRefreshBuilder::buildRangeLogJoinPredicate() const
 {
   
@@ -558,7 +547,6 @@ ItemExpr *MvRefreshBuilder::buildRangeLogJoinPredicate() const
 
   return buildRangeLogJoinPredicateWithCols(rangeType, baseCI, beginCI, endCI);
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 //   a) BASE_TABLE.CI >= RANGE_LOG.BEGIN_CI DIRECTEDBY <direction-vector>
@@ -572,7 +560,6 @@ ItemExpr *MvRefreshBuilder::buildRangeLogJoinPredicate() const
 //   c0)  WHEN 0 CI<> RANGE_LOG.BEGIN_CI AND CI<> RANGE_LOG.END_CI
 //      END
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvRefreshBuilder::buildRangeLogJoinPredicateWithCols(
 						       ItemExpr *rangeType,
 						       ItemExpr *baseCI,
@@ -628,7 +615,6 @@ ItemExpr *MvRefreshBuilder::buildRangeLogJoinPredicateWithCols(
 
   return predicate;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // This virtual method is overridden by MvMultiTxnMavBuilder for some specific
@@ -636,7 +622,6 @@ ItemExpr *MvRefreshBuilder::buildRangeLogJoinPredicateWithCols(
 // the one in the Scan node on the range log itself - not to confuse with the
 // range log join predicate in the method above.
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 ItemExpr *MvRefreshBuilder::buildSelectionPredicateForScanOnRangeLog() const
 { 
   if (!useUnionBakeboneToMergeEpochs())
@@ -647,7 +632,6 @@ ItemExpr *MvRefreshBuilder::buildSelectionPredicateForScanOnRangeLog() const
   }
   return NULL;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Have a uniform select list over the IUD log.
@@ -677,7 +661,6 @@ RelRoot *MvRefreshBuilder::buildRootOverIUDLog(RelExpr *topNode) const
     return root;
 
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 
   const NAString beginRangePrefix(COMMV_BEGINRANGE_PREFIX);
   const NAString endRangePrefix(COMMV_ENDRANGE_PREFIX);
@@ -707,7 +690,6 @@ RelRoot *MvRefreshBuilder::buildRootOverIUDLog(RelExpr *topNode) const
   root->addCompExprTree(rangeIdCol);
 
   return root;
-// LCOV_EXCL_STOP
 }  // MvRefreshBuilder::buildRootOverIUDLog()
 
 //----------------------------------------------------------------------------
@@ -720,7 +702,6 @@ RelRoot *MvRefreshBuilder::buildRootOverIUDLog(RelExpr *topNode) const
 //                    5. Range ID
 //----------------------------------------------------------------------------
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 RelRoot *MvRefreshBuilder::buildRootOverRangeBlock(RelExpr *topNode) const
 {
   ItemExpr *opExpr = new(heap_) SystemLiteral(1); // Range log has only inserts.
@@ -762,7 +743,6 @@ RelRoot *MvRefreshBuilder::buildRootOverRangeBlock(RelExpr *topNode) const
 
   return root;
 }  // MvRefreshBuilder::buildRootOverRangeBlock()
-// LCOV_EXCL_STOP
 
 
 //////////////////////////////////////////////////////////////////////////////
@@ -803,7 +783,6 @@ RelRoot *MvRefreshBuilder::buildRootWithUniformSelectList(RelExpr *topNode,
 //	         (Range Log)  (Base table)
 //
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 RelExpr *MvRefreshBuilder::buildReadRangesBlock() const
 {
   CMPASSERT(getLogsInfo().getDeltaDefinition().useRangeLog());
@@ -835,13 +814,11 @@ RelExpr *MvRefreshBuilder::buildReadRangesBlock() const
   
   return root;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Build the scan on the table and rename the table syskey column if exists
 // to @SYSKEY
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 #pragma nowarn(1506)   // warning elimination 
 RelExpr *MvRefreshBuilder::buildReadBaseTable() const
 {
@@ -879,11 +856,9 @@ RelExpr *MvRefreshBuilder::buildReadBaseTable() const
   return rootNode;
 }
 #pragma warn(1506)  // warning elimination 
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 RelExpr *MvRefreshBuilder::buildJoinBaseTableWithRangeLog(RelExpr *scanRangeLog, 
 							  RelExpr *scanBaseTable) const
 {
@@ -902,14 +877,12 @@ RelExpr *MvRefreshBuilder::buildJoinBaseTableWithRangeLog(RelExpr *scanRangeLog,
 
   return joinNode;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // This function builds a sub-tree that will read the range log records.
 // For optimization reasons, in some cases , we prefer to use a merge union
 // sub-tree instead of using a simple scan and a sort node on top.
 // Excluded from coverage test - used only with range logging.
-// LCOV_EXCL_START
 RelExpr *MvRefreshBuilder::buildReadRangeLogBlock() const
 {
   // This is the Scan on the range log table.
@@ -941,7 +914,6 @@ RelExpr *MvRefreshBuilder::buildReadRangeLogBlock() const
 
   return topNode;
 }
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Set the ForceCardinalityInfo for this node in order to fix the estimated 
@@ -2767,7 +2739,6 @@ void MultiDeltaRefreshMatrixRow::addColumn(scanType type)
 
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MultiDeltaRefreshMatrixRow::print(FILE* ofd,
 	     const char* indent,
 	     const char* title) const
@@ -2787,7 +2758,6 @@ void MultiDeltaRefreshMatrixRow::display() const
 {
   print();
 }
-// LCOV_EXCL_STOP
 #endif
 
 // ===========================================================================
@@ -2971,7 +2941,6 @@ const MultiDeltaRefreshMatrixRow *MultiDeltaRefreshMatrix::getRow(Int32 i) const
 
 #ifndef NDEBUG
 // Exclude from coverage testing - Debugging code
-// LCOV_EXCL_START
 void MultiDeltaRefreshMatrix::print(FILE* ofd,
 	     const char* indent,
 	     const char* title) const
@@ -2996,7 +2965,6 @@ void MultiDeltaRefreshMatrix::display() const
 {
   print();
 }
-// LCOV_EXCL_STOP
 #endif
 
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/MvRefreshBuilder.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvRefreshBuilder.h b/core/sql/optimizer/MvRefreshBuilder.h
index bd8bb22..b86102c 100644
--- a/core/sql/optimizer/MvRefreshBuilder.h
+++ b/core/sql/optimizer/MvRefreshBuilder.h
@@ -612,7 +612,6 @@ protected:
 //----------------------------------------------------------------------------
 //----------------------------------------------------------------------------
 // Exclude from coverage testing - used only with range loggiing
-// LCOV_EXCL_START
 class MultiTxnDEMavBuilder : public MvMultiTxnMavBuilder
 {
 public:
@@ -693,7 +692,6 @@ private:
   static const char   lastNotNullPrefixColName_[];
 
 };  // MultiTxnDEMavBuilder
-// LCOV_EXCL_STOP
 
 //----------------------------------------------------------------------------
 // Builds the refresh tree of a single-delta pipelined MAV. 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NAClusterInfo.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NAClusterInfo.cpp b/core/sql/optimizer/NAClusterInfo.cpp
index 4dc0985..fa681ad 100644
--- a/core/sql/optimizer/NAClusterInfo.cpp
+++ b/core/sql/optimizer/NAClusterInfo.cpp
@@ -92,12 +92,10 @@ void SetStaticCompiler(NABoolean isStaticCompiler)
   gIsStaticCompiler = isStaticCompiler;
 }
 
-// LCOV_EXCL_START
 NABoolean IsStaticCompiler()
 {
   return gIsStaticCompiler;
 } 
-// LCOV_EXCL_STOP
 
 //------------------------------------------------------------------------
 // Global pointer to cluster information is initially null and remains so
@@ -122,10 +120,8 @@ THREAD_P NAClusterInfo* gpClusterInfo = NULL;
 void setUpClusterInfo(CollHeap* heap)
 {
   #ifndef NDEBUG
-  // LCOV_EXCL_START
   if (getenv("NO_SERVICES"))  // KSKSKS
     return;                   // KSKSKS
-  // LCOV_EXCL_STOP
   #endif
 
 
@@ -378,12 +374,10 @@ Lng32 NAClusterInfo::getTotalNumberOfCPUs()
   Lng32 cpuCount = cpuArray_.entries();
 
 #ifndef NDEBUG
-// LCOV_EXCL_START
   if ( inTestMode() ) {
     NADefaults & defs = ActiveSchemaDB()->getDefaults();
     cpuCount = (Int32)(defs.getAsLong(POS_TEST_NUM_NODES));
   }
-// LCOV_EXCL_STOP
 #endif
   // 
   return cpuCount;
@@ -420,12 +414,10 @@ NAClusterInfoLinux::NAClusterInfoLinux(CollHeap * heap) : NAClusterInfo(heap),
       // Simulate the NAClusterInfo.
       simulateNAClusterInfoLinux();
       break;
-    // LCOV_EXCL_START
     default:
       // The OSIM must run under OFF (normal), CAPTURE or SIMULATE mode.
       OSIM_errorMessage("Invalid OSIM mode - It must be OFF or CAPTURE or SIMULATE.");
       break;
-    // LCOV_EXCL_STOP
   }
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NAClusterInfo.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NAClusterInfo.h b/core/sql/optimizer/NAClusterInfo.h
index fbcfc66..c980ab9 100644
--- a/core/sql/optimizer/NAClusterInfo.h
+++ b/core/sql/optimizer/NAClusterInfo.h
@@ -122,11 +122,9 @@ public:
   // three methods to enter, leave and test the test mode. The test 
   // mode is for testing POS.
 
-// LCOV_EXCL_START
   NABoolean inTestMode() const { return inTestMode_; };
   void setTestMode() { inTestMode_ = TRUE; };
   void resetTestMode() { inTestMode_ = FALSE; };
-// LCOV_EXCL_STOP
 
 protected :
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NAColumn.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NAColumn.cpp b/core/sql/optimizer/NAColumn.cpp
index 430343d..a7b0a68 100644
--- a/core/sql/optimizer/NAColumn.cpp
+++ b/core/sql/optimizer/NAColumn.cpp
@@ -124,7 +124,6 @@ NAColumn *NAColumn::deepCopy(const NAColumn & nac, NAMemory * heap)
   return column;
 }
 
-// LCOV_EXCL_START :cnu
 // -----------------------------------------------------------------------
 // See NAColumn.h and BindRelExpr.C (bindCheckConstraint function)
 // for the reason for these two methods.
@@ -151,7 +150,6 @@ const QualifiedName& NAColumn::getNotNullConstraintName() const
   CMPASSERT(isNotNullNondroppable_);
   return isNotNullNondroppable_->getConstraintName();
 }
-// LCOV_EXCL_STOP
 
 // warning elimination (removed "inline")
 static NAString makeTableName(const NATable *table,
@@ -621,7 +619,6 @@ NABoolean NAColumn::createNAType(TrafColumnsDesc *column_desc	/*IN*/,
 
 } // createNAType()
 
-// LCOV_EXCL_START :dpm
 // -----------------------------------------------------------------------
 // Print function for debugging
 // -----------------------------------------------------------------------
@@ -689,7 +686,6 @@ void NAColumnArray::trace(FILE* ofd) const
     }
   }
 }
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // functions for NAColumnArray
@@ -753,7 +749,6 @@ NAColumn * NAColumnArray::getColumnByPos(Lng32 position) const
   return NULL;
 }
 
-// LCOV_EXCL_START :cnu
 // removes the column that has the same position
 void NAColumnArray::removeByPosition(Lng32 position)
 {
@@ -802,7 +797,6 @@ ULng32 NAColumnArray::getMaxTrafHbaseColQualifier() const
   return maxVal;
 }
 
-// LCOV_EXCL_STOP
 
 //method to reset an NAColumn object after a statement
 //In the ideal world NAColumn objects should not be having any state
@@ -832,7 +826,6 @@ void NAColumn::resetAfterStatement()
   return;
 }
 
-// LCOV_EXCL_START :dd
 NABoolean NAColumnArray::operator==(const NAColumnArray &other) const
 {
   if (entries() != other.entries())
@@ -847,7 +840,6 @@ NABoolean NAColumnArray::operator==(const NAColumnArray &other) const
     }
   return TRUE;
 }
-// LCOV_EXCL_STOP
 
 Int32 NAColumnArray::getTotalStorageSize() const
 {

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NATable.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NATable.cpp b/core/sql/optimizer/NATable.cpp
index dbcc323..1fcd1f2 100644
--- a/core/sql/optimizer/NATable.cpp
+++ b/core/sql/optimizer/NATable.cpp
@@ -2023,7 +2023,6 @@ static PartitioningFunction * createRangePartitioningFunction
 // createRoundRobinPartitioningFunction()
 // This method is used for creating a RoundRobinPartitioningFunction.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START :cnu
 static PartitioningFunction * createRoundRobinPartitioningFunction
                                 (TrafDesc * part_desc_list,
                                  NodeMap* nodeMap,
@@ -2055,7 +2054,6 @@ static PartitioningFunction * createRoundRobinPartitioningFunction
   return new (heap) RoundRobinPartitioningFunction(numberOfPartitions, nodeMap, heap);
 
 } // static createRoundRobinPartitioningFunction()
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // createHashDistPartitioningFunction()
@@ -3610,7 +3608,6 @@ ULng32 naStringHashFunc(const NAString& indexName)
 // The method processDuplicateNames() is called by createNAFileSet() for
 // tables having duplicate remote indexes.
 //*************************************************************************
-// LCOV_EXCL_START :nsk
 void processDuplicateNames(NAHashDictionaryIterator<NAString, Int32> &Iter,
                            NAFileSetList & indexes,
                            char *localNodeName)
@@ -3618,7 +3615,6 @@ void processDuplicateNames(NAHashDictionaryIterator<NAString, Int32> &Iter,
 {
     return;
 } // processDuplicateNames()
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // Method for:
@@ -5642,7 +5638,6 @@ NABoolean NATable::fetchObjectUIDForNativeTable(const CorrName& corrName,
          } // if
      } // if
 
-   // LCOV_EXCL_STOP
    initialSize_ = heap_->getAllocSize();
    MonitorMemoryUsage_Exit((char*)mmPhase.data(), heap_, NULL, TRUE);
  } // NATable()
@@ -5936,7 +5931,6 @@ NATable::NATable(BindWA *bindWA,
 
   hiveDefaultStringLen_ = CmpCommon::getDefaultLong(HIVE_MAX_STRING_LENGTH_IN_BYTES);
 
-  // LCOV_EXCL_STOP
   initialSize_ = heap_->getAllocSize();
   MonitorMemoryUsage_Exit((char*)mmPhase.data(), heap_, NULL, TRUE);
 } // NATable()
@@ -8763,7 +8757,6 @@ void NATableDB::removeNATable2(CorrName &corrName, ComQiScope qiScope,
           //remove from list of cached NATables
           if (cachedTableList_.remove(cachedNATable) > 0)
             {
-              // LCOV_EXCL_START - caching is off by default for now
               //if metadata caching is ON, then adjust cache size
               //since we are deleting a caching entry
               if(cacheMetaData_)
@@ -8771,7 +8764,6 @@ void NATableDB::removeNATable2(CorrName &corrName, ComQiScope qiScope,
               if (cachedNATable->heap_ &&
                   cachedNATable->heap_ != CmpCommon::statementHeap())
                 tablesToDeleteAfterStatement_.insert(cachedNATable);
-              // LCOV_EXCL_STOP
             }
           else
             {
@@ -9123,7 +9115,6 @@ NABoolean NATableDB::enforceMemorySpaceConstraints()
 //the current statement.
 //This is used when a binder error occurs. In rare cases the binder
 //error might be due to a stale metadata cache entry.
-// LCOV_EXCL_START :cnu
 void NATableDB::flushCacheEntriesUsedInCurrentStatement(){
 
   //do this only if metadata caching is 'ON'
@@ -9147,7 +9138,6 @@ void NATableDB::flushCacheEntriesUsedInCurrentStatement(){
     statementCachedTableList_.clear();
   }
 }
-// LCOV_EXCL_STOP
 
 //Turn metadata caching ON
 void NATableDB::setCachingON()

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NATable.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NATable.h b/core/sql/optimizer/NATable.h
index 111f99f..edf338f 100644
--- a/core/sql/optimizer/NATable.h
+++ b/core/sql/optimizer/NATable.h
@@ -623,21 +623,17 @@ public:
     return isAlignedFormat;
   }
  
-// LCOV_EXCL_START :cnu
   void setVerticalPartitions( NABoolean value )
   {  value ? flags_ |= IS_VERTICAL_PARTITION : flags_ &= ~IS_VERTICAL_PARTITION;}
-// LCOV_EXCL_STOP
 
   NABoolean isVerticalPartition() const
   {  return (flags_ & IS_VERTICAL_PARTITION) != 0; }
 
-// LCOV_EXCL_START :cnu
   void setHasVerticalPartitions( NABoolean value )
   {
     value ?
        flags_ |= HAS_VERTICAL_PARTITIONS : flags_ &= ~HAS_VERTICAL_PARTITIONS;
   }
-// LCOV_EXCL_STOP
 
   NABoolean hasVerticalPartitions() const
   {  return (flags_ & HAS_VERTICAL_PARTITIONS) != 0; }
@@ -1356,10 +1352,8 @@ public:
   void getCacheStats(NATableCacheStats & stats);
 
 
-// LCOV_EXCL_START :cnu
   inline ULng32 currentCacheSize() { return currentCacheSize_; }
   inline ULng32 intervalWaterMark() { return intervalWaterMark_; }
-// LCOV_EXCL_STOP
   inline ULng32 hits() { return totalCacheHits_; }
   inline ULng32 lookups() { return totalLookupsCount_; }
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NodeMap.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NodeMap.cpp b/core/sql/optimizer/NodeMap.cpp
index 432200f..86913dc 100644
--- a/core/sql/optimizer/NodeMap.cpp
+++ b/core/sql/optimizer/NodeMap.cpp
@@ -261,7 +261,6 @@ NodeMapEntry::NodeMapEntry(const NodeMapEntry& other, CollHeap* heap )
 //
 //==============================================================================
 // The function is not called anywhere
-// LCOV_EXCL_START
 void
 NodeMapEntry::setDp2Name(char* dp2Name)
 {
@@ -279,7 +278,6 @@ NodeMapEntry::setDp2Name(char* dp2Name)
   strcpy(dp2Name_,dp2Name);
 
 } //NodeMapEntry::setDp2Name()
-// LCOV_EXCL_STOP
 
 //<pb>
 //==============================================================================
@@ -446,7 +444,6 @@ NodeMapEntry::getText() const
 //  none
 //
 //==============================================================================
-// LCOV_EXCL_START
 void
 NodeMapEntry::print(FILE* ofd, const char* indent, const char* title) const
 {
@@ -463,7 +460,6 @@ NodeMapEntry::print(FILE* ofd, const char* indent, const char* title) const
                                                      "State: ",partitionState_);
 
 } // NodeMapEntry::print()
-// LCOV_EXCL_STOP
 
 //<pb>
 //============================================================================
@@ -615,7 +611,6 @@ NodeMap::NodeMap(const NodeMap& other, CollHeap* heap)
 //
 //==============================================================================
 // NodeMaps are deleted with the statement heap. 
-// LCOV_EXCL_START
 NodeMap::~NodeMap()
 {
 
@@ -645,7 +640,6 @@ NodeMap::~NodeMap()
     QueryAnalysis::Instance()->tempMonitor().exit();
 
 } // NodeMap destructor.
-// LCOV_EXCL_STOP
 //<pb>
 //==============================================================================
 //  Make a copy of this NodeMap object in a specified heap.
@@ -708,7 +702,6 @@ NodeMap::synthesizeLogicalMap(const CollIndex logicalNumEntries,
   // number of CPUs in cluster.
   //-----------------------------------------------------------------------
 #ifdef _DEBUG
-// LCOV_EXCL_START
     if ((CmpCommon::getDefault( NSK_DBG ) == DF_ON) &&
         (CmpCommon::getDefault( NSK_DBG_GENERIC ) == DF_ON )) {
 	  CURRCONTEXT_OPTDEBUG->stream()
@@ -716,7 +709,6 @@ NodeMap::synthesizeLogicalMap(const CollIndex logicalNumEntries,
 	    << "logicalNumEntries = " << logicalNumEntries << endl
 	    << "totalESPs= " << totalESPs << endl;
     }
-// LCOV_EXCL_STOP
 #endif
 
   Lng32 requiredESPs = CURRSTMT_OPTDEFAULTS->getRequiredESPs();
@@ -877,7 +869,6 @@ NodeMap::synthesizeLogicalMap(const CollIndex logicalNumEntries,
 //
 //==============================================================================
 // the method is not used under SQ, except in OSM mode simulating NSK
-// LCOV_EXCL_START
 void
 NodeMap::deriveGrouping(const CollIndex         numGroups,
                               CollIndexPointer& groupStart,
@@ -1095,7 +1086,6 @@ NodeMap::deriveGrouping(const CollIndex         numGroups,
       }
     }
 } // NodeMap::deriveGrouping()
-// LCOV_EXCL_STOP
 //<pb>
 //==============================================================================
 //  Determine if node map has a node specification for all entries.
@@ -2386,7 +2376,6 @@ void NodeMap::balanceScanInfos(HivePartitionAndBucketKey *hiveSearchKey,
 } // NodeMap::balanceScanInfos
 
 // to be called from the debugger
-// LCOV_EXCL_START
 void 
 NodeMap::display() const
 {
@@ -2493,7 +2482,6 @@ NodeMap::print(FILE* ofd, const char* indent, const char* title) const
          );
 
 } // NodeMap::print()
-// LCOV_EXCL_STOP
 #pragma warn(1506)  // warning elimination 
 
 //=======================================================

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/NormRelExpr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/NormRelExpr.cpp b/core/sql/optimizer/NormRelExpr.cpp
index 2c8eeab..5a33084 100644
--- a/core/sql/optimizer/NormRelExpr.cpp
+++ b/core/sql/optimizer/NormRelExpr.cpp
@@ -9692,7 +9692,6 @@ NABoolean CommonSubExprRef::createTempTable(CSEInfo &info)
   // ------------------------------
 
   // we create a name of this form:
-  // CSE_TEMP_ppppp_MXIDiiiii_Ssss_ccc
   // where
   //   ppp... is a prefix of the CTE name or an internal name
   //          (just to make it easier to identify, not really needed,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/ObjectNames.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ObjectNames.cpp b/core/sql/optimizer/ObjectNames.cpp
index c58fef1..e36b34a 100644
--- a/core/sql/optimizer/ObjectNames.cpp
+++ b/core/sql/optimizer/ObjectNames.cpp
@@ -174,7 +174,6 @@ NAString QualifiedName::getQualifiedNameAsString(NABoolean formatForDisplay,
   return result;
 }
 
-//LCOV_EXCL_START /* : cnu -- not used on Linux */
 // -----------------------------------------------------------------------
 // makeSafeFilenamePart() and
 // QualifiedName::getQualifiedNameAsAnsiNTFilenameString()
@@ -303,7 +302,6 @@ const NAString QualifiedName::getQualifiedNameAsAnsiNTFilenameString() const
 
   return result;
 }
-//LCOV_EXCL_STOP /* : cnu -- not used on Linux */
 
 const NAString QualifiedName::getQualifiedNameAsAnsiString(NABoolean formatForDisplay,
 							   NABoolean externalDisplay) const
@@ -1390,7 +1388,6 @@ const TableRefName *TableRefList::findTable(const CorrName& tableCorr) const
 // Additional non-inline functions for all ``ObjectNames'' classes
 // -----------------------------------------------------------------------
 
-//LCOV_EXCL_START : dpm
 // Display/print, for debugging.
 
 void CatalogName::display()   const { print(); }	
@@ -1476,7 +1473,6 @@ void ColRefName::print(FILE* ofd, const char* indent, const char* title,
   if (strcmp(title,"")) fprintf(ofd,"\n");
 #endif
 }
-//LCOV_EXCL_STOP : dpm
 
 // ++MV
 ComAnsiNameSpace ExtendedQualName::convSpecialTableTypeToAnsiNameSpace( const SpecialTableType type )

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/OptRange.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/OptRange.cpp b/core/sql/optimizer/OptRange.cpp
index 0aacab3..8a6ef24 100644
--- a/core/sql/optimizer/OptRange.cpp
+++ b/core/sql/optimizer/OptRange.cpp
@@ -691,7 +691,7 @@ void OptRangeSpec::addSubrange(ConstValue* start, ConstValue* end,
         break;
 
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,
                            FALSE, QRDescriptorException, 
                            "Unhandled data type: %d", typeQual);
         break;
@@ -701,7 +701,6 @@ void OptRangeSpec::addSubrange(ConstValue* start, ConstValue* end,
 
 ItemExpr* OptRangeSpec::getCheckConstraintPred(ItemExpr* checkConstraint)
 {
-  // LCOV_EXCL_START :rfi
   if (checkConstraint->getOperatorType() != ITM_CASE)
     {
       QRLogger::log(CAT_SQL_COMP_RANGE, logLevel_,
@@ -709,9 +708,7 @@ ItemExpr* OptRangeSpec::getCheckConstraintPred(ItemExpr* checkConstraint)
         checkConstraint->getOperatorType());
       return NULL;
     }
-  // LCOV_EXCL_STOP
 
-  // LCOV_EXCL_START :rfi
   ItemExpr* itemExpr = checkConstraint->child(0);
   if (itemExpr->getOperatorType() != ITM_IF_THEN_ELSE)
     {
@@ -720,7 +717,6 @@ ItemExpr* OptRangeSpec::getCheckConstraintPred(ItemExpr* checkConstraint)
         itemExpr->getOperatorType());
       return NULL;
     }
-  // LCOV_EXCL_STOP
 
   // Child of the if-then-else is either is_false, which is the parent of the
   // predicate (for most check constraints), or the predicate itself (for
@@ -752,7 +748,6 @@ void OptRangeSpec::intersectCheckConstraints(QRDescGenerator* descGen,
         }
       return;
     }
-  // LCOV_EXCL_START :rfi
   else if (itemExpr->getOperatorType() != ITM_BASECOLUMN)
     {
       QRLogger::log(CAT_SQL_COMP_RANGE, logLevel_,
@@ -760,7 +755,6 @@ void OptRangeSpec::intersectCheckConstraints(QRDescGenerator* descGen,
         "%d instead of ITM_BASECOLUMN.", itemExpr->getOperatorType());
       return;
     }
-  // LCOV_EXCL_STOP
 
 #ifdef _DEBUG
     const NATable* tbl = colValId.getNAColumn()->getNATable();
@@ -872,7 +866,7 @@ void OptRangeSpec::intersectTypeConstraint(QRDescGenerator* descGen,
             break;
 
           default:
-            QRLogger::log(CAT_SQL_COMP_RANGE, logLevel_,  // LCOV_EXCL_LINE :rfi
+            QRLogger::log(CAT_SQL_COMP_RANGE, logLevel_,
               "No case in intersectTypeConstraint() for "
                         "approximate numeric of type %d",
                         colType.getFSDatatype());
@@ -1123,7 +1117,6 @@ NABoolean OptRangeSpec::buildRange(ItemExpr* origPredExpr)
           isRange = FALSE;
         break;
 
-      // LCOV_EXCL_START :cnu -- Transformation phase rewrites between op
       case ITM_BETWEEN:
         startValue = getConstOperand(predExpr);
         if (startValue)
@@ -1140,7 +1133,6 @@ NABoolean OptRangeSpec::buildRange(ItemExpr* origPredExpr)
         else
           isRange = FALSE;
         break;
-      // LCOV_EXCL_STOP
 
       case ITM_IS_NULL:
       case ITM_IS_NOT_NULL:
@@ -1394,7 +1386,7 @@ ConstValue* OptRangeSpec::reconstituteInt64Value(NAType* type, Int64 val) const
                 break;
 
               default:
-                assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,  // LCOV_EXCL_LINE :rfi
+                assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,
                                    FALSE, QRLogicException,
                                    "Unknown datetime subtype -- %d",
                                    dtType->getSubtype());
@@ -1448,7 +1440,7 @@ ConstValue* OptRangeSpec::reconstituteInt64Value(NAType* type, Int64 val) const
                 break;
 
               default:
-                assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,  // LCOV_EXCL_LINE :rfi
+                assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,
                                   FALSE, QRLogicException,
                                   "Invalid end field for interval type -- %d",
                                   intvlType->getEndField());
@@ -1519,7 +1511,7 @@ ConstValue* OptRangeSpec::reconstituteInt64Value(NAType* type, Int64 val) const
         break;
 
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_, FALSE, QRLogicException,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_, FALSE, QRLogicException,
                            "Type not handled by reconstituteInt64Value() -- %d",
                            typeQual);
         return NULL;
@@ -1533,7 +1525,6 @@ ConstValue* OptRangeSpec::reconstituteInt64Value(NAType* type, Int64 val) const
 ConstValue* OptRangeSpec::reconstituteDoubleValue(NAType* type, Float64 val) const
 {
   NABuiltInTypeEnum typeQual = type->getTypeQualifier();
-  // LCOV_EXCL_START :rfi
   if (typeQual != NA_NUMERIC_TYPE)
     {
       assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_, FALSE, QRLogicException,
@@ -1541,7 +1532,6 @@ ConstValue* OptRangeSpec::reconstituteDoubleValue(NAType* type, Float64 val) con
                          typeQual);
       return NULL;
     }
-  // LCOV_EXCL_STOP
 
   // Use these for the textual representation of a constant value, which is
   // passed to the ConstValue ctor.
@@ -1743,7 +1733,7 @@ ItemExpr* OptRangeSpec::makeSubrangeItemExpr(SubrangeBase* subrange,
         break;
 
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, logLevel_, 
                            FALSE, QRDescriptorException, 
                            "Unhandled data type in "
                            "OptRangeSpec::makeSubrangeItemExpr: %d",
@@ -2045,7 +2035,7 @@ static Int64 getInt64ValueFromDateTime(ConstValue* val,
         break;
 
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,
                            FALSE, QRDescriptorException,
                            "Invalid datetime subtype -- %d", constType->getSubtype());
     }
@@ -2118,7 +2108,7 @@ static Int64 getInt64ValueFromInterval(ConstValue* constVal,
         valWasNegative = (i64val < 0);
         break;
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,
                            FALSE, QRDescriptorException,
                            "Invalid interval storage length -- %d",
                            storageSize);
@@ -2157,7 +2147,7 @@ static Int64 getInt64ValueFromInterval(ConstValue* constVal,
         i64val *= (Int64)pow(10, 6 - constIntvlType->getFractionPrecision());
         break;
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,
                            FALSE, QRDescriptorException,
                            "Invalid end field for interval -- %d",
                            constIntvlType->getEndField());
@@ -2201,7 +2191,7 @@ static Int64 getInt64ValueFromInterval(ConstValue* constVal,
         i64val = i64val / scaleFactor * scaleFactor;
         break;
       default:
-        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,  // LCOV_EXCL_LINE :rfi
+        assertLogAndThrow1(CAT_SQL_COMP_RANGE, level,
                           FALSE, QRDescriptorException,
                           "Invalid end field for interval -- %d",
                           colIntvlType->getEndField());

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/OptTrigger.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/OptTrigger.cpp b/core/sql/optimizer/OptTrigger.cpp
index 0679e2c..a00a781 100644
--- a/core/sql/optimizer/OptTrigger.cpp
+++ b/core/sql/optimizer/OptTrigger.cpp
@@ -527,9 +527,9 @@ OptTriggersBackbone::~OptTriggersBackbone()
     {
       OptTriggerPtr optTrigger = (*triggerList_)[i];
       // exclude coverage - we don't seem to handle macro expansion very well
-      NADELETEBASIC(optTrigger, CmpCommon::statementHeap()); // LCOV_EXCL_LINE
+      NADELETEBASIC(optTrigger, CmpCommon::statementHeap());
     }
-    NADELETEBASIC(triggerList_, CmpCommon::statementHeap()); // LCOV_EXCL_LINE
+    NADELETEBASIC(triggerList_, CmpCommon::statementHeap());
   }
 
   if (triggerGroups_)
@@ -537,9 +537,9 @@ OptTriggersBackbone::~OptTriggersBackbone()
     for (CollIndex i = 1; i < triggerGroups_->entries(); i++)
     {
       OptTriggerGroup *optGroup = (*triggerGroups_)[i];
-      NADELETE(optGroup, OptTriggerGroup, (CmpCommon::statementHeap())); // LCOV_EXCL_LINE
+      NADELETE(optGroup, OptTriggerGroup, (CmpCommon::statementHeap()));
     }
-    NADELETEBASIC(triggerGroups_, CmpCommon::statementHeap()); // LCOV_EXCL_LINE
+    NADELETEBASIC(triggerGroups_, CmpCommon::statementHeap());
   }
 
 }
@@ -921,7 +921,7 @@ OptTriggersBackbone::reorder()
 
   // free the temporary array
   // exclude coverage - we don't seem to handle macro expansion very well
-  NADELETEBASIC(optTriggerPtrArray, (CmpCommon::statementHeap())); // LCOV_EXCL_LINE
+  NADELETEBASIC(optTriggerPtrArray, (CmpCommon::statementHeap()));
 }
 
 //-----------------------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/OptTrigger.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/OptTrigger.h b/core/sql/optimizer/OptTrigger.h
index a70f88b..3714558 100644
--- a/core/sql/optimizer/OptTrigger.h
+++ b/core/sql/optimizer/OptTrigger.h
@@ -74,7 +74,7 @@ public:
 	     RelExpr *parentSubTree);
 
   // Dummy copy constructor - method body does not exist
-  OptTrigger(const OptTrigger &orig, NAMemory *h=0); // LCOV_EXCL_LINE
+  OptTrigger(const OptTrigger &orig, NAMemory *h=0); 
   // ---------------------------------------------------------------------
   // Accessor functions
   // ---------------------------------------------------------------------
@@ -103,7 +103,7 @@ public:
   OptTriggerList(): LIST(OptTriggerPtr)(CmpCommon::statementHeap()) { }
 
   // Dummy copy constructor - method body does not exist
-  OptTriggerList(const OptTriggerList &orig, NAMemory *h=0); // LCOV_EXCL_LINE
+  OptTriggerList(const OptTriggerList &orig, NAMemory *h=0);
 
   RelExpr *createUnionSubTree() const;
 };
@@ -138,7 +138,7 @@ public:
   // Dummy copy constructor - method body does not exist
   OptTriggerGroup(const OptTriggerGroup &orig);
 
-  virtual ~OptTriggerGroup() {} // LCOV_EXCL_LINE
+  virtual ~OptTriggerGroup() {}
 
   inline CollIndex entries() const 
     { return (rowTriggerGroup_.entries()+statmentTriggerGroup_.entries());}
@@ -199,7 +199,7 @@ public:
   OptTriggerGroupList(): LIST(OptTriggerGroup *)(CmpCommon::statementHeap()) { }
 
   // Dummy copy constructor - method body does not exist
-  OptTriggerGroupList(const OptTriggerGroupList &orig, NAMemory *h=0); // LCOV_EXCL_LINE
+  OptTriggerGroupList(const OptTriggerGroupList &orig, NAMemory *h=0);
 };
 
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PackedColDesc.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PackedColDesc.cpp b/core/sql/optimizer/PackedColDesc.cpp
index d8967cd..52def3e 100644
--- a/core/sql/optimizer/PackedColDesc.cpp
+++ b/core/sql/optimizer/PackedColDesc.cpp
@@ -33,7 +33,6 @@
 ******************************************************************************
 */
 
-// LCOV_EXCL_START
 // exclude this whole file from coverage since this code is related to vertical
 // partitioning and that feature is not active anymore
 
@@ -585,4 +584,3 @@ PackedTableDesc::getPackingInfoForColumn(Lng32 position)
   return (PackedColDesc *)packingInfo;
 }
 
-// LCOV_EXCL_STOP

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PackedColDesc.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PackedColDesc.h b/core/sql/optimizer/PackedColDesc.h
index acb7ff2..2a96991 100644
--- a/core/sql/optimizer/PackedColDesc.h
+++ b/core/sql/optimizer/PackedColDesc.h
@@ -37,7 +37,6 @@
 *
 ******************************************************************************
 */
-// LCOV_EXCL_START
 // exclude this whole file from coverage since this code is related to vertical
 // partitioning and that feature is not active anymore
 #include "Collections.h"
@@ -445,6 +444,5 @@ private:
   //
   NABoolean callFromCatMan_;
 };
-// LCOV_EXCL_STOP
 
 #endif

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PartFunc.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PartFunc.cpp b/core/sql/optimizer/PartFunc.cpp
index 706c308..7e46e94 100644
--- a/core/sql/optimizer/PartFunc.cpp
+++ b/core/sql/optimizer/PartFunc.cpp
@@ -67,7 +67,6 @@
 // an undefined symbol.
 // ***********************************************************************
 
-// LCOV_EXCL_START
 void displayPartitioningFunction(const PartitioningFunction& pf)
 {
   pf.display();
@@ -89,7 +88,6 @@ void displayPartitionBoundaries(const RangePartitionBoundaries* pb)
   if (pb)
     pb->display();
 }
-// LCOV_EXCL_STOP
 
 
 // ***********************************************************************
@@ -276,14 +274,12 @@ PartitioningFunction::replaceNodeMap(NodeMap* nodeMap)
 // PartitioningFunction::copy()
 // Virtual copy constructor returns a copy of myself.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 PartitioningFunction* PartitioningFunction::copy() const
 {
   // illegal to call copy() of the base class
   CMPABORT;
   return NULL;
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // PartitioningFunction::normalizePartitioningKeys()
@@ -384,14 +380,12 @@ NABoolean PartitioningFunction::isAGroupingOf(
   return (comparePartFuncToFunc(other) == SAME);
 }
 
-// LCOV_EXCL_START
 PartitioningRequirement* PartitioningFunction::makePartitioningRequirement()
 {
   // Redefine PartitioningFunction::makePartitioningRequirement()
   CMPABORT;
   return NULL;
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // PartitioningFunction::scaleNumberOfPartitions
@@ -538,14 +532,12 @@ NABoolean PartitioningFunction::shouldUseSynchronousAccess(
 // -----------------------------------------------------------------------
 // Virtual functions that must be redefined for derived classes.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 Lng32 PartitioningFunction::getCountOfPartitions() const
 {
   // Redefine PartitioningFunction::getCountOfPartitions()
   CMPABORT;
   return 1;
 }
-// LCOV_EXCL_STOP
 
 NABoolean PartitioningFunction::canProducePartitioningKeyPredicates() const
 {
@@ -570,7 +562,6 @@ const ValueIdList& PartitioningFunction::getPartitionInputValuesLayout() const
   return partitionInputValuesLayout_;
 }
 
-// LCOV_EXCL_START
 void PartitioningFunction::createPartitioningKeyPredicates()
 {
   // Redefine PartitioningFunction::createPartitioningKeyPredicates()
@@ -600,7 +591,6 @@ ItemExpr* PartitioningFunction::createPartitioningExpression()
   CMPABORT;
   return NULL;
 }
-// LCOV_EXCL_STOP
 
 void PartitioningFunction::createPartSelectionExprFromSearchKey(
       const ValueId beginPartSelId,
@@ -636,14 +626,12 @@ void PartitioningFunction::preCodeGen(const ValueIdSet& availableValues)
 
 } // PartitioningFunction::preCodeGen()
 
-// LCOV_EXCL_START
 const NAString PartitioningFunction::getText() const
 {
   CMPABORT;
   return NAString("some type of partitioning function",
                    CmpCommon::statementHeap());
 }
-// LCOV_EXCL_STOP
 
 void PartitioningFunction::setupForStatement()
 {
@@ -675,7 +663,6 @@ void PartitioningFunction::resetAfterStatement()
 // -----------------------------------------------------------------------
 // Method for debugging
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 void PartitioningFunction::print(FILE* ofd, const char* indent,
 				 const char* title) const
 {
@@ -725,7 +712,6 @@ void PartitioningFunction::print(FILE* ofd, const char* indent,
 } // PartitioningFunction::print()
 
 void PartitioningFunction::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // SinglePartitionPartitioningFunction
@@ -766,7 +752,6 @@ void SinglePartitionPartitioningFunction::createPartitioningKeyPredicates()
   storePartitioningKeyPredicates(ValueIdSet());
 }
 
-// LCOV_EXCL_START
 void SinglePartitionPartitioningFunction::replacePivs(
        const ValueIdList& newPivs,
        const ValueIdSet& newPartKeyPreds)
@@ -774,7 +759,6 @@ void SinglePartitionPartitioningFunction::replacePivs(
   // do nothing, there aren't any pivs for a single
   // partition
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // SinglePartitionPartitioningFunction::createPartitioningExpression()
@@ -849,14 +833,12 @@ const NAString SinglePartitionPartitioningFunction::getText() const
   return "exactly 1 partition";
 }
 
-// LCOV_EXCL_START
 void SinglePartitionPartitioningFunction::print(FILE* ofd, const char* indent,
 						const char* title) const
 {
   PartitioningFunction::print(ofd, indent,
 			      "SinglePartitionPartitioningFunction");
 }
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // ReplicateViaBroadcastPartitioningFunction
@@ -1440,13 +1422,11 @@ const NAString HashPartitioningFunction::getText() const
    return getTextImp("hash"); 
 }
 
-// LCOV_EXCL_START
 void HashPartitioningFunction::print(FILE* ofd, const char* indent,
 	   			     const char* title) const
 {
   PartitioningFunction::print(ofd, indent, "HashPartitioningFunction");
 } // HashPartitioningFunction::print()
-// LCOV_EXCL_STOP
 
 // Return an expression casting an encoded skew value to oType.
 static 
@@ -2056,13 +2036,11 @@ const NAString HashDistPartitioningFunction::getText() const
   return result;
 }
 
-// LCOV_EXCL_START
 void HashDistPartitioningFunction::print(FILE* ofd, const char* indent,
                                          const char* title) const
 {
   PartitioningFunction::print(ofd, indent, "HashDistPartitioningFunction");
 } // TableHashPartitioningFunction::print()
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // HashDistPartitioningFunction::createPartitioningFunctionForIndexDesc()
@@ -2464,13 +2442,11 @@ const NAString Hash2PartitioningFunction::getText() const
   return result;
 }
 
-// LCOV_EXCL_START
 void Hash2PartitioningFunction::print(FILE* ofd, const char* indent,
                                          const char* title) const
 {
   PartitioningFunction::print(ofd, indent, "Hash2PartitioningFunction");
 } // TableHashPartitioningFunction::print()
-// LCOV_EXCL_STOP
 
 
 // -----------------------------------------------------------------------
@@ -2933,13 +2909,11 @@ const NAString SkewedDataPartitioningFunction::getText() const
   return result;
 }
 
-// LCOV_EXCL_START
 void SkewedDataPartitioningFunction::print(FILE* ofd, const char* indent,
                                          const char* title) const
 {
   PartitioningFunction::print(ofd, indent, "SkewedDataPartitioningFunction");
 }  
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // SkewedDataPartitioningFunction::comparePartFuncToFunc(): Compare this
@@ -2977,7 +2951,6 @@ comparePartFuncToFunc(const PartitioningFunction &other) const
 // SkewedDataPartitioningFunction::scaleNumberOfPartitions()
 // -----------------------------------------------------------------------
 
-// LCOV_EXCL_START
 
 //::scaleNUmberOfPartitions() are called in following locations
 //
@@ -3006,7 +2979,6 @@ scaleNumberOfPartitions(Lng32 &suggestedNewNumberOfPartitions,
     return this;
 
 } // SkewedDataPartitioningFunction::scaleNumberOfPartitions()
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // SkewedDataPartitioningFunction::isAGroupingOf()
@@ -3973,7 +3945,6 @@ void RangePartitionBoundaries::resetAfterStatement()
 // -----------------------------------------------------------------------
 // Method for debugging.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 void RangePartitionBoundaries::print(FILE* ofd, const char* indent,
 				     const char* title) const
 {
@@ -4006,7 +3977,6 @@ void RangePartitionBoundaries::print(FILE* ofd, const char* indent,
     }
 
 } // RangePartitionBoundaries::print()
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // RangePartitioningFunction
@@ -4995,7 +4965,6 @@ const NAString RangePartitioningFunction::getText() const
   return result;
 }
 
-// LCOV_EXCL_START
 void RangePartitioningFunction::print(FILE* ofd, const char* indent,
 					const char* title) const
 {
@@ -5135,7 +5104,6 @@ RangePartitioningFunction::computeNumOfActivePartitions(SearchKey* skey, const T
 }
 
 
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // LogPhysPartitioningFunction
@@ -5664,7 +5632,6 @@ const NAString LogPhysPartitioningFunction::getPhysForSplitTop() const
   return physPartFunc_->getText();
 }
 
-// LCOV_EXCL_START
 void LogPhysPartitioningFunction::print(
      FILE* ofd,
      const char* indent,
@@ -5674,13 +5641,11 @@ void LogPhysPartitioningFunction::print(
   logPartFunc_->print(ofd,"logical:  ");
   physPartFunc_->print(ofd,"physical: ");
 }
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // RoundRobinPartitioningFunction
 // ***********************************************************************
 
-// LCOV_EXCL_START
 PartitioningRequirement*
 RoundRobinPartitioningFunction::makePartitioningRequirement()
 {
@@ -6323,7 +6288,6 @@ void RoundRobinPartitioningFunction::print(
   PartitioningFunction::print(ofd,indent,"RoundRobinPartitioningFunction");
 }
 
-// LCOV_EXCL_STOP
 
 const skewProperty ANY_SKEW_PROPERTY(skewProperty::ANY, NULL);
   
@@ -6546,13 +6510,11 @@ const NAString HivePartitioningFunction::getText() const
    return getTextImp("hive"); 
 }
 
-// LCOV_EXCL_START
 void HivePartitioningFunction::print(FILE* ofd, const char* indent,
 	   			     const char* title) const
 {
   PartitioningFunction::print(ofd, indent, "HivePartitioningFunction");
 } // HivePartitioningFunction::print()
-// LCOV_EXCL_STOP
 
 PartitioningFunction*
 HivePartitioningFunction::

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PartFunc.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PartFunc.h b/core/sql/optimizer/PartFunc.h
index b179b21..92f577d 100644
--- a/core/sql/optimizer/PartFunc.h
+++ b/core/sql/optimizer/PartFunc.h
@@ -2558,7 +2558,6 @@ private:
 // partitions in a random fashion so as to balance the number of records
 // in each partition.
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 class RoundRobinPartitioningFunction : public PartitioningFunction
 {
 public:
@@ -2704,7 +2703,6 @@ private:
   NABoolean resetAfterStatement_;
 
 }; // class RoundRobinPartitioningFunction
-// LCOV_EXCL_STOP
 //
 
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PartReq.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PartReq.cpp b/core/sql/optimizer/PartReq.cpp
index 08ae4dc..e19c609 100644
--- a/core/sql/optimizer/PartReq.cpp
+++ b/core/sql/optimizer/PartReq.cpp
@@ -209,7 +209,6 @@ PartitioningRequirement::copy() const
   return NULL;
 }
 
-// LCOV_EXCL_START
 void PartitioningRequirement::print(FILE* ofd, const char* indent, 
 				    const char* title) const
 {
@@ -245,7 +244,6 @@ COMPARE_RESULT PartitioningRequirement::comparePartReqToReq
   ABORT("Redefine PartitioningRequirement::comparePartReqToReq()");
   return INCOMPATIBLE;
 }
-// LCOV_EXCL_STOP
                                          
 // ***********************************************************************
 // FuzzyPartitioningRequirement
@@ -302,7 +300,6 @@ FuzzyPartitioningRequirement::copy() const
   return NULL;
 }
 
-// LCOV_EXCL_START
 void FuzzyPartitioningRequirement::print(FILE* ofd, const char* indent, 
                                          const char* title) const
 {
@@ -310,7 +307,6 @@ void FuzzyPartitioningRequirement::print(FILE* ofd, const char* indent,
 } 
 
 void FuzzyPartitioningRequirement::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // ***********************************************************************
 // FullySpecifiedPartitioningRequirement
@@ -486,7 +482,6 @@ FullySpecifiedPartitioningRequirement::copy() const
   return NULL;
 }
 
-// LCOV_EXCL_START
 void FullySpecifiedPartitioningRequirement::print
        (FILE* ofd, const char* indent, const char* title) const
 {
@@ -494,7 +489,6 @@ void FullySpecifiedPartitioningRequirement::print
 } 
 
 void FullySpecifiedPartitioningRequirement::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // RequireApproximatelyNPartitions
@@ -1260,7 +1254,6 @@ RequireApproximatelyNPartitions::copy() const
     new (CmpCommon::statementHeap()) RequireApproximatelyNPartitions(*this); 
 }
 
-// LCOV_EXCL_START
 void RequireApproximatelyNPartitions::print(FILE* ofd, const char* indent, 
 				       const char* title) const
 {
@@ -1268,7 +1261,6 @@ void RequireApproximatelyNPartitions::print(FILE* ofd, const char* indent,
 } 
 
 void RequireApproximatelyNPartitions::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 
 // -----------------------------------------------------------------------
@@ -1299,7 +1291,6 @@ RequireExactlyOnePartition::copy() const
     new (CmpCommon::statementHeap()) RequireExactlyOnePartition(*this); 
 }
 
-// LCOV_EXCL_START
 void RequireExactlyOnePartition::print(FILE* ofd, const char* indent, 
                                        const char* title) const
 {
@@ -1307,7 +1298,6 @@ void RequireExactlyOnePartition::print(FILE* ofd, const char* indent,
 } 
 
 void RequireExactlyOnePartition::display() const  { print(); }
-// LCOV_EXCL_STOP
 // -----------------------------------------------------------------------
 // RequireReplicateViaBroadcast
 // -----------------------------------------------------------------------
@@ -1370,7 +1360,6 @@ RequireReplicateViaBroadcast::copy() const
     new (CmpCommon::statementHeap()) RequireReplicateViaBroadcast(*this); 
 }
 
-// LCOV_EXCL_START
 void RequireReplicateViaBroadcast::print(FILE* ofd, const char* indent, 
                                          const char* title) const
 {
@@ -1378,7 +1367,6 @@ void RequireReplicateViaBroadcast::print(FILE* ofd, const char* indent,
 } 
 
 void RequireReplicateViaBroadcast::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // RequireReplicateNoBroadcast
@@ -1438,7 +1426,6 @@ RequireReplicateNoBroadcast::copy() const
     new (CmpCommon::statementHeap()) RequireReplicateNoBroadcast(*this); 
 }
 
-// LCOV_EXCL_START
 void RequireReplicateNoBroadcast::print(FILE* ofd, const char* indent, 
                                          const char* title) const
 {
@@ -1446,7 +1433,6 @@ void RequireReplicateNoBroadcast::print(FILE* ofd, const char* indent,
 } 
 
 void RequireReplicateNoBroadcast::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // RequireHash
@@ -1455,7 +1441,6 @@ void RequireReplicateNoBroadcast::display() const  { print(); }
 // -----------------------------------------------------------------------
 // Method for performing a pointer type cast
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START
 const RequireHash*
 RequireHash::castToRequireHash() const
   { return this; }
@@ -1474,7 +1459,6 @@ void RequireHash::print(FILE* ofd, const char* indent,
 } 
 
 void RequireHash::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // RequireHashDist
@@ -1510,7 +1494,6 @@ RequireHashDist::copy() const
     new (CmpCommon::statementHeap()) RequireHashDist(*this); 
 }
 
-// LCOV_EXCL_START
 void RequireHashDist::print(FILE* ofd, const char* indent, 
                         const char* title) const
 {
@@ -1518,7 +1501,6 @@ void RequireHashDist::print(FILE* ofd, const char* indent,
 } 
 
 void RequireHashDist::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // RequireHash2
@@ -1563,7 +1545,6 @@ RequireHash2::copy() const
     new (CmpCommon::statementHeap()) RequireHash2(*this);
 }
 
-// LCOV_EXCL_START
 void RequireHash2::print(FILE* ofd, const char* indent,
                         const char* title) const
 {
@@ -1571,7 +1552,6 @@ void RequireHash2::print(FILE* ofd, const char* indent,
 }
 
 void RequireHash2::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 //===========
 // -----------------------------------------------------------------------
@@ -1633,7 +1613,6 @@ RequireSkewed::copy() const
   return new (CmpCommon::statementHeap()) RequireSkewed(*this);
 }
 
-// LCOV_EXCL_START
 void RequireSkewed::print(FILE* ofd, const char* indent,
                         const char* title) const
 {
@@ -1641,7 +1620,6 @@ void RequireSkewed::print(FILE* ofd, const char* indent,
 }
 
 void RequireSkewed::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 
 // -----------------------------------------------------------------------
@@ -1662,7 +1640,6 @@ RequireRange::copy() const
     new (CmpCommon::statementHeap()) RequireRange(*this); 
 }
 
-// LCOV_EXCL_START
 void RequireRange::print(FILE* ofd, const char* indent, 
                          const char* title) const
 {
@@ -1670,13 +1647,11 @@ void RequireRange::print(FILE* ofd, const char* indent,
 } 
 
 void RequireRange::display() const  { print(); }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // RequireRoundRobin
 // -----------------------------------------------------------------------
 
-// LCOV_EXCL_START
 NABoolean
 RequireRoundRobin::
 partReqAndFuncCompatible(const PartitioningFunction* other) const
@@ -1715,7 +1690,6 @@ void RequireRoundRobin::print(FILE* ofd, const char* indent,
 
 void RequireRoundRobin::display() const  { print(); }
 
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // Methods for class LogicalPartitioningRequirement

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PartReq.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PartReq.h b/core/sql/optimizer/PartReq.h
index 8721666..7ad893e 100644
--- a/core/sql/optimizer/PartReq.h
+++ b/core/sql/optimizer/PartReq.h
@@ -199,10 +199,8 @@ public:
   virtual NABoolean isRequirementRange() const
     { return FALSE; }
 
-  // LCOV_EXCL_START
   virtual NABoolean isRequirementRoundRobin() const
     { return FALSE; }
-  // LCOV_EXCL_STOP
 
   virtual NABoolean isRequirementSkewBusterBroadcast() const
     { return FALSE; };
@@ -458,12 +456,10 @@ public:
        getPartitioningFunction()->isARangePartitioningFunction();
     }
 
-  // LCOV_EXCL_START
   virtual NABoolean isRequirementRoundRobin() const
     { return
        getPartitioningFunction()->isARoundRobinPartitioningFunction();
     }
-  // LCOV_EXCL_STOP
 
   virtual NABoolean isRequirementSkewBusterBroadcast() const;
 
@@ -996,7 +992,6 @@ public:
 }; // class RequireRange
 
 
-// LCOV_EXCL_START
 class RequireRoundRobin : public FullySpecifiedPartitioningRequirement
 {
 public:
@@ -1037,7 +1032,6 @@ public:
   virtual void display() const;
 
 }; // class RequireRoundRobin
-// LCOV_EXCL_STOP
 
 class RequireHive : public FullySpecifiedPartitioningRequirement
 {

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PhyProp.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PhyProp.cpp b/core/sql/optimizer/PhyProp.cpp
index c6aedc3..7849e47 100644
--- a/core/sql/optimizer/PhyProp.cpp
+++ b/core/sql/optimizer/PhyProp.cpp
@@ -52,7 +52,6 @@
 
 PhysicalProperty::~PhysicalProperty() {}
 
-// LCOV_EXCL_START
 void PhysicalProperty::print(FILE* ofd,
 			     const char * /* prefix */,
 			     const char * /* suffix */) const
@@ -93,7 +92,6 @@ NABoolean PhysicalProperty::isPartKeyPrefixOfSortKey() const
   return TRUE;
 
 } // PhysicalProperty::isPartKeyPrefixOfSortKey()
-// LCOV_EXCL_STOP
 
 // The following method is used by the overloaded implementations of
 // '<', '>', '==' for physical properties.
@@ -306,7 +304,6 @@ ReqdPhysicalProperty::~ReqdPhysicalProperty()
 }
 
 
-// LCOV_EXCL_START
 void ReqdPhysicalProperty::print(FILE* ofd,
 				 const char * /* prefix */,
 				 const char * /* suffix */) const
@@ -315,7 +312,6 @@ void ReqdPhysicalProperty::print(FILE* ofd,
  availableCPUs_, pipelinesPerCPU_);
 }
 
-// LCOV_EXCL_STOP
 
 // --------------------------------------------------------------------
 // does a given plan satisfy the required property
@@ -885,7 +881,6 @@ ReqdPhysicalProperty::compareRequirements(const ReqdPhysicalProperty &other) con
 } // ReqdPhysicalProperty::compareRequirements
 
 
-// LCOV_EXCL_START
 // Checked in M5. This function is never called
 RelExpr * ReqdPhysicalProperty::getInputMustMatch(Lng32 childIndex) const
 {
@@ -902,7 +897,6 @@ RelExpr * ReqdPhysicalProperty::getInputMustMatch(Lng32 childIndex) const
     else
       return NULL; // pattern has fewer children, no need for a match
 }
-// LCOV_EXCL_STOP
 
 // ||opt this method should never be called because we always
 // have a location requirement???

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/PhyProp.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PhyProp.h b/core/sql/optimizer/PhyProp.h
index 6207c28..79ccd23 100644
--- a/core/sql/optimizer/PhyProp.h
+++ b/core/sql/optimizer/PhyProp.h
@@ -266,7 +266,7 @@ public:
 
   // For determining if the partitioning key is a prefix of the
   // sort key (i.e. the clustering key) 
-  NABoolean isPartKeyPrefixOfSortKey() const; // LCOV_EXCL_LINE
+  NABoolean isPartKeyPrefixOfSortKey() const;
 
   // --- For sort key
   inline NABoolean isSorted() const   { return (sortKey_.entries() > 0); }
@@ -549,7 +549,6 @@ private:
 }; // class OptimizeForNRows
 
 // -- Optimize for first row - not used in SQ
-// LCOV_EXCL_START
 class OptimizeForFirstRow : public OptimizeForNRows
 {
 public:
@@ -558,7 +557,6 @@ public:
   virtual ~OptimizeForFirstRow() {}
 
 }; // class OptimizeForFirstRow
-// LCOV_EXCL_STOP
 
 // -- Optimize for last row
 class OptimizeForLastRow : public OptimizeForNRows
@@ -574,7 +572,6 @@ public:
 }; // class OptimizeForLastRow
 
 // -- Optimize for resource consumption - not used in SQ
-// LCOV_EXCL_START
 class OptimizeForResourceConsumption : public PerformanceGoal
 {
 public:
@@ -583,7 +580,6 @@ public:
   virtual NABoolean isOptimizeForResourceConsumption() const;
 
 }; // class OptimizeForResourceConsumption
-// LCOV_EXCL_STOP
 
 
 // -----------------------------------------------------------------------
@@ -991,7 +987,7 @@ public:
   // ---------------------------------------------------------------------
   inline const RelExpr * getMustMatch() const       { return mustMatch_; }
 
-  RelExpr* getInputMustMatch(Lng32 childIndex) const; // LCOV_EXCL_LINE
+  RelExpr* getInputMustMatch(Lng32 childIndex) const;
 
 
   void setPushDownRequirement(const PushDownRequirement* pdp) 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/QRDescGenerator.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/QRDescGenerator.cpp b/core/sql/optimizer/QRDescGenerator.cpp
index 9ea571c..9071018 100644
--- a/core/sql/optimizer/QRDescGenerator.cpp
+++ b/core/sql/optimizer/QRDescGenerator.cpp
@@ -103,11 +103,9 @@ void EqualitySet::determineType()
   if (isEmpty())
     {
       // I don't think this should happen.
-      // LCOV_EXCL_START :rfi
       QRLogger::log(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,
         "determineType() called for empty EqualitySet.");
       return;
-      // LCOV_EXCL_STOP
     }
 
   NABoolean isExact = FALSE, wasExact, isSigned = FALSE, isNullable = FALSE;
@@ -781,7 +779,6 @@ QRExplicitExprPtr QRDescGenerator::getExprTree(ItemExpr* itemExpr)
         }
         break;
 
-      // LCOV_EXCL_START :rfi
       case QR::QRNoElem:
       default:
         assertLogAndThrow1(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,
@@ -789,7 +786,6 @@ QRExplicitExprPtr QRDescGenerator::getExprTree(ItemExpr* itemExpr)
 			   "Unhandled ExprElement enum value: %d",
 			   itemExpr->getQRExprElem());
         return NULL;
-      // LCOV_EXCL_STOP
     }
   // make the compiler happy
   return NULL;
@@ -895,7 +891,6 @@ QRDescGenerator::genQRExpr(ItemExpr* pExpr,
 }  // genQRExpr()
 
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START :cnu
 NABoolean
 QRDescGenerator::normalizeColumnInExpression(NAString& pExprText,
 					     ValueId   colvid,
@@ -936,7 +931,6 @@ QRDescGenerator::normalizeColumnInExpression(NAString& pExprText,
   return bColFound;
 
 }  // normalizeColumnInExpression()
-// LCOV_EXCL_STOP
 
 void QRDescGenerator::markColumnsAsResidual(ValueIdSet& vegrefsInExpr)
 {
@@ -1328,14 +1322,12 @@ void QRDescGenerator::processJBBCList(CANodeIdSet* jbbcNodeIds,
           }
         else
           {
-            // LCOV_EXCL_START :rfi
             deletePtr(groupJbb);
             Int32 nodeIdVal = nodeId;
             assertLogAndThrow1(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,
                                FALSE, QRDescriptorException,
                                "Unsupported operator: %s",
                                nodeAnalysis->getOriginalExpr()->getText().data());
-            // LCOV_EXCL_STOP
           }
       }
   }
@@ -1818,7 +1810,6 @@ NABoolean QRDescGenerator::processJBBs(QRDescriptorPtr descPtr,
   return jbbElemsWereCreated;
 }
 
-// LCOV_EXCL_START :cnu
 void QRDescGenerator::logColumnBitmap(QRTablePtr table,
                                       const XMLBitmap& bitmap,
                                       ElementType predType)
@@ -1876,7 +1867,6 @@ void QRDescGenerator::logColumnBitmap(QRTablePtr table,
       
     }
 }  // logColumnBitmap()
-// LCOV_EXCL_STOP
 
 QRQueryDescriptorPtr QRDescGenerator::createQueryDescriptor(QueryAnalysis* qa,
                                                             RelExpr* expr)
@@ -1924,10 +1914,8 @@ QRMVDescriptorPtr QRDescGenerator::createMvDescriptor(QueryAnalysis* qa,
     }
   else
     {
-      // LCOV_EXCL_START :rfi  processJBBs should not return false for mv
       deletePtr(mvDesc);
       return NULL;
-      // LCOV_EXCL_STOP
     }
 }  // createMvDescriptor() 
 
@@ -3033,13 +3021,11 @@ void QRDescGenerator::setPredBitmap(QRValueId colVid, ElementType elemType)
         }
       else
         {
-          // LCOV_EXCL_START :rfi
           Int32 vidInt = vid;
           assertLogAndThrow2(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,
                             FALSE, QRDescriptorException,
                             "ValueId %d is not a base col or veg ref -- op type = %d",
                             vidInt, opType);
-          // LCOV_EXCL_STOP
         }
     }
   assertLogAndThrow1(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,
@@ -3063,7 +3049,7 @@ void QRDescGenerator::setPredBitmap(QRValueId colVid, ElementType elemType)
   else if (elemType == ET_ResidualPred)
     elem->downCastToQRTable()->setResidualBit(col->getColIndex());
   else
-    assertLogAndThrow1(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,  // LCOV_EXCL_LINE :rfi
+    assertLogAndThrow1(CAT_SQL_COMP_QR_DESC_GEN, LL_MVQR_FAIL,
                        FALSE, QRDescriptorException,
                        "Wrong element type sent to setPredBitmap() -- %d",
                        elemType);

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/QueryGraph.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/QueryGraph.cpp b/core/sql/optimizer/QueryGraph.cpp
index d75c900..ab64527 100644
--- a/core/sql/optimizer/QueryGraph.cpp
+++ b/core/sql/optimizer/QueryGraph.cpp
@@ -20,7 +20,6 @@
 //
 // @@@ END COPYRIGHT @@@
 **********************************************************************/
-// LCOV_EXCL_START
 // code that is not compiled, but for some reason is reported
 // just excluding the entire file
 #include "AppliedStatMan.h"
@@ -725,4 +724,3 @@ const CANodeIdSet * QueryGraphConnection::getBestIncomingReductionPath()
   return bestIncomingReductionPath_;
 }
 //QueryGraphConnection::getBestIncomingReductionPath
-// LCOV_EXCL_STOP

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/QueryRewriteHandler.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/QueryRewriteHandler.cpp b/core/sql/optimizer/QueryRewriteHandler.cpp
index b097a14..28bc812 100644
--- a/core/sql/optimizer/QueryRewriteHandler.cpp
+++ b/core/sql/optimizer/QueryRewriteHandler.cpp
@@ -52,7 +52,6 @@ void MvQueryRewriteHandler::createMvDescriptor(QueryAnalysis* qa, RelExpr* expr,
   {
     mvDescriptor_ = descGenerator.createMvDescriptor(qa, expr);
   }
-  // LCOV_EXCL_START :rfi
   catch (QRDescriptorException& ex)
   {
     QRLogger::log(CAT_SQL_COMP_QR_HANDLER, LL_MVQR_FAIL,
@@ -65,7 +64,6 @@ void MvQueryRewriteHandler::createMvDescriptor(QueryAnalysis* qa, RelExpr* expr,
       "An Unknown exception occurred while generating MV descriptor.");
     warningMessage = "Unknown internal error.";
   }
-  // LCOV_EXCL_STOP
 }
 
 // -----------------------------------------------------------------------
@@ -115,16 +113,13 @@ static QRRequestResult parseXML(char* xmlText, Int32 xmlLen,
 
       if (!descriptor)
         {
-          // LCOV_EXCL_START :rfi
           QRLogger::log(CAT_SQL_COMP_QR_HANDLER, LL_MVQR_FAIL,
             "XMLDocument.parse() returned NULL.");
           return XMLParseError;
-          // LCOV_EXCL_STOP
         }
       else
         ;//debugMessage("Parsed XML document successfully.");
     }
-  // LCOV_EXCL_START :rfi
   catch (XMLException& ex)
     {
       QRLogger::log(CAT_SQL_COMP_QR_HANDLER, LL_MVQR_FAIL,
@@ -143,7 +138,6 @@ static QRRequestResult parseXML(char* xmlText, Int32 xmlLen,
         "An Unknown exception occurred");
       return InternalError;
     }
-  // LCOV_EXCL_STOP
 
   return Success;
 }
@@ -250,7 +244,6 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
                    ? descGenerator.createXmlText(requestDescriptor)
                    : NULL);
   }
-  // LCOV_EXCL_START :rfi
   catch(QRDescriptorException e)
   {
     // Just ignore it and leave xmlText_ as NULL to skip the rest of this method.
@@ -272,7 +265,6 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
     warningMessage = "Internal error";
     return rootExpr;
   }
-  // LCOV_EXCL_STOP
 
   if (xmlText_ == NULL)
   {
@@ -313,13 +305,11 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
           IpcServer* qms = MvQueryRewriteServer::getQmsServer(publishDest);
           if (!qms)
           {
-            // LCOV_EXCL_START :rfi
             QRLogger::log(CAT_SQL_COMP_QR_IPC, LL_MVQR_FAIL,
               "Match failed due to inability to connect to QMS.");
             if (rootExpr->isAnalyzeOnly())
               rootExpr = handleAnalyzeOnlyQuery(rootExpr, "Can't connect to QMS");
             return rootExpr;  // Can't get a QMS
-            // LCOV_EXCL_STOP
           }
 	    
           // Do QMS MATCH protocol here.
@@ -345,19 +335,17 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
               xmlResponse->decrRefCount();
             }
           else
-            result = ProtocolError;  // LCOV_EXCL_LINE :rfi
+            result = ProtocolError;
 
           if (result == Success)
           {
             // Make sure the parsed document was a result descriptor.
             if (responseDescriptor->getElementType() !=  ET_ResultDescriptor)
             {
-              // LCOV_EXCL_START :rfi
               QRLogger::log(CAT_SQL_COMP_QR_HANDLER, LL_MVQR_FAIL,
                           "Response to MATCH request was an XML document with "
                           "document element <%s> instead of <%s>",
                           responseDescriptor->getElementName(), QRResultDescriptor::elemName);
-              // LCOV_EXCL_STOP
             }
             else
             {
@@ -369,7 +357,6 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
           }
         }
       }
-      // LCOV_EXCL_START :rfi
       catch(QRDescriptorException e)
       {
         // Exception has generated mx event, but not mvqr-logged. 
@@ -398,7 +385,6 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
           rootExpr = handleAnalyzeOnlyQuery(rootExpr, "Unknown exception thrown");
         return rootExpr;
       }
-      // LCOV_EXCL_STOP
     }
   
     delete xmlText_;
@@ -409,7 +395,6 @@ RelExpr* MvQueryRewriteHandler::handleMvQueryRewrite(QueryAnalysis* qa,
 }  // handleMvQueryRewrite()
 
 // -----------------------------------------------------------------------
-// LCOV_EXCL_START :dpm
 void MvQueryRewriteHandler::dumpToFile(const char* fileName, const char* data)
 {
   FILE *mvqr_fd = fopen(fileName, "w+");
@@ -421,7 +406,6 @@ void MvQueryRewriteHandler::dumpToFile(const char* fileName, const char* data)
     fclose(mvqr_fd);
   }
 }  // dumpToFile()
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 #if 0

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/QueryRewriteHandler.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/QueryRewriteHandler.h b/core/sql/optimizer/QueryRewriteHandler.h
index 48121d7..4dbe77f 100644
--- a/core/sql/optimizer/QueryRewriteHandler.h
+++ b/core/sql/optimizer/QueryRewriteHandler.h
@@ -41,7 +41,7 @@ class QRXmlMessageObj;
 
 //============================================================================
 class MvQueryRewriteHandler : public NABasicObject
-{ // LCOV_EXCL_LINE -- for some reason, LCOV marks this brace as "not covered"
+{ 
 public:
   MvQueryRewriteHandler(CollHeap* heap)
     : mvName_(heap),

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/Refresh.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Refresh.cpp b/core/sql/optimizer/Refresh.cpp
index aef4a04..ed575dd 100644
--- a/core/sql/optimizer/Refresh.cpp
+++ b/core/sql/optimizer/Refresh.cpp
@@ -687,7 +687,6 @@ const NAString Refresh::getText() const
 //////////////////////////////////////////////////////////////////////////////
 //////////////////////////////////////////////////////////////////////////////
 // Exclude from coverage testing - Must be implemented as a RelExpr subclass, but not used.
-// LCOV_EXCL_START
 RelExpr *Refresh::copyTopNode(RelExpr *derivedNode, CollHeap* outHeap)
 {
   Refresh *result = NULL;
@@ -726,7 +725,6 @@ RelExpr *Refresh::copyTopNode(RelExpr *derivedNode, CollHeap* outHeap)
 
   return BinderOnlyNode::copyTopNode(result, outHeap);
 }  // Refresh::copyTopNode()
-// LCOV_EXCL_STOP
 
 //////////////////////////////////////////////////////////////////////////////
 // Return the DeltaDefinition for the table named 'name'.

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/Rule.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Rule.cpp b/core/sql/optimizer/Rule.cpp
index 212a484..9e1e066 100644
--- a/core/sql/optimizer/Rule.cpp
+++ b/core/sql/optimizer/Rule.cpp
@@ -79,10 +79,8 @@ void ReinitRuleSet(RuleSet* rules)
 Rule::Rule (const char * name, RelExpr * pattern, RelExpr * substitute)
 {
   if (name == NULL)
-// LCOV_EXCL_START
 // all current rules have name, which is a good practice
     name_ = "no user name";
-// LCOV_EXCL_STOP
   else
     name_ = name;
 
@@ -97,16 +95,13 @@ Rule::Rule (const char * name, RelExpr * pattern, RelExpr * substitute)
 
 } // Rule::Rule
 
-// LCOV_EXCL_START
 // Rules are created once and never deleted
 Rule::~Rule ()
 {
   delete pattern_;
   delete substitute_;
 } // Rule::~Rule
-// LCOV_EXCL_STOP
 
-// LCOV_EXCL_START
 // print methods are for debugging
 void Rule::print (FILE * f, const char * prefix, const char * suffix)
 {
@@ -116,7 +111,6 @@ void Rule::print (FILE * f, const char * prefix, const char * suffix)
   substitute_ -> print (f, "  Substitute = ", "");
   fprintf (f, "%s\n", suffix);
 } // Rule::print
-// LCOV_EXCL_STOP
 
 NABoolean Rule::isImplementationRule() const
 {
@@ -395,14 +389,12 @@ RuleSet::RuleSet(Int32 approxNumRules, CollHeap* h) :
   initializeAllPasses();
 }
 
-// LCOV_EXCL_START
 // Rules are created once and never deleted
 RuleSet::~RuleSet()
 {
   for (Lng32 i = 0; i < (Lng32)allRules_.entries(); i++)
     delete allRules_[i];
 }
-// LCOV_EXCL_STOP
 
 void RuleSet::insert(Rule * r)
 {
@@ -513,7 +505,6 @@ void  RuleSet::initializeFirstPass()
   setTotalPasses();
 }
 
-// LCOV_EXCL_START
 // this is called by the old optimization driver i.e. RelExpr::optimize
 // the new optimization driver is method RelExpr::optimize2
 NABoolean RuleSet::nextPass()
@@ -527,7 +518,6 @@ NABoolean RuleSet::nextPass()
   else
     return FALSE;
 }
-// LCOV_EXCL_STOP
 
 void RuleSet::setCurrentPassNumber(Lng32 passNumber)
 {
@@ -594,7 +584,6 @@ NABoolean RulesPerContextList::applied (const Context * const context,
   return FALSE;
 }
 
-// LCOV_EXCL_START
 // not called anywhere in the code
 //
 // Has the provided rule been applied in any prior context which has the
@@ -613,7 +602,6 @@ NABoolean RulesPerContextList::applied (const EstLogPropSharedPtr& inputLogProp,
   }
   return FALSE;
 }
-// LCOV_EXCL_STOP
 
 void RulesPerContextList::addRule (const Context* const context,
 				   NAUnsigned ruleNumber)
@@ -641,7 +629,6 @@ void RulesPerContextList::addRule (const Context* const context,
   insertAt (0, newEntry);
 }
 
-// LCOV_EXCL_START
 // method is not called anywhere
 void RulesPerContextList::removeRule (const Context* const context,
 				   NAUnsigned ruleNumber)
@@ -659,7 +646,6 @@ void RulesPerContextList::removeRule (const Context* const context,
       i++;
   }
 }
-// LCOV_EXCL_STOP
 
 // -----------------------------------------------------------------------
 // methods for class Guidance

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/7a95e1da/core/sql/optimizer/Rule.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Rule.h b/core/sql/optimizer/Rule.h
index 452d75d..8337a6a 100644
--- a/core/sql/optimizer/Rule.h
+++ b/core/sql/optimizer/Rule.h
@@ -182,10 +182,8 @@ public:
 		      const char * suffix = "");
 
   // methods to get instance variables / data members
-// LCOV_EXCL_START
 // method is used by debug code and therefore not exercised in mainline code
   inline const char * getName () const                   { return name_; }
-// LCOV_EXCL_STOP
   inline RelExpr * getPattern () const                { return pattern_; }
   inline NAUnsigned getNumber() const              { return ruleNumber_; }
   inline RelExpr * getSubstitute () const          { return substitute_; }
@@ -344,12 +342,10 @@ public:
 
   // Methods dealing with the current pass number.
   inline void initializeCurrentPassNumber()          { currentPass_ = 0; }
-// LCOV_EXCL_START
 // method is called in an old code path not exercised any more
 // this gets called when RelExpr::optimize was used as the optimization
 // driver. The new driver (for quite some time now) is RelExpr::optimize2
   inline void incrementCurrentPassNumber()             { currentPass_++; }
-// LCOV_EXCL_STOP
 
   inline Lng32 getCurrentPassNumber() const        { return currentPass_; }
 
@@ -420,10 +416,8 @@ public:
 
   // accessor functions
   inline Lng32 getCountOfRules() const       { return allRules_.entries(); }
-// LCOV_EXCL_START
 // method is used in debugging and therefore not exercised in mainline code
   inline Int32 getRuleApplCount() const            { return ruleApplCount_; }
-// LCOV_EXCL_STOP
   inline void bumpRuleApplCount()                     { ruleApplCount_++; }
 
   inline const RuleSubset & oldRules()                { return oldRules_; }
@@ -509,13 +503,11 @@ public:
   // copy ctor
   RulesPerContext (const RulesPerContext &) ; // not written
 
-// LCOV_EXCL_START
 // destructors a generally not called for objects involved in
 // optimization (unless the class is heavy weight). This is 
 // because the entire statement heap is discarded at the end
 // of compilation.
   ~RulesPerContext() {}
-// LCOV_EXCL_STOP
 
   // Accessor methods
   inline const Context* getContext() const { return context_; }