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/10/02 00:14:09 UTC

[05/12] incubator-trafodion git commit: TRAFODION-2731 CodeCleanup: Phase 4. Remove legacy/obsolete pragmas

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/BindRelExpr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/BindRelExpr.cpp b/core/sql/optimizer/BindRelExpr.cpp
index 6085508..403a55b 100644
--- a/core/sql/optimizer/BindRelExpr.cpp
+++ b/core/sql/optimizer/BindRelExpr.cpp
@@ -163,7 +163,6 @@ static void GU_DEBUG_Display(BindWA *bindWA, GenericUpdate *gu,
 #endif
 } // GU_DEBUG_Display()
 
-#pragma nowarn(770)   // warning elimination
 static RETDesc *bindRowValues(BindWA *bindWA,
                               ItemExpr *exprTree,
                               ValueIdList &vidList,
@@ -609,7 +608,6 @@ static RETDesc *bindRowValues(BindWA *bindWA,
 
   return resultTable;
 } // bindRowValues()
-#pragma warn(770)  // warning elimination
 
 // Bind a constraint (MP Check Constraint).
 // Returns NULL if error in constraint *OR* we can safely ignore the constraint
@@ -3499,9 +3497,7 @@ RelExpr *Union::bindNode(BindWA *bindWA)
       ValueIdUnion(leftTable.getValueId(i),
                    rightTable.getValueId(i),
                    NULL_VALUE_ID,
-#pragma nowarn(1506)   // warning elimination
                    getUnionFlags());
-#pragma warn(1506)  // warning elimination
       vidUnion->setIsTrueUnion(TRUE);
       vidUnion->bindNode(bindWA);
       if (bindWA->errStatus()) {
@@ -6030,9 +6026,7 @@ RelExpr *RelRoot::bindNode(BindWA *bindWA)
       Lng32 sqlcode = (CmpCommon::context()->GetMode() == STMT_DYNAMIC) ?
       -4093 : -4094;
       *CmpCommon::diags() << DgSqlCode(sqlcode)
-#pragma nowarn(1506)   // warning elimination
       << DgInt0(outputVarCnt()) << DgInt1(getRETDesc()->getDegree());
-#pragma warn(1506)  // warning elimination
       bindWA->setErrStatus();
       return NULL;
     }
@@ -9000,9 +8994,7 @@ RelExpr *RenameTable::bindNode(BindWA *bindWA)
     if (derivedColList.entries() != sourceTable.getDegree()) {
       // 4016 The number of derived columns must equal the degree of the derived table.
       *CmpCommon::diags() << DgSqlCode(-4016)
-#pragma nowarn(1506)   // warning elimination
         << DgInt0(derivedColList.entries()) << DgInt1(sourceTable.getDegree());
-#pragma warn(1506)  // warning elimination
       bindWA->setErrStatus();
       delete resultTable;
       return this;
@@ -10117,9 +10109,7 @@ RelExpr *Insert::bindNode(BindWA *bindWA)
       if ((sourceTable.getDegree() != newTgtColList.entries())&& !bulkLoadIndex) {
       // 4023 degree of row value constructor must equal that of target table
       *CmpCommon::diags() << DgSqlCode(-4023)
-#pragma nowarn(1506)   // warning elimination
         << DgInt0(sourceTable.getDegree()) << DgInt1(tgtColList.entries());
-#pragma warn(1506)  // warning elimination
       bindWA->setErrStatus();
       return boundExpr;
       }
@@ -11336,12 +11326,8 @@ const char *Insert::getColDefaultValue(BindWA *bindWA, CollIndex i) const
   if (colList.entries() <= pos) {
     // 4023 degree of row value constructor must equal that of target table
     *CmpCommon::diags() << DgSqlCode(-4023)
-#pragma nowarn(1506)   // warning elimination
                         << DgInt0(++pos)
-#pragma warn(1506)  // warning elimination
-#pragma nowarn(1506)   // warning elimination
                         << DgInt1(colList.entries());
-#pragma warn(1506)  // warning elimination
     bindWA->setErrStatus();
     return NULL;
   }
@@ -12136,7 +12122,6 @@ static const char OLDTable [] = "OLD";    // QSTUFF:  corr for embedded d/u
 // the before image.
 // delete from tab set on rollback x = 1;
 // update tab set x = 1 set on rollback x = 2;
-#pragma nowarn(770)   // warning elimination
 void GenericUpdate::bindUpdateExpr(BindWA        *bindWA,
                                    ItemExpr      *recExpr,
                                    ItemExprList  &assignList,
@@ -12334,9 +12319,7 @@ void GenericUpdate::bindUpdateExpr(BindWA        *bindWA,
   // to the columns, of course.
   //
   CollIndex totalColCount = getTableDesc()->getColumnList().entries();
-#pragma nowarn(1506)   // warning elimination
   ValueIdArray holeyArray(totalColCount);
-#pragma warn(1506)  // warning elimination
   ValueId assignId;                                 // i'th newRecExpr valueid
   for (i = 0, assignId = newRecExpr.init();         // bizarre ValueIdSet iter
          newRecExpr.next(assignId);
@@ -12448,7 +12431,6 @@ void GenericUpdate::bindUpdateExpr(BindWA        *bindWA,
    CMPASSERT(j == a);
    bindWA->getCurrentScope()->setRETDesc(origScope);
 }
-#pragma warn(770)  // warning elimination
 
 void getScanPreds(RelExpr *start, ValueIdSet &preds)
 {
@@ -15116,9 +15098,7 @@ RelExpr *Transpose::bindNode(BindWA *bindWA)
 
         // Construct the constant value
         //
-#pragma nowarn(1506)   // warning elimination
         constExpr = new(bindWA->wHeap()) SystemLiteral(keyVal);
-#pragma warn(1506)  // warning elimination
 
         // Bind the constant value.
         //
@@ -15323,9 +15303,7 @@ RelExpr* Pack::bindNode(BindWA* bindWA)
   // ---------------------------------------------------------------------
 
   // Create and bind the packing factor item expression.
-#pragma nowarn(1506)   // warning elimination
   ItemExpr* pfie = new (bindWA->wHeap()) SystemLiteral(packingFactorLong());
-#pragma warn(1506)  // warning elimination
   pfie->bindNode(bindWA);
   if (bindWA->errStatus()) return this;
 
@@ -15348,14 +15326,10 @@ RelExpr* Pack::bindNode(BindWA* bindWA)
       // Add all columns to result table.
       NAString packedColName( "PACKEDCOL_", bindWA->wHeap());
       packedColName += bindWA->fabricateUniqueName();
-#pragma nowarn(1506)   // warning elimination
       Int32 length = packedColName.length();
-#pragma warn(1506)  // warning elimination
       char * colName = new (bindWA->wHeap()) char[length + 1];
       colName[length] = 0;
-#pragma nowarn(1506)   // warning elimination
       str_cpy_all(colName, packedColName, packedColName.length());
-#pragma warn(1506)  // warning elimination
 
       ColRefName colRefName(colName);
       resultTable->addColumn(bindWA,
@@ -15440,10 +15414,8 @@ RelExpr* Pack::bindNode(BindWA* bindWA)
             &(packedCols[i].getItemExpr()->child(0)->getValueId().getType());
 
       Lng32 width = colType->getNominalSize();
-#pragma nowarn(1506)   // warning elimination
       Lng32 base = (colType->supportsSQLnullPhysical() ? (pf-1)/CHAR_BIT +1 : 0)
                    + sizeof(Int32);
-#pragma warn(1506)  // warning elimination
 
       // $$$ Some duplicate code to be moved to PackColDesc later.
       ColRefName colRefName;
@@ -16097,9 +16069,7 @@ RelExpr * RowsetInto::bindNode(BindWA* bindWA)
   if (numOutputHostvars != childTableVidList.entries()) {
     // 4094 The number of output host vars  ($0) must equal the number of cols
     *CmpCommon::diags() << DgSqlCode(-4094)
-#pragma nowarn(1506)   // warning elimination
       << DgInt0(numOutputHostvars) << DgInt1(childTableVidList.entries());
-#pragma warn(1506)  // warning elimination
     bindWA->setErrStatus();
     return NULL;
   }
@@ -16914,13 +16884,11 @@ void CallSP::setInOrOutParam ( ItemExpr *expr,
       if ( throwInTranslateNode == FALSE )
       {
         // Error, data types dont match
-#pragma nowarn(1506)   // warning elimination
         *CmpCommon::diags() <<  DgSqlCode(-UDR_BINDER_PARAM_TYPE_MISMATCH)
                             << DgInt0 (ordinalPosition)
                             << DgTableName(getRoutineName().getQualifiedNameAsString())
                             << DgString0 (inputType.getTypeSQLname (TRUE))
                             << DgString1 (paramType.getTypeSQLname (TRUE));
-#pragma warn(1506)  // warning elimination
         bindWA->setErrStatus ();
         return;
       }
@@ -16968,11 +16936,9 @@ void CallSP::setInOrOutParam ( ItemExpr *expr,
     if (!( ITM_HOSTVAR == expr->getOperatorType () ||
            ITM_DYN_PARAM == expr->getOperatorType ()))
     {
-#pragma nowarn(1506)   // warning elimination
       *CmpCommon::diags() << DgSqlCode(-UDR_BINDER_OUTVAR_NOT_HV_OR_DP)
                           << DgInt0(ordinalPosition)
                           << DgTableName(getRoutineName().getQualifiedNameAsString());
-#pragma warn(1506)  // warning elimination
       bindWA->setErrStatus ();
       return;
     } // if NOT HOSTVAR or DYNAMIC PARAM

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/BindWA.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/BindWA.cpp b/core/sql/optimizer/BindWA.cpp
index 8e8c89a..a6e19d8 100644
--- a/core/sql/optimizer/BindWA.cpp
+++ b/core/sql/optimizer/BindWA.cpp
@@ -1095,9 +1095,7 @@ void HostArraysWA::processArrayHostVar(ItemExpr *parent, Int32 childNumber)
       // an INSERT, for instance, the types will be determined in the Insert node
       SQLRowset *rowsetType = 
         new (bindWA_->wHeap()) SQLRowset(bindWA_->wHeap(), (new (bindWA_->wHeap()) SQLUnknown(bindWA_->wHeap())),
-#pragma nowarn(1506)   // warning elimination 
                                           size, size);
-#pragma warn(1506)  // warning elimination 
       NAString name = param->getName();
       if (name.isNull()) {
         name = "__array" + bindWA_->fabricateUniqueName();

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/CascadesBasic.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/CascadesBasic.h b/core/sql/optimizer/CascadesBasic.h
index a8915d7..1a7cf68 100644
--- a/core/sql/optimizer/CascadesBasic.h
+++ b/core/sql/optimizer/CascadesBasic.h
@@ -82,7 +82,6 @@ class HashValue : public NABasicObject
 {
 public:
 
-// warning elimination (removed "inline")
   HashValue(ULng32 v = 0x0) { val_ = v; }
 
   inline NABoolean operator == (const HashValue &other)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ChangesTable.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ChangesTable.cpp b/core/sql/optimizer/ChangesTable.cpp
index f6a9b29..7f62890 100644
--- a/core/sql/optimizer/ChangesTable.cpp
+++ b/core/sql/optimizer/ChangesTable.cpp
@@ -249,9 +249,7 @@ RelExpr *ChangesTable::buildInsert(NABoolean useLeafInsert,
   ItemExpr *delColExpr, *insColExpr;
   for (CollIndex i=0; i < tempColumns.entries(); i++) 
   {
-#pragma nowarn(1506)   // warning elimination 
     NAColumn *currentTempCol = tempColumns.getColumn(i);
-#pragma warn(1506)  // warning elimination 
     const NAString& colName = currentTempCol->getColName();
 
     delColExpr = insColExpr = NULL;
@@ -465,9 +463,7 @@ ItemExpr *ChangesTable::buildBaseColsSelectList(const CorrName& tableName) const
 
   for (CollIndex i=0; i<subjectColumns.entries(); i++) 
   {
-#pragma nowarn(1506)   // warning elimination 
     NAString colName(subjectColumns.getColumn(i)->getColName());
-#pragma warn(1506)  // warning elimination 
     if (!colName.compareTo("SYSKEY"))
       continue;  // Skip SYSKEY.
 
@@ -498,9 +494,7 @@ ChangesTable::buildColsCorrespondingToBaseSelectList() const
 
   for (CollIndex i=0; i<columns.entries(); i++) 
   {
-#pragma nowarn(1506)   // warning elimination 
     NAString colName(columns.getColumn(i)->getColName());
-#pragma warn(1506)  // warning elimination 
     if (colName.data()[0] == '@' && colName.compareTo("@SYSKEY"))
       continue;  // Skip any special column that is not @SYSKEY.
 
@@ -581,9 +575,7 @@ ItemExpr *ChangesTable::buildRenameColsList() const
 
   for (CollIndex i=0; i<subjectColumns.entries(); i++) 
   {
-#pragma nowarn(1506)   // warning elimination 
     const NAString subjectCol(subjectColumns.getColumn(i)->getColName());
-#pragma warn(1506)  // warning elimination 
     const NAString *colName = &subjectCol;
     if (!subjectCol.compareTo("SYSKEY"))
     {
@@ -1247,7 +1239,6 @@ ItemExpr *MvIudLog::buildLogEpochPredicate(const DeltaDefinition *deltaDef,
 //		       We use here a special builtin function that evalutes
 //		       this expression
 //////////////////////////////////////////////////////////////////////////////
-#pragma nowarn(262)   // warning elimination 
 ItemExpr *MvIudLog::createSpecificWhereExpr(RowsType type) const
 {
   CMPASSERT(deltaDef_ != NULL);
@@ -1333,7 +1324,6 @@ ItemExpr *MvIudLog::createSpecificWhereExpr(RowsType type) const
 
   return result;
 }
-#pragma warn(262)  // warning elimination 
 
 //////////////////////////////////////////////////////////////////////////////
 // The orig selection predicate is on the base table columns. This recursive 
@@ -1387,9 +1377,7 @@ ItemExpr *MvIudLog::buildOrigScanPredicate() const
     parser.getItemExprTree((char *)textPredicate.data());
 
   ItemExprList predicateList(origScanPredicate, bindWA_->wHeap(), ITM_AND);
-#pragma nowarn(1506)   // warning elimination 
   for (Int32 i=predicateList.entries()-1; i>=0; i--)
-#pragma warn(1506)  // warning elimination 
   {
     if (fixReferencesFromBaseTableToLog(predicateList[i]) == FALSE)
       predicateList.removeAt(i);
@@ -1453,9 +1441,7 @@ ItemExpr *MvIudLog::constructUpdateBitmapFromList(const LIST(Lng32) &columnList)
   
   for (CollIndex i=0; i < logColumns.entries(); i++) 
   {
-#pragma nowarn(1506)   // warning elimination 
     currentTempCol = logColumns.getColumn(i);
-#pragma warn(1506)  // warning elimination 
     if (!currentTempCol->getColName().compareTo(COMMV_BITMAP_COL))
       break;
   }

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ClusteredBitmap.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ClusteredBitmap.cpp b/core/sql/optimizer/ClusteredBitmap.cpp
index e530246..8c75b3f 100644
--- a/core/sql/optimizer/ClusteredBitmap.cpp
+++ b/core/sql/optimizer/ClusteredBitmap.cpp
@@ -42,12 +42,6 @@
 #include "ClusteredBitmap.h"
 
 
-#ifdef WIN32
-// The firstSetBit() function produces a warning on Windows.
-// Turn it off temporarily.
-#pragma warning( disable : 4146 ) // disable "unsigned" warnings
-#endif // WIN32
-
 // Isolate the first set bit in the integer value.
 inline ClusteredBitmap::cb_int_t 
 ClusteredBitmap::firstSetBit(cb_int_t value)
@@ -55,10 +49,6 @@ ClusteredBitmap::firstSetBit(cb_int_t value)
   return value & (-value);
 }
 
-#ifdef WIN32
-#pragma warning( default : 4146 ) // allow "unsigned" warnings
-#endif // WIN32
-
 // Return the significant bits for a particular value.  The
 // significant bits are bits 9-31 and are used as a lookup
 // value in the bitmapMap_ array.

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ColStatDesc.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ColStatDesc.cpp b/core/sql/optimizer/ColStatDesc.cpp
index f5a6f65..8623526 100644
--- a/core/sql/optimizer/ColStatDesc.cpp
+++ b/core/sql/optimizer/ColStatDesc.cpp
@@ -3780,7 +3780,6 @@ ColStatDescList::identifyMergeCandidates (ItemExpr * operand,
 // This is the new version of this function which facilitates applying all
 // predicates at once.
 // -----------------------------------------------------------------------
-#pragma nowarn(770)   // warning elimination
 NABoolean
 ColStatDescList::applyVEGPred (ItemExpr *VEGpred,
                                CostScalar & rowcount,
@@ -4119,9 +4118,7 @@ ColStatDescList::applyVEGPred (ItemExpr *VEGpred,
     // statsToMerge
 
     //NB: i is unsigned, so this loop as-is should never terminate
-#pragma nowarn(270)   // warning elimination
     for ( i = statsToMerge.entries() - 1; i >= 0; i-- )
-#pragma warn(270)  // warning elimination
     {
       if (statsToMerge[i] != rootStatIndex)
       {
@@ -4243,7 +4240,6 @@ ColStatDescList::applyVEGPred (ItemExpr *VEGpred,
   return appliedPredicateFlag;
 
 } // applyVEGPred
-#pragma warn(770)  // warning elimination
 
 // -----------------------------------------------------------------------
 //  ColStatDescList::applyBiLogicPred
@@ -4771,7 +4767,6 @@ ColStatDescList::applyBiLogicPred(CostScalar & tempRowcount,
 	ValueIdSet matchedRight;
 	CollIndex currentL, currentR;
 
-#pragma nowarn(262)   // warning elimination
 	if( this->entries() != copyStatsList.entries() )
 	{
 	  // copyStatsList is a copy of THIS statsList, during
@@ -4779,7 +4774,6 @@ ColStatDescList::applyBiLogicPred(CostScalar & tempRowcount,
 	  // the copy, we should not have dropped any columns.
 	  Int32 stophere = 0;
 	}
-#pragma warn(262)  // warning elimination
 
 	for( currentL = 0; currentL < entries(); currentL++ )
 	{
@@ -4868,14 +4862,12 @@ ColStatDescList::applyBiLogicPred(CostScalar & tempRowcount,
 	  }
 	}  // for     (currentL)
 
-#pragma nowarn(262)   // warning elimination
 	if( copyStatsList.entries() != 0 )
 	{
       CCMPASSERT (copyStatsList.entries() == 0);
 	  // The OR merge between THIS and the copy did not go properly
 	  return newRowCount;
 	}
-#pragma warn(262)  // warning elimination
 
 	// Determine the resultant rowcount.  If not all columns overlapped,
 	// use previously determined rowcount
@@ -8360,7 +8352,6 @@ ColStatDescList::getColStatDescIndex (CollIndex& index,           /* out */
 //  ColStatDescList
 // -----------------------------------------------------------------------
 
-#pragma nowarn(262)   // warning elimination
 ColStatsSharedPtr
 ColStatDescList::getColStatsPtrForColumn (const ValueId& inputColumn) const
 {
@@ -8374,7 +8365,6 @@ ColStatDescList::getColStatsPtrForColumn (const ValueId& inputColumn) const
   }
   else
   {
-#pragma nowarn(270)   // warning elimination
     if ((index < 0) || (index >= entries()) )
     {
       // if the index is out side the range of histogram list, return
@@ -8384,11 +8374,9 @@ ColStatDescList::getColStatsPtrForColumn (const ValueId& inputColumn) const
       return NULL;
     }
 
-#pragma warn(270)  // warning elimination
     return (*this)[index]->getColStats();
   }
 }
-#pragma warn(262)  // warning elimination
 
 // -----------------------------------------------------------------------
 // This method returns the ColStatsSharedPtr for the ColStats that references
@@ -9468,7 +9456,6 @@ MultiColumnUecList::findDenom (const ValueIdSet & columns) const
 ULng32 TableDescHashFn (const TableDesc & tablePtr)
 { return (ULng32)((Long)&tablePtr/8) ; }
 
-#pragma nowarn(262)   // warning elimination
 NABoolean
 MultiColumnUecList::useMCUecForCorrPreds (
      NAHashDictionary<ValueId, CostScalar> & predReductions, /* in/mod */
@@ -9784,7 +9771,6 @@ MultiColumnUecList::useMCUecForCorrPreds (
 			     numPredicates );
     return TRUE;
 }
-#pragma warn(262)  // warning elimination
 
 NABoolean 
 MultiColumnUecList::createMCStatsForColumnSet(ValueIdSet colsWithReductions, 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ColumnDesc.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ColumnDesc.h b/core/sql/optimizer/ColumnDesc.h
index 8d32e0b..5475d45 100644
--- a/core/sql/optimizer/ColumnDesc.h
+++ b/core/sql/optimizer/ColumnDesc.h
@@ -49,7 +49,6 @@ class ColumnDescList;
 // ***********************************************************************
 // ColumnDesc : A column descriptor
 // ***********************************************************************
-#pragma nowarn(1506)   // warning elimination 
 class ColumnDesc : public NABasicObject
 {
 public:
@@ -145,7 +144,6 @@ private:
   const char * viewFileName_;
 
 }; // class ColumnDesc
-#pragma warn(1506)  // warning elimination 
 
 // ***********************************************************************
 // ColumnDescList : A list of column descriptors

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ColumnNameMap.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ColumnNameMap.h b/core/sql/optimizer/ColumnNameMap.h
index 0f31955..e161aea 100644
--- a/core/sql/optimizer/ColumnNameMap.h
+++ b/core/sql/optimizer/ColumnNameMap.h
@@ -67,7 +67,6 @@ class XCNM;
 // whose name is exposed in a given scope.
 // 
 // ***********************************************************************
-#pragma nowarn(1506)   // warning elimination 
 class ColumnNameMap : public NABasicObject
 {
 public:
@@ -198,7 +197,6 @@ private:
   NABoolean qualColAmbiguousFlag_;
 
 }; // class ColumnNameMap
-#pragma warn(1506)  // warning elimination 
 
 // ***********************************************************************
 // Implementation for inline functions

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ControlDB.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ControlDB.cpp b/core/sql/optimizer/ControlDB.cpp
index 4af0d81..cd64594 100644
--- a/core/sql/optimizer/ControlDB.cpp
+++ b/core/sql/optimizer/ControlDB.cpp
@@ -1133,18 +1133,14 @@ void ControlTableOptions::addTokenAndValue(const NAString &token,
 
 const NAString &ControlTableOptions::getToken(CollIndex index)
 {
-#pragma nowarn(270)   // warning elimination
   CMPASSERT((index >= 0) && (index < tokens_->entries()));
-#pragma warn(270)  // warning elimination
 
   return *((*tokens_)[index]);
 }
 
 const NAString &ControlTableOptions::getValue(CollIndex index)
 {
-#pragma nowarn(270)   // warning elimination
   CMPASSERT((index >= 0) && (index < values_->entries()));
-#pragma warn(270)  // warning elimination
 
   return *((*values_)[index]);
 }
@@ -1595,9 +1591,7 @@ ExprNode *DecodeShapeSyntax(const NAString &fname,
       fname == "FILE_SCAN" OR
       fname == "INDEX_SCAN")
     {
-#pragma nowarn(1506)   // warning elimination
       Int32 numArgs = args->entries();
-#pragma warn(1506)  // warning elimination
       Int32 firstNonStringArg=0;
       NAString tableName(CmpCommon::statementHeap());
       NAString indexName(CmpCommon::statementHeap());
@@ -1709,9 +1703,7 @@ ExprNode *DecodeShapeSyntax(const NAString &fname,
     {
       result = new (heap) ScanForceWildCard();
       NABoolean dummyNegate = FALSE;
-#pragma nowarn(1506)   // warning elimination
       Int32 numColumns = args->entries();
-#pragma warn(1506)  // warning elimination
       ItemExpr *itm;
 
       ScanForceWildCard::scanOptionEnum* columnAlgorithms
@@ -1938,9 +1930,7 @@ ExprNode *DecodeShapeSyntax(const NAString &fname,
     }
   else if (fname == "ISOLATED_SCALAR_UDF")
     {
-#pragma nowarn(1506)   // warning elimination
       Int32 numArgs = args->entries();
-#pragma warn(1506)  // warning elimination
       if (numArgs > 2)
       {
         // No more than two arguments allowed.

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/Cost.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Cost.h b/core/sql/optimizer/Cost.h
index 26600ae..e5c1cfc 100644
--- a/core/sql/optimizer/Cost.h
+++ b/core/sql/optimizer/Cost.h
@@ -905,7 +905,6 @@ class CostWeight : public NABasicObject
 {
 public:
 
-// warning elimination (removed "inline")
   virtual ~CostWeight() {}
 
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/CostVector.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/CostVector.h b/core/sql/optimizer/CostVector.h
index 3f90647..78c91be 100644
--- a/core/sql/optimizer/CostVector.h
+++ b/core/sql/optimizer/CostVector.h
@@ -76,7 +76,6 @@ class CostVector : public NABasicObject
 {
 public:
 
-// warning elimination (removed "inline)
   virtual ~CostVector() {}
 
   // A virtual method that returns the number of entries.
@@ -287,14 +286,12 @@ j*/
 
   SimpleCostVector(const SimpleCostVector &other);
 
-// warning elimination (removed "inline")
   virtual CostVector* copy() const
     { return new(CmpCommon::statementHeap()) SimpleCostVector(*this); }
 
   // ---------------------------------------------------------------------
   // Destructor
   // ---------------------------------------------------------------------
-// warning elimination (removed "inline")
   ~SimpleCostVector() {}
 
   // ---------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/EncodedValue.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/EncodedValue.cpp b/core/sql/optimizer/EncodedValue.cpp
index 0e769ef..cd0bc0d 100644
--- a/core/sql/optimizer/EncodedValue.cpp
+++ b/core/sql/optimizer/EncodedValue.cpp
@@ -645,7 +645,6 @@ EncodedValue::EncodedValue (ItemExpr *expr,
   addANormValue(this,expr,negate);
 }
 
-#pragma nowarn(262)   // warning elimination 
 void
 EncodedValue::constructorFunction (const NAWchar * theValue,
                                    const NAColumnArray &columns, 
@@ -803,7 +802,6 @@ EncodedValue::constructorFunction (const NAWchar * theValue,
 	// invoke parser to parse the char string and generate a ConstValue
         Parser parser(CmpCommon::context());
 
-#pragma nowarn(1506)   // warning elimination 
                          // Leave space for both semi-colon and null
                          // next points to the next char after the value
         Int32 numChars = MINOF(BOUNDARY_LEN-2,na_wcslen(item)-na_wcslen(next));
@@ -846,9 +844,7 @@ EncodedValue::constructorFunction (const NAWchar * theValue,
         buf[numChars+prefixLen] = L';';
         buf[numChars+prefixLen+1] = L'\0';
        
-#pragma warn(1506)  // warning elimination 
 
-#pragma warn(1506)  // warning elimination 
 
 	NABoolean negate = FALSE;
 
@@ -933,7 +929,6 @@ EncodedValue::constructorFunction (const NAWchar * theValue,
 
   return;
 }
-#pragma warn(262)  // warning elimination 
 
 // -----------------------------------------------------------------------
 //  Given an upper and lower bound, represented in multi-attribute

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/EstLogProp.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/EstLogProp.h b/core/sql/optimizer/EstLogProp.h
index 959a3fa..3400dd1 100644
--- a/core/sql/optimizer/EstLogProp.h
+++ b/core/sql/optimizer/EstLogProp.h
@@ -94,12 +94,10 @@ public:
   // ---------------------------------------------------------------------
   //  Accessor Functions
   // ---------------------------------------------------------------------
-// warning elimination (removed "inline")
   CostScalar getResultCardinality() const 
   { CCMPASSERT (resultCardinality_ >= 0) ; 
     return resultCardinality_; 
   }
-// warning elimination (removed "inline")
   void setResultCardinality(CostScalar v)
   { CCMPASSERT (v >= 0) ;
     v.round();

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/GroupAttr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/GroupAttr.cpp b/core/sql/optimizer/GroupAttr.cpp
index 7e87bb6..30a04fd 100644
--- a/core/sql/optimizer/GroupAttr.cpp
+++ b/core/sql/optimizer/GroupAttr.cpp
@@ -908,7 +908,6 @@ HashValue GroupAttributes::hash() const
 //          covered by a partitioning requirement that has no part key cols
 // Returns: A list that is a prefix of the chosen index sort key.
 // -----------------------------------------------------------------------
-#pragma nowarn(770)   // warning elimination
 ValueIdList GroupAttributes::recommendedOrderForNJProbing(
                                GroupAttributes* child0GA, // IN
                                Lng32 numForcedParts, //IN
@@ -1011,9 +1010,7 @@ ValueIdList GroupAttributes::recommendedOrderForNJProbing(
                           getCharacteristicInputs(),
                           currentIndexUncoveredCols);
 
-#pragma nowarn(1506)   // warning elimination
     currentIndexNumUncoveredCols = currentIndexUncoveredCols.entries();
-#pragma warn(1506)  // warning elimination
 
     // The current index must have at least one equijoincolumn to use it.
     if (currentIndexOrder.entries() == 0)
@@ -1259,7 +1256,6 @@ ValueIdList GroupAttributes::recommendedOrderForNJProbing(
   return chosenIndexOrder;
 
 } // GroupAttributes::recommendedOrderForNJProbing()
-#pragma warn(770)  // warning elimination
 
 // -----------------------------------------------------------------------
 // coverTest()
@@ -2346,9 +2342,7 @@ Int32 GroupAttributes::existsInputLogProp (const EstLogPropSharedPtr& inputLP) c
   for (CollIndex i = 0; i < inputEstLogProp_.entries(); i++)
   {
     if (inputEstLogProp_[i]->compareEstLogProp (inputLP) == SAME)
-#pragma nowarn(1506)   // warning elimination
       return i;
-#pragma warn(1506)  // warning elimination
   }
   return -1;
 }

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ImplRule.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ImplRule.cpp b/core/sql/optimizer/ImplRule.cpp
index 38c9ff0..bbd4659 100644
--- a/core/sql/optimizer/ImplRule.cpp
+++ b/core/sql/optimizer/ImplRule.cpp
@@ -1621,7 +1621,6 @@ RelExpr * FileScanRule::nextSubstitute(RelExpr * before,
    return generateScanSubstitutes(before, context, memory, FALSE);
 }
 
-#pragma warn(770)  // warning elimination
 
 // -----------------------------------------------------------------------
 // methods for class HbaseScanRule
@@ -4084,7 +4083,6 @@ PhysicalPackRule::~PhysicalPackRule()
 }
 
 // PhysicalPackRule::topMatch()
-#pragma nowarn(262)   // warning elimination
 NABoolean PhysicalPackRule::topMatch(RelExpr* relExpr, Context* context)
 {
   // Match the node type first.
@@ -4205,7 +4203,6 @@ NABoolean PhysicalPackRule::topMatch(RelExpr* relExpr, Context* context)
 
   return TRUE;
 }
-#pragma warn(262)  // warning elimination
 
 RelExpr* PhysicalPackRule::nextSubstitute(RelExpr* before,
                                           Context* /*context*/,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/IndexDesc.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/IndexDesc.cpp b/core/sql/optimizer/IndexDesc.cpp
index 9ae1518..dfb9593 100644
--- a/core/sql/optimizer/IndexDesc.cpp
+++ b/core/sql/optimizer/IndexDesc.cpp
@@ -101,9 +101,7 @@ IndexDesc::IndexDesc(TableDesc *tdesc,
 	  baseItemExpr = NULL;
 	}
 
-#pragma nowarn(1506)   // warning elimination 
       IndexColumn *ixcol = new(wHeap()) IndexColumn(fileSet_,i,baseValueId);
-#pragma warn(1506)  // warning elimination 
       ixcol->synthTypeAndValueId();
 
       // add the newly obtained value id to the index column list
@@ -125,7 +123,6 @@ IndexDesc::IndexDesc(TableDesc *tdesc,
   for (i = 0; i < indexKeyColumns.entries(); i++)
     {
       // which column of the index is this (usually this will be == i)
-#pragma nowarn(1506)   // warning elimination 
 
       if ( !naTable->isHbaseTable() )
          ixColNumber = allColumns.index(indexKeyColumns[i]);
@@ -139,7 +136,6 @@ IndexDesc::IndexDesc(TableDesc *tdesc,
          CMPASSERT(ixColNumber >= 0);
       }
 
-#pragma warn(1506)  // warning elimination 
 
       // insert the value id of the index column into the key column
       // value id list
@@ -173,9 +169,7 @@ IndexDesc::IndexDesc(TableDesc *tdesc,
   for (i = 0; i < clustKeyColumns.entries() AND found; i++)
     {
       // which column of the index is this?
-#pragma nowarn(1506)   // warning elimination 
       ixColNumber = allColumns.index(clustKeyColumns[i]);
-#pragma warn(1506)  // warning elimination 
 
       found = (ixColNumber != NULL_COLL_INDEX);
 
@@ -203,9 +197,7 @@ IndexDesc::IndexDesc(TableDesc *tdesc,
   for (i = 0; i < partitioningKeyColumns.entries(); i++)
     {
       // which column of the index is this 
-#pragma nowarn(1506)   // warning elimination 
       ixColNumber = allColumns.index(partitioningKeyColumns[i]);
-#pragma warn(1506)  // warning elimination 
 
       // insert the value id of the index column into the partitioningkey column
       // value id list
@@ -301,12 +293,9 @@ int IndexDesc::indexHintPriorityDelta() const
 }
 
 // Print function
-#pragma nowarn(770)   // warning elimination
 void IndexDesc::print(FILE* ofd, const char* indent, const char* title)
 {
-#pragma nowarn(1506)   // warning elimination 
   BUMP_INDENT(indent);
-#pragma warn(1506)  // warning elimination  
   cout << title << " " << this << " "
     << indexLevels_ << "," << clusteringIndexFlag_
     << " pf=" << partFunc_ << " fs=" << fileSet_
@@ -316,7 +305,6 @@ void IndexDesc::print(FILE* ofd, const char* indent, const char* title)
   orderOfKeyValues_.print(ofd, indent, "IndexDesc::orderOfKeyValues_");
   clusteringKey_.print(ofd, indent, "IndexDesc::clusteringKey_");
 }
-#pragma warn(770)  // warning elimination 
 
 // Get the statement heap
 CollHeap* IndexDesc::wHeap()
@@ -469,10 +457,8 @@ IndexDesc::getEstimatedIndexBlocksLowerBound(const CostScalar& probes) const
       indexBlocksLowerBound = MINOF( indexBlocks, probes );
 
       // Index blocks touch by all probes for level three and above:
-#pragma warning (disable : 4018)   //warning elimination
       for (CollIndex i=2; i < levels; i++)
 	{
-#pragma warning (default : 4018)   //warning elimination
 	  indexBlocks = indexBlocks*40;
 	  indexBlocksLowerBound += MINOF( indexBlocks, probes );
 	}
@@ -573,9 +559,7 @@ NABoolean IndexDesc::isUniqueIndex() const
 
   return  getNAFileSet()->uniqueIndex();
 
-#pragma nowarn(269)   // warning elimination 
   ValueIdList nonKeyColumnList;
-#pragma warn(269)  // warning elimination 
   getNonKeyColumnList(nonKeyColumnList);
   
   // if there are some non-index-key columns(the key of base table),

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/Inlining.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/Inlining.cpp b/core/sql/optimizer/Inlining.cpp
index 6b7ebd2..234acf5 100644
--- a/core/sql/optimizer/Inlining.cpp
+++ b/core/sql/optimizer/Inlining.cpp
@@ -893,9 +893,7 @@ static ItemExpr *addCheckForTriggerEnabled(BindWA    *bindWA,
 
   ItemExpr *enableCheck = new(heap) 
     GetBitValueAt(new(heap) GetTriggersStatus(), 
-#pragma nowarn(1506)   // warning elimination 
 		  new(heap) ConstValue(triggerIndex) );
-#pragma warn(1506)  // warning elimination 
 
   // Check if whenClause is empty or TRUE
   if (whenClause == NULL || whenClause->getOperatorType() == ITM_RETURN_TRUE)
@@ -1632,14 +1630,10 @@ RelExpr *Update::createEffectiveGU(BindWA   *bindWA,
   for (CollIndex i=0; i<subjectColumns.entries(); i++)
   {
     // If this column was not SET into, no need to change it.
-#pragma nowarn(1506)   // warning elimination 
     if (!colsToSet->contains(i))
-#pragma warn(1506)  // warning elimination 
       continue;
 
-#pragma nowarn(1506)   // warning elimination 
     NAColumn *currentColumn = subjectColumns.getColumn(i);
-#pragma warn(1506)  // warning elimination 
     const NAString &colName = currentColumn->getColName();
 
     // Cannot update a clustering/primary key column!
@@ -2281,9 +2275,7 @@ RelExpr * GenericUpdate::createUndoTempTable(TriggersTempTable *tempTableObj,Bin
   tempCorrName.setCorrName( NEWCorr);
   for (CollIndex i=0; i<tempColumns.entries(); i++) 
     {
-#pragma nowarn(1506)   // warning elimination 
       NAString tempColName(tempColumns.getColumn(i)->getColName());
-#pragma warn(1506)  // warning elimination 
    
 
       ColReference *tempColRef = new(bindWA->wHeap()) 
@@ -2700,9 +2692,7 @@ RelExpr* GenericUpdate::inlineRI (BindWA *bindWA,
 
   CMPASSERT (!refConstraints->isEmpty())
   
-#pragma nowarn(1506)   // warning elimination 
   if ((entries = refConstraints->entries())) 
-#pragma warn(1506)  // warning elimination 
   {
     riSubtree = createRISubtree(bindWA, naTable, *(refConstraints->at(0)), heap);
     for (Int32 i=1; i < entries; i++) 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemArith.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemArith.h b/core/sql/optimizer/ItemArith.h
index 5278f51..80cfaf5 100644
--- a/core/sql/optimizer/ItemArith.h
+++ b/core/sql/optimizer/ItemArith.h
@@ -57,7 +57,6 @@ class BiArith : public ItemExpr
 {
   // ITM_PLUS, ITM_MINUS, ITM_TIMES, ITM_DIVIDE, ITM_EXPONENT
 public:
-// warning elimination (removed "inline")
   BiArith(OperatorTypeEnum otype,
 	  ItemExpr *child0 = NULL,
 	  ItemExpr *child1 = NULL)
@@ -71,7 +70,6 @@ public:
   {}
 
   // virtual destructor
-// warning elimination (removed "inline")
   virtual ~BiArith() {}
  
   // accessor functions
@@ -194,7 +192,6 @@ private:
 class BiArithSum : public BiArith
 {
 public:
-// warning elimination (removed "inline")
   BiArithSum(OperatorTypeEnum otype,
 		 ItemExpr *child0 = NULL,
 		 ItemExpr *child1 = NULL)
@@ -202,7 +199,6 @@ public:
   {}
   
   // virtual destructor
-// warning elimination (removed "inline")
   virtual ~BiArithSum() {}
  
   virtual ItemExpr * copyTopNode(ItemExpr *derivedNode = NULL,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemColRef.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemColRef.h b/core/sql/optimizer/ItemColRef.h
index 6a96370..783d327 100644
--- a/core/sql/optimizer/ItemColRef.h
+++ b/core/sql/optimizer/ItemColRef.h
@@ -78,7 +78,6 @@ typedef ClusteredBitmap PositionSet;
 // the ValueDesc.
 // -----------------------------------------------------------------------
 
-#pragma nowarn(1682)   // warning elimination 
 class BaseColumn : public ItemExpr
 {
 
@@ -183,13 +182,11 @@ private:
   // If this is a computed column, the expression used to compute it (NULL otherwise)
   ValueId computedColumnExpr_;
 }; // class BaseColumn
-#pragma warn(1682)  // warning elimination 
 
 // -----------------------------------------------------------------------
 // An index column object is allocated each time when an index is used
 // by a rule that transforms some base table access into an index scan.
 // -----------------------------------------------------------------------
-#pragma nowarn(1682)   // warning elimination 
 class IndexColumn : public ItemExpr
 {
 
@@ -256,7 +253,6 @@ private:
   ValueId indexColDefinition_;
 
 };
-#pragma warn(1682)  // warning elimination 
 
 // -----------------------------------------------------------------------
 // A column reference points to a column in a relational node. Constants
@@ -954,11 +950,8 @@ public:
  // Raj P - 01/2001
   // Parameter  mode, ordinal position and variable index
   // needed for (java) stored procedures
-// warning elimination (removed "inline")
   ComColumnDirection getParamMode () const {return paramMode_;};
-// warning elimination (removed "inline")
   Int32 getOrdinalPosition () const {return ordinalPosition_;};
-// warning elimination (removed "inline")
   Int32 getHVorDPIndex () const { return hvIndex_;}
   virtual void setPMOrdPosAndIndex( ComColumnDirection paramMode,
 				    Int32 ordinalPosition,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemConstr.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemConstr.h b/core/sql/optimizer/ItemConstr.h
index 9d21aa8..1b3642a 100644
--- a/core/sql/optimizer/ItemConstr.h
+++ b/core/sql/optimizer/ItemConstr.h
@@ -471,7 +471,6 @@ protected:
 
 }; // AbstractRIConstraint
 
-#pragma nowarn(1026)   // warning elimination 
 class ComplementaryRIConstraint : public NABasicObject
 {
 public:
@@ -521,7 +520,6 @@ public:
   const QualifiedName &getTableName() const { return tableName_; }
 
 }; // ComplementaryRIConstraint
-#pragma warn(1026)  // warning elimination 
 
 // -----------------------------------------------------------------------
 // Uniqueness of a combination of columns in a table:
@@ -641,7 +639,6 @@ public:
   inline NABoolean isaForeignKeyinTableBeingUpdated() const;
   inline NABoolean referencesTableBeingUpdated() const;
 
- //warning elimination (removed "inline")
   const QualifiedName &getOtherTableName() const
   {
     return *otherTableName_;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemExpr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemExpr.cpp b/core/sql/optimizer/ItemExpr.cpp
index 31b8e58..154d39a 100644
--- a/core/sql/optimizer/ItemExpr.cpp
+++ b/core/sql/optimizer/ItemExpr.cpp
@@ -1358,14 +1358,10 @@ ItemExpr * ItemExpr::transformMultiValuePredicate(	     // virtual method
 
 NABoolean ItemExpr::containsAnAggregate() const
 {
-#pragma warning (disable : 4018)   //warning elimination
   for (Int32 i=0; i<getArity(); i++)
   {
-#pragma warning (default : 4018)   //warning elimination
-#pragma nowarn(1506)   // warning elimination
     if (child(i)->containsAnAggregate())
       return TRUE;
-#pragma warn(1506)  // warning elimination
   }
   return FALSE;
 }
@@ -4635,14 +4631,12 @@ NABoolean ValueIdUnion::isCovered(const ValueIdSet& newExternalInputs,
   for(CollIndex i = 0; i < entries(); i++)
   {
     localSubExpr.clear();
-#pragma nowarn(1506)   // warning elimination
     if (coveringGA.covers(getSource(i), newExternalInputs,
 			  referencedInputs, &localSubExpr) )
       {
 	coveredSubExpr += getSource(i);
         break;
       }
-#pragma warn(1506)  // warning elimination
   }
 
   // ---------------------------------------------------------------------
@@ -4723,9 +4717,7 @@ HashValue ValueIdUnion::topHash()
   // hash any local data members of the derived class
   for(CollIndex i = 0; i < entries(); i++)
   {
-#pragma nowarn(1506)   // warning elimination
     result ^= getSource(i);
-#pragma warn(1506)  // warning elimination
   }
 
   result ^= result_;
@@ -4746,10 +4738,8 @@ NABoolean ValueIdUnion::duplicateMatch(const ItemExpr & other) const
   // and return FALSE if they don't match
   for(CollIndex i = 0; i < entries(); i++)
   {
-#pragma nowarn(1506)   // warning elimination
     if (getSource(i) != o.getSource(i))
       return FALSE;
-#pragma warn(1506)  // warning elimination
   }
 
   if (result_ != o.result_ || flags_ != o.flags_)
@@ -7246,7 +7236,6 @@ ItemExpr * PivotGroup::copyTopNode(ItemExpr *derivedNode, CollHeap* outHeap)
 // -----------------------------------------------------------------------
 // member functions for class Function
 // -----------------------------------------------------------------------
-#pragma nowarn(262)   // warning elimination
 Function::Function(OperatorTypeEnum otype,
                    NAMemory *h,
 		   Lng32   argumentCount,
@@ -7284,16 +7273,13 @@ Function::Function(OperatorTypeEnum otype,
       children_.insertAt(i, childx);
     } // end for
 }
-#pragma warn(262)  // warning elimination
 
 Function::Function(OperatorTypeEnum otype, const LIST(ItemExpr *) &children, 
                    CollHeap *h)
          : ItemExpr(otype),
 	   children_(h)
 {
-#pragma nowarn(1506)   // warning elimination
   Lng32 ne = children.entries();
-#pragma warn(1506)  // warning elimination
 
   for (Lng32 i = 0; i < ne; i++)
     {
@@ -7305,9 +7291,7 @@ Function::~Function() {}
 
 Lng32 Function::getNumChildren() const
 {
-#pragma nowarn(1506)   // warning elimination
   Lng32 count = children_.entries();
-#pragma warn(1506)  // warning elimination
   // $$$$ Skip all the NULL children at the tail end.
   // $$$$ Assumes children that are missing in the middle
   // $$$$ should figure in the count, e.g., F(a, NULL, b, NULL, NULL)
@@ -7327,9 +7311,7 @@ ItemExpr * Function::copyTopNode(ItemExpr * derivedNode, CollHeap* outHeap)
   result->allowsSQLnullArg() = allowsSQLnullArg();
 
   // Make sure we copy the kids as well.
-#pragma nowarn(1506)   // warning elimination
   Lng32 ne = children_.entries();
-#pragma warn(1506)  // warning elimination
   for (Lng32 i = 0; i < ne; i++)
     result->children_.insertAt(i, children_[i]);
 
@@ -9021,7 +9003,6 @@ Lng32 RangeLookup::splitKeysLen()
     partFunc_->getRangePartitionBoundaries()->getEncodedBoundaryKeyLength();
 }
 
-#pragma nowarn(770)   // warning elimination
 void RangeLookup::copySplitKeys(char *tgt, Lng32 tgtLen)
 {
   CMPASSERT(tgtLen = splitKeysLen());
@@ -9039,7 +9020,6 @@ void RangeLookup::copySplitKeys(char *tgt, Lng32 tgtLen)
       offset += entryLen;
     }
 }
-#pragma warn(770)  // warning elimination
 
 Lng32 RangeLookup::getNumOfPartitions()
 {
@@ -9137,9 +9117,7 @@ void PackFunc::deriveFormatInfoFromUnpackType(const NAType* unpackType)
   // For bit precision integers, width needs to be in negative no of bits.
   if(unpackType->getFSDatatype() == REC_BPINT_UNSIGNED)
   {
-#pragma nowarn(1506)   // warning elimination
     width_ = ((SQLBPInt*)unpackType)->getDeclaredLength();
-#pragma warn(1506)  // warning elimination
     dataSizeInBytes = (width_*pf-1)/8+1;
     width_ = -width_;
   }
@@ -9955,7 +9933,6 @@ ConstValue::ConstValue()
 }
 
 // constructor for a numeric constant
-#pragma nowarn(262)   // warning elimination
 ConstValue::ConstValue(Lng32 intval, NAMemory * outHeap)
            : ItemExpr(ITM_CONSTANT)
            , isNull_(IS_NOT_NULL)
@@ -9979,7 +9956,6 @@ ConstValue::ConstValue(Lng32 intval, NAMemory * outHeap)
   // copy the bit pattern as is
   memcpy(value_,(void *)(&intval),(Int32)storageSize_);
 }
-#pragma warn(262)  // warning elimination
 
 ConstValue::ConstValue(const NAString & strval,
              enum CharInfo::CharSet charSet,
@@ -10057,9 +10033,7 @@ void ConstValue::initCharConstValue
 			charSet, collation, coercibility);
 
 
-#pragma nowarn(1506)   // warning elimination
       storageSize_ = strval.length();
-#pragma warn(1506)  // warning elimination
       value_ = (void *)( new (outHeap)
 			 char[storageSize_] );
       memcpy(value_, (void *)(strval.data()), (Int32)storageSize_);
@@ -10144,9 +10118,7 @@ void ConstValue::initCharConstValue(const NAWString& strval,
 		SQLChar(outHeap, num_of_chars, FALSE, FALSE, FALSE, FALSE,
 			charSet, collation, coercibility);
 
-#pragma nowarn(1506)   // warning elimination
       storageSize_ = cachedBPC * strval.length();
-#pragma warn(1506)  // warning elimination
       value_ = (void *)( new (outHeap) 
 			 NAWchar[storageSize_] );
       memcpy(value_, (void *)(strval.data()), (Int32)storageSize_);
@@ -10518,9 +10490,7 @@ void ConstValue::changeStringConstant(const NAString* strval)
      value_ = (void *)( new (CmpCommon::statementHeap()) char[storageSize_] );
      str_pad((char *)value_, (Int32)storageSize_, '\0');
    } else {
-#pragma nowarn(1506)   // warning elimination
      storageSize_ = strval -> length();
-#pragma warn(1506)  // warning elimination
      value_ = (void *)( new (CmpCommon::statementHeap()) char[storageSize_] );
      memcpy(value_,(void *)(strval -> data()),(Int32)storageSize_);
    }
@@ -12236,7 +12206,6 @@ ConstValue * Cast::castToConstValue(NABoolean & negate_it)
   return child(0)->castToConstValue(negate_it);
 }
 
-#pragma nowarn(262)   // warning elimination
 ItemExpr * Cast::foldConstants(ComDiagsArea * diagsArea,
 			       NABoolean newTypeSynthesis)
 {
@@ -12263,7 +12232,6 @@ ItemExpr * Cast::foldConstants(ComDiagsArea * diagsArea,
 
   return ItemExpr::foldConstants(diagsArea,newTypeSynthesis);
 }
-#pragma warn(262)  // warning elimination
 
 NABoolean Cast::isCovered
                    (const ValueIdSet& newExternalInputs,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemExpr.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemExpr.h b/core/sql/optimizer/ItemExpr.h
index 992a12a..e24a1fc 100644
--- a/core/sql/optimizer/ItemExpr.h
+++ b/core/sql/optimizer/ItemExpr.h
@@ -120,7 +120,6 @@ public:
   inline ItemExpr * operator ->() const;	// defined below class ItemExpr
 
   // same as a "normal" method
-// warning elimination (removed "inline")
   ItemExpr * getPtr() const;		// defined below class ItemExpr
 
   // cast into an ItemExpr *
@@ -129,7 +128,6 @@ public:
   // cast into a ValueId
   inline operator ValueId() const                     { return getValueId(); }
 
-// warning elimination (removed "inline")
   NAColumn *getNAColumn(NABoolean okIfNotColumn = FALSE) const
 			   { return getValueId().getNAColumn(okIfNotColumn); }
 
@@ -1164,7 +1162,6 @@ public:
   virtual ComColumnDirection getParamMode () const;
   virtual Int32 getOrdinalPosition () const;
   virtual Int32 getHVorDPIndex () const;
-// warning elimination (removed "inline")
   virtual void setPMOrdPosAndIndex( ComColumnDirection paramMode,
 					   Int32 ordinalPosition,
                                     Int32 index) { CMPASSERT (0);}

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemLog.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemLog.h b/core/sql/optimizer/ItemLog.h
index 9e5240f..a6597f5 100644
--- a/core/sql/optimizer/ItemLog.h
+++ b/core/sql/optimizer/ItemLog.h
@@ -82,7 +82,6 @@ public:
   }
 
   // virtual destructor
-  // warning elimination (removed "inline")
   virtual ~BiLogic() {}
 
   // we want BiLogic to be cacheable
@@ -215,7 +214,6 @@ public:
   {}
 
   // virtual destructor
-// warning elimination (removed "inline")
   virtual ~UnLogic() {}
 
   // get the degree of this node (it is a unary op).
@@ -357,7 +355,6 @@ public:
   }
  
   // virtual destructor
-  // warning elimination (removed "inline")
   virtual ~BiRelat() {}
 
   // we want BiRelat to be cacheable

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemNAType.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemNAType.h b/core/sql/optimizer/ItemNAType.h
index 85eb2c4..5d64557 100644
--- a/core/sql/optimizer/ItemNAType.h
+++ b/core/sql/optimizer/ItemNAType.h
@@ -63,7 +63,6 @@ public:
    }
   
   // virtual destructor
-// warning elimination (removed "inline")
   virtual ~NATypeToItem() { delete natype_pointer; }
 
   // a virtual function for type propagating the node

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemOther.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemOther.h b/core/sql/optimizer/ItemOther.h
index 30aef79..4ebdad5 100644
--- a/core/sql/optimizer/ItemOther.h
+++ b/core/sql/optimizer/ItemOther.h
@@ -355,7 +355,6 @@ private:
 // the derivation hierarchy for ValueDescs.
 // -----------------------------------------------------------------------
 
-#pragma nowarn(1682)   // warning elimination
 class ValueIdRef : public ItemExpr
 {
 
@@ -397,7 +396,6 @@ private:
   ValueId  derivedFrom_;
 
 }; // class ValueIdRef
-#pragma warn(1682)  // warning elimination
 
 //! ValueIdProxy  class
 // -----------------------------------------------------------------------
@@ -415,7 +413,6 @@ private:
 //
 // -----------------------------------------------------------------------
 
-#pragma nowarn(1682)   // warning elimination
 class ValueIdProxy : public ItemExpr
 {
 
@@ -585,7 +582,6 @@ private:
   Int32  outputOrdinalNumber_;
 
 }; // class ValueIdProxy
-#pragma warn(1682)  // warning elimination
 
 // -----------------------------------------------------------------------
 // A ValueIdUnion is used whenever two or more data streams are
@@ -1054,7 +1050,6 @@ private:
 // Its datatype is computed as the minimum of the values that belong
 // to the VEG it references.
 // -----------------------------------------------------------------------
-#pragma nowarn(1682)   // warning elimination
 class VEGReference : public ItemExpr
 {
 
@@ -1411,7 +1406,4 @@ static void usePartofSelectionPredicatesFromTheItemExpressionTree(ValueIdSet& in
  }
 }
 
-#pragma warn(1682)  // warning elimination
-
-
 #endif /* ITEMOTHER_H */

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItemSubq.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItemSubq.h b/core/sql/optimizer/ItemSubq.h
index 6cadbfa..919f66c 100644
--- a/core/sql/optimizer/ItemSubq.h
+++ b/core/sql/optimizer/ItemSubq.h
@@ -60,12 +60,10 @@ class GenericUpdate;
 // ***********************************************************************
 // A subquery 
 // ***********************************************************************
-#pragma nowarn(1506)   // warning elimination 
 class Subquery : public ItemExpr
 {
 public:
 
-// warning elimination (removed "inline")
   Subquery(OperatorTypeEnum otype,
                   RelExpr * tableExpr, ItemExpr * scalarExpr = NULL)
          : ItemExpr(otype,scalarExpr),
@@ -73,7 +71,6 @@ public:
            tableExpr_(tableExpr)
   {}
 
-// warning elimination (removed "inline")
   virtual ~Subquery() {}
 
   // get the degree of this node
@@ -207,7 +204,6 @@ public:
   RelExpr * tableExpr_;
   
 }; // class Subquery
-#pragma warn(1506)  // warning elimination 
 
 // ***********************************************************************
 // Row subquery 
@@ -217,11 +213,9 @@ class RowSubquery : public Subquery
   // ITM_ROW_SUBQUERY
 public:
 
-// warning elimination (removed "inline")
   RowSubquery(RelExpr * tableExpr)
          : Subquery(ITM_ROW_SUBQUERY, tableExpr) {}
 
-// warning elimination (removed "inline")
   virtual ~RowSubquery() {}
 
   // a virtual function for type propagating the node
@@ -255,7 +249,6 @@ class QuantifiedComp : public Subquery
   // ITM_GREATER_EQ_ALL, ITM_GREATER_EQ_ANY
 public:
 
-// warning elimination (removed "inline")
   QuantifiedComp(OperatorTypeEnum otype,
                  ItemExpr * scalarExpr,
                  RelExpr  * tableExpr,
@@ -267,7 +260,6 @@ public:
     setAvoidHalloweenR2(avoidHalloweenR2);
   }
 
-// warning elimination (removed "inline")
   virtual ~QuantifiedComp() {}
 
   // a virtual function for type propagating the node
@@ -317,13 +309,11 @@ class InSubquery : public Subquery
   // ITM_IN_SUBQUERY
 public:
 
-// warning elimination (removed "inline")
   InSubquery(OperatorTypeEnum otype,
 		    ItemExpr * scalarExpr,
 		    RelExpr  * tableExpr) 
          : Subquery(otype, tableExpr, scalarExpr) {}
 
-// warning elimination (removed "inline")
   virtual ~InSubquery() {}
 
   // get a printable string that identifies the operator

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItmBitMuxFunction.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItmBitMuxFunction.cpp b/core/sql/optimizer/ItmBitMuxFunction.cpp
index 6a77ec8..05aa05f 100644
--- a/core/sql/optimizer/ItmBitMuxFunction.cpp
+++ b/core/sql/optimizer/ItmBitMuxFunction.cpp
@@ -47,7 +47,6 @@ const NAType *ItmBitMuxFunction::synthesizeType() {
 
 // copyTopNode
 //
-#pragma nowarn(770)   // warning elimination 
 ItemExpr *ItmBitMuxFunction::copyTopNode(ItemExpr *derivedNode, 
 					 CollHeap *outHeap) {
   ItemExpr *result;
@@ -61,4 +60,3 @@ ItemExpr *ItmBitMuxFunction::copyTopNode(ItemExpr *derivedNode,
 
   return BuiltinFunction::copyTopNode(result, outHeap);
 };
-#pragma warn(770)  // warning elimination 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/ItmFlowControlFunction.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/ItmFlowControlFunction.cpp b/core/sql/optimizer/ItmFlowControlFunction.cpp
index fc9a974..03b2298 100644
--- a/core/sql/optimizer/ItmFlowControlFunction.cpp
+++ b/core/sql/optimizer/ItmFlowControlFunction.cpp
@@ -38,7 +38,6 @@ const NAType *ItmDoWhileFunction::synthesizeType() {
 
 // copyTopNode
 //
-#pragma nowarn(770)   // warning elimination 
 ItemExpr *ItmDoWhileFunction::copyTopNode(ItemExpr *derivedNode, 
 					 CollHeap *outHeap) {
   ItemExpr *result;
@@ -51,7 +50,6 @@ ItemExpr *ItmDoWhileFunction::copyTopNode(ItemExpr *derivedNode,
 
   return BuiltinFunction::copyTopNode(result, outHeap);
 };
-#pragma warn(770)  // warning elimination 
 
 
 //
@@ -68,7 +66,6 @@ const NAType *ItmBlockFunction::synthesizeType() {
 
 // copyTopNode
 //
-#pragma nowarn(770)   // warning elimination 
 ItemExpr *ItmBlockFunction::copyTopNode(ItemExpr *derivedNode, 
 					 CollHeap *outHeap) {
   ItemExpr *result;
@@ -81,7 +78,6 @@ ItemExpr *ItmBlockFunction::copyTopNode(ItemExpr *derivedNode,
 
   return BuiltinFunction::copyTopNode(result, outHeap);
 };
-#pragma warn(770)  // warning elimination 
 
 //
 // ItmWhile
@@ -95,7 +91,6 @@ const NAType *ItmWhileFunction::synthesizeType() {
 
 // copyTopNode
 //
-#pragma nowarn(770)   // warning elimination 
 ItemExpr *ItmWhileFunction::copyTopNode(ItemExpr *derivedNode, 
 					 CollHeap *outHeap) {
   ItemExpr *result;
@@ -108,7 +103,6 @@ ItemExpr *ItmWhileFunction::copyTopNode(ItemExpr *derivedNode,
 
   return BuiltinFunction::copyTopNode(derivedNode, outHeap);
 };
-#pragma warn(770)  // warning elimination 
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/LargeScopeRules.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/LargeScopeRules.cpp b/core/sql/optimizer/LargeScopeRules.cpp
index 30cf4d2..74c85f5 100644
--- a/core/sql/optimizer/LargeScopeRules.cpp
+++ b/core/sql/optimizer/LargeScopeRules.cpp
@@ -412,9 +412,7 @@ RelExpr * MJEnumRule::nextSubstitute(RelExpr * before,
 
     // Data flow optimization
     CostScalar childrenFlow = mjoin->getChildrenDataFlow();
-#pragma nowarn(1506)   // warning elimination
     const Lng32 numChildren = jbbcs.entries();
-#pragma warn(1506)  // warning elimination
     Lng32 childIter = -1; // temp iterator. *NOT* the same as child index
     RelExpr** potentialSubstitutes = new (CmpCommon::statementHeap()) RelExpr*[numChildren];
     CostScalar* substituteMetric = new (CmpCommon::statementHeap()) CostScalar[numChildren];

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MJVIndexBuilder.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MJVIndexBuilder.cpp b/core/sql/optimizer/MJVIndexBuilder.cpp
index 8679b38..3fe08fc 100644
--- a/core/sql/optimizer/MJVIndexBuilder.cpp
+++ b/core/sql/optimizer/MJVIndexBuilder.cpp
@@ -233,9 +233,7 @@ ColIndSetBucketVector::insert (ColIndSet& newSet)
   // get the size of new ColIndSet -
   // remember - the size defines the order number of ColIndSetBucket
   // the new ColIndSet will be inserted into.
-#pragma nowarn(1506)   // warning elimination 
   Int32 newSetSize = newSet.entries();
-#pragma warn(1506)  // warning elimination 
   
   if (newSetSize > (Int32)maxNonEmptyEntrySize_) 
   { // if the new ColIndSet is longer than the maximal already inserted
@@ -243,9 +241,7 @@ ColIndSetBucketVector::insert (ColIndSet& newSet)
     // at the last resize(), getSize() entries were allocated 
     // (it can be more than asked) -- so the last entry is 
     // getSize()-1 
-#pragma nowarn(1506)   // warning elimination 
     Int32 oldArrSize = getSize();
-#pragma warn(1506)  // warning elimination 
     // if the size of the new ColIndSet is greater than the number of 
     // the last entry allocated - resize self
     if (newSetSize > (oldArrSize - 1)) 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MJVIndexBuilder.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MJVIndexBuilder.h b/core/sql/optimizer/MJVIndexBuilder.h
index b6dcde8..98fd5cc 100644
--- a/core/sql/optimizer/MJVIndexBuilder.h
+++ b/core/sql/optimizer/MJVIndexBuilder.h
@@ -175,9 +175,7 @@ public:
   
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   ColIndSetBucketVector& operator=(const ColIndSetBucketVector& other);
-#pragma warn(1026)  // warning elimination 
   ColIndSetBucketVector();
   ColIndSetBucketVector(const ColIndSetBucketVector& other);
 
@@ -236,9 +234,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   ColIndSetMatrix& operator=(const ColIndSetMatrix& other);
-#pragma warn(1026)  // warning elimination 
   //
   // ctors
   //
@@ -323,9 +319,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   NestingStack& operator=(const NestingStack& other);
-#pragma warn(1026)  // warning elimination 
   NestingStack();
   NestingStack(const NestingStack& other);
   
@@ -401,9 +395,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MJVIndCook& operator=(const MJVIndCook& other);
-#pragma warn(1026)  // warning elimination 
   MJVIndCook();
   MJVIndCook(const MJVIndCook& other);
   
@@ -452,9 +444,7 @@ public:
   
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MJVIndexBuilder& operator=(const MJVIndexBuilder& other);
-#pragma warn(1026)  // warning elimination 
   MJVIndexBuilder();
   MJVIndexBuilder(const MJVIndexBuilder& other);
   

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MVInfo.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVInfo.cpp b/core/sql/optimizer/MVInfo.cpp
index 515a70f..03e324b 100644
--- a/core/sql/optimizer/MVInfo.cpp
+++ b/core/sql/optimizer/MVInfo.cpp
@@ -945,9 +945,7 @@ Lng32 MVVegPredicate::findIndexFor(const QualifiedName& tableName,
     const MVVegPredicateColumn *col = at(i);
     if ((col->getTableName() == tableName) && 
 	(col->getColNumber() == colPosition))
-#pragma nowarn(1506)   // warning elimination 
       return i;
-#pragma warn(1506)  // warning elimination 
   }
   return -1;
 }
@@ -2072,8 +2070,6 @@ Int32 MVColumnInfo::newMavDependentColumn(ExpressionHash&     expHash,
 // STDDEVW(a,b) and VARIANCE(a,b) need SUM(b), SUM(a*b) and SUM(a*a*b).
 // If a is NOT NULL, then COUNT(a) can be replaced by COUNT(*).
 //////////////////////////////////////////////////////////////////////////////
-#pragma nowarn(770)   // warning elimination 
-#pragma nowarn(262)   // warning elimination 
 void MVColumnInfo::createDependentColumns(ExpressionHash& expHash, 
 					  MVInfoForDDL&	  mvInfoObj,
 					  CollHeap	 *heap)
@@ -2152,8 +2148,6 @@ void MVColumnInfo::createDependentColumns(ExpressionHash& expHash,
     dep1_ = newStddevwDepColumn(2, expHash, newExprText, mvInfoObj, heap);
   }
 }
-#pragma warn(770)  // warning elimination 
-#pragma warn(262)  // warning elimination 
 
 //////////////////////////////////////////////////////////////////////////////
 //////////////////////////////////////////////////////////////////////////////
@@ -2613,9 +2607,7 @@ MVInfo::MVInfo( const NAString&             nameOfMV,
   {
     switch (directColumnList[i]->getOperatorType())
     {
-#pragma nowarn(1506)   // warning elimination 
       case ITM_COUNT: posOfCountStar_ = i;
-#pragma warn(1506)  // warning elimination 
 		      break;
       case ITM_MIN  :
       case ITM_MAX  : isMinMaxUsed_ = TRUE;
@@ -2735,9 +2727,7 @@ void MVInfo::fixMvSelectList(RelRoot *mvSelectTree) const
        selectListIndex < selectList.entries(); 
        selectListIndex++, mvColIndex++)
   {
-#pragma nowarn(1506)   // warning elimination 
     const MVColumnInfo *mvCol = mvColumns[mvColIndex];
-#pragma warn(1506)  // warning elimination 
     const NAString& mvColName = mvCol->getColName();
     ItemExpr *colExpr = selectList[selectListIndex];
 
@@ -2793,9 +2783,7 @@ RelRoot *MVInfo::buildMVSelectTree(const NAString* alternativeText, CharInfo::Ch
 
   // Parse the SQL text.
   Parser parser(CmpCommon::context());
-#pragma nowarn(1506)   // warning elimination 
   if (parser.parseDML(MVSelectText.data(), MVSelectText.length(), textCharSet, &parsedNode))
-#pragma warn(1506)  // warning elimination 
     return NULL;
 
   // Skip the DDL nodes of the CREATE MV command.
@@ -3154,9 +3142,7 @@ NAString MVInfo::getOptionalNameClause(StmtDDLCreateMV *createMvNode,
   const MVColumns& mvCols = getMVColumns();
   for (CollIndex ci(0); ci < mvCols.entries() ; ci++)
   {
-#pragma nowarn(1506)   // warning elimination 
     const MVColumnInfo *mvCol = mvCols[ci];
-#pragma warn(1506)  // warning elimination 
     if (!mvCol->isSystem())
     { // skip columns that are not system added. 
       continue;
@@ -3204,9 +3190,7 @@ NAString MVInfo::getSelectPhraseAsString(NAString& sysAddedCols) const
   selectListIndex++, mvColIndex++)
   {
     CMPASSERT(mvColIndex <  mvCols.entries());
-#pragma nowarn(1506)   // warning elimination 
     const MVColumnInfo *mvCol = mvCols[mvColIndex];
-#pragma warn(1506)  // warning elimination 
     const NAString& mvColName = mvCol->getColName();
     ItemExpr *colExpr = selectList[selectListIndex];
     NAString origColName("", heap_);
@@ -3495,9 +3479,7 @@ MVInfo::buildColumnInfoListFromColIndList(const ColIndList &currentRCI) const
   {
     currentColNumber = currentRCI.at(i);
     MVColumnInfo *currentColInfo = 
-#pragma nowarn(1506)   // warning elimination 
       getMVColumns().getMvColInfoByIndex(currentColNumber);
-#pragma warn(1506)  // warning elimination 
     currentColumnInfoList->insert(currentColInfo);
   }
   return currentColumnInfoList;
@@ -3600,9 +3582,7 @@ void MVInfoForDDL::setRootNode(RelRoot *rootNode, BindWA *bindWA)
   // Get the unbound column text.
   ItemExprList selectList(selectItemList, getHeap());
   for (CollIndex colNumber=0; colNumber<selectList.entries(); colNumber++)
-#pragma nowarn(1506)   // warning elimination 
     extractParsedColumnText(colNumber, selectList[colNumber]);
-#pragma warn(1506)  // warning elimination 
 }
 
 //////////////////////////////////////////////////////////////////////////////
@@ -3716,9 +3696,7 @@ void MVInfoForDDL::initUsedObjectsList(BindWA *bindWA)
   }
 
   // Construct the join graph.
-#pragma nowarn(1506)   // warning elimination 
   newJoinGraph(scanNodesNumber);
-#pragma warn(1506)  // warning elimination 
 
   // For each Scan node on the tree
   for (CollIndex scanNodeIndex=0; 
@@ -3747,9 +3725,7 @@ void MVInfoForDDL::initUsedObjectsList(BindWA *bindWA)
       getUsedObjectsList().insert(usedInfo);
 
     // And into the join graph.
-#pragma nowarn(1506)   // warning elimination 
     getJoinGraph()->addTable(scanNodeIndex, scanNodeIndex, naTable);
-#pragma warn(1506)  // warning elimination 
   }
 
   // Now make sure Views' usage is marked correctly, the default is
@@ -3990,14 +3966,10 @@ void MVInfoForDDL::addMavSystemColumns(BindWA *bindWA)
   // Add the user columns to the expression hash.
   for (CollIndex i=0; i<columnList.entries(); i++)
   {
-#pragma nowarn(1506)   // warning elimination 
     MVColumnInfo *colInfo = columnList[i];
-#pragma warn(1506)  // warning elimination 
     // Remember the position of the COUNT(*) column.
     if (colInfo->isCountStarColumn())
-#pragma nowarn(1506)   // warning elimination 
       setPosOfCountStar(i);
-#pragma warn(1506)  // warning elimination 
     else
     {
       // Remember if we are using any Min/Max functions.
@@ -4032,9 +4004,7 @@ void MVInfoForDDL::addMavSystemColumns(BindWA *bindWA)
     // Identify them by ValueId from the column expression.
     for (CollIndex j=0; j<columnList.entries(); j++)
     {
-#pragma nowarn(1506)   // warning elimination 
       MVColumnInfo *colInfo = columnList[j];
-#pragma warn(1506)  // warning elimination 
       if (colInfo->getColType() == COM_MVCOL_GROUPBY)
   	groupingCols.remove(colInfo->getColExpr()->getValueId());
     }
@@ -4059,9 +4029,7 @@ void MVInfoForDDL::addMavSystemColumns(BindWA *bindWA)
   // so createDependentColumns() is called for these new columns as well.
   for (CollIndex k=0; k<columnList.entries(); k++)
   {
-#pragma nowarn(1506)   // warning elimination 
     MVColumnInfo *colInfo = columnList[k];
-#pragma warn(1506)  // warning elimination 
     colInfo->createDependentColumns(expHash, *this, getHeap());
   }
 }
@@ -4224,9 +4192,7 @@ void MVInfoForDDL::addBaseColsUsedByComputedMvColumns()
   MVColumns& columnList = getMVColumns();
   for (CollIndex mvCol=0; mvCol<columnList.entries(); mvCol++)
   {
-#pragma nowarn(1506)   // warning elimination 
     MVColumnInfo *colInfo = columnList[mvCol];
-#pragma warn(1506)  // warning elimination 
 
     // Insert only base columns (not complex)
     if (colInfo->getColType() != COM_MVCOL_FUNCTION)
@@ -4400,9 +4366,7 @@ void MVInfoForDDL::processBoundInformation(BindWA *bindWA)
   // build the MV column list is taken from.
   colDescList_ = rootNode_->getRETDesc()->getColumnList();
   CMPASSERT(colDescList_ != NULL);
-#pragma nowarn(1506)   // warning elimination 
   userColumnCount_ = colDescList_->entries();
-#pragma warn(1506)  // warning elimination 
 
   // Only one GroupBy node allowed on the direct tree.
   if (groupByNodes_.entries()>1)
@@ -4621,9 +4585,7 @@ void MVInfoForDDL::verifyGroupByColumns(GroupByAgg *groupByNode)
   for (CollIndex i=0; i<columnList.entries(); i++)
   {
     // Check only column of type GROUPBY
-#pragma nowarn(1506)   // warning elimination 
     MVColumnInfo *colInfo = columnList[i];
-#pragma warn(1506)  // warning elimination 
     if (colInfo->getColType() != COM_MVCOL_GROUPBY)
       continue;
     
@@ -4802,9 +4764,7 @@ void MVInfoForDML::getMavGroupByColumns(LIST(Lng32)& gbColList) const
 
   for (CollIndex i=0; i<columnList.entries(); i++)
   {
-#pragma nowarn(1506)   // warning elimination 
     MVColumnInfo *currentCol = columnList[i];
-#pragma warn(1506)  // warning elimination 
     if (currentCol->getColType() == COM_MVCOL_GROUPBY)
       gbColList.insert(currentCol->getColNumber());
   }
@@ -4853,9 +4813,7 @@ MVJoinGraph *MVInfoForDML::initJoinGraph(BindWA		              *bindWA,
     CMPASSERT(naTable != NULL);
 
     MVJoinTable *newNode = new(getHeap()) 
-#pragma nowarn(1506)   // warning elimination 
       MVJoinTable(nodeNumber, usedObjectsIndex, directTables, naTable, getHeap());
-#pragma warn(1506)  // warning elimination 
 
     DeltaDefinition *deltaDef =
       deltaDefList->findEntryFor(usedInfo->getObjectName());
@@ -5092,9 +5050,7 @@ void MVUsedObjectColNameMap::initColNameMap(const NATable *naTable, CollHeap *he
     const NAColumn *naCol = naColumns[i];
     
     // Initialize the current position of the array with i.
-#pragma nowarn(1506)   // warning elimination 
     *colPositionPtr = i;
-#pragma warn(1506)  // warning elimination 
     // Insert the entry into the hash table.
     colNameHash_.insert(&naCol->getColName(), colPositionPtr);
   }

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MVInfo.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVInfo.h b/core/sql/optimizer/MVInfo.h
index bee133d..53278cf 100644
--- a/core/sql/optimizer/MVInfo.h
+++ b/core/sql/optimizer/MVInfo.h
@@ -167,9 +167,7 @@ public:
 private:
   // Copy Ctor and = operator are not implemented.
   ViewColumnConnection(const ViewColumnConnection& other);
-#pragma nowarn(1026)   // warning elimination 
   ViewColumnConnection& operator=(const ViewColumnConnection& other);
-#pragma warn(1026)  // warning elimination 
 
   ColRefName	    baseColName_; // The name of the column in the base table.
   const ColRefName  viewColName_; // The name of the column in the view.
@@ -223,9 +221,7 @@ public:
 private:
     // Copy Ctor and = operator are not implemented.
   ViewTableConnection(const ViewTableConnection& other);
-#pragma nowarn(1026)   // warning elimination 
   ViewTableConnection& operator=(const ViewTableConnection& other);
-#pragma warn(1026)  // warning elimination 
 
   typedef NAHashDictionary<const NAString, const ViewColumnConnection> columnConnection;
 
@@ -277,9 +273,7 @@ public:
 private:
     // Copy Ctor and = operator are not implemented.
   ViewColumnGraph(const ViewColumnGraph& other);
-#pragma nowarn(1026)   // warning elimination 
   ViewColumnGraph& operator=(const ViewColumnGraph& other);
-#pragma warn(1026)  // warning elimination 
 
   void addConnection(ViewColumnConnection *colConnection, CollHeap *heap);
   const ViewColumnConnection *findColumn(const ValueId vid) const;
@@ -367,9 +361,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVVegPredicateColumn& operator=(const MVVegPredicateColumn& other);
-#pragma warn(1026)  // warning elimination 
   MVVegPredicateColumn(const MVVegPredicateColumn& other);
 
   const QualifiedName		tableName_;
@@ -447,9 +439,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVVegPredicate& operator=(const MVVegPredicate& other);
-#pragma warn(1026)  // warning elimination 
   MVVegPredicate(const MVVegPredicate& other);
 
   // Is this predicate from a left join?
@@ -535,9 +525,7 @@ public:
 
 private:
   // Prevent accidental use of default = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVUsedObjectCatmanFlags& operator=(const MVUsedObjectCatmanFlags& other);
-#pragma warn(1026)  // warning elimination 
 
   ComMVSUsedTableAttribute  objectAttributes_; // Ignore changes/Insert only.
   ComMVSUsageType	    usageType_;        // Direct/Expanded/User specified.
@@ -701,9 +689,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVUsedObjectInfo& operator=(const MVUsedObjectInfo& other);
-#pragma warn(1026)  // warning elimination 
   MVUsedObjectInfo(const MVUsedObjectInfo& other);
 
   const QualifiedName	  objectName_; 
@@ -856,9 +842,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVColumnInfo& operator=(const MVColumnInfo& other);
-#pragma warn(1026)  // warning elimination 
   MVColumnInfo(const MVColumnInfo& other);
 
   ItemExpr   *findMavColumnType(ItemExpr *expr, MVInfoForDDL& mvInfoObj);
@@ -959,9 +943,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVColumns& operator=(const MVColumns& other);
-#pragma warn(1026)  // warning elimination 
   MVColumns(const MVColumns& other);
 
   typedef NAHashDictionary<const NAString, MVColumnInfo>     ColumnInfoHash;
@@ -1116,9 +1098,7 @@ protected:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVInfo& operator=(const MVInfo& other);
-#pragma warn(1026)  // warning elimination
   MVInfo(); // do not use
   MVInfo(const MVInfo& other);
 
@@ -1234,9 +1214,7 @@ public:
 
 private:
   // Prevent accidental use of default copy Ctor and = operator.
-#pragma nowarn(1026)   // warning elimination 
   MVInfoForDDL& operator=(const MVInfoForDDL& other);
-#pragma warn(1026)  // warning elimination 
   MVInfoForDDL(const MVInfoForDDL& other);
 
   // Called by processBoundInformation() and processNormalizedInformation().
@@ -1357,9 +1335,7 @@ public:
 private:
   // Prevent accidental use of default copy Ctor and = operator.
   MVInfoForDML(const MVInfoForDML& other);
-#pragma nowarn(1026)   // warning elimination 
   MVInfoForDML& operator=(const MVInfoForDML& other);
-#pragma warn(1026)  // warning elimination 
 
   TableNameHash usedObjectsHash_;
   CharInfo::CharSet mvSelectTextCharSet_;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MVJoinGraph.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVJoinGraph.cpp b/core/sql/optimizer/MVJoinGraph.cpp
index 4bc0d2f..5efc4b6 100644
--- a/core/sql/optimizer/MVJoinGraph.cpp
+++ b/core/sql/optimizer/MVJoinGraph.cpp
@@ -220,9 +220,7 @@ static void BitmapToString(const NABitVector& bm, NAString& text)
   CollIndex lastBit;
 
   bm.lastUsed(lastBit);
-#pragma nowarn(1506)   // warning elimination 
   for (Int32 i=lastBit; i>=0; i--)
-#pragma warn(1506)  // warning elimination 
   {
     if (bm.testBit(i))
       text += "1  ";
@@ -248,9 +246,7 @@ void MVJoinTable::print(FILE* ofd, const char* indent, const char* title)const
   CollIndex lastBit;
   
   predicateBitmap_.lastUsed(lastBit);
-#pragma nowarn(1506)   // warning elimination 
   for (Int32 i=lastBit; i>=0  ; i--)
-#pragma warn(1506)  // warning elimination 
   {
 	snprintf( buffer, 20, "%d", i );
     titleString += buffer;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MVJoinGraph.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVJoinGraph.h b/core/sql/optimizer/MVJoinGraph.h
index 4035426..3aedd38 100644
--- a/core/sql/optimizer/MVJoinGraph.h
+++ b/core/sql/optimizer/MVJoinGraph.h
@@ -151,7 +151,6 @@ private:
 //////////////////////////////////////////////////////////////////////////////
 // This class describes an ordered traverse of the join tree, where each
 // table is connected to at lease one of its predecessors.
-#pragma nowarn(1506)   // warning elimination 
 class MVJoinGraphSolution : public NABasicObject
 {
 public:
@@ -190,7 +189,6 @@ private:
   NABitVector   bitmap_;    // Bitmap of route tables.
   MVTableSet	riTables_;  // Set of tables for which RI opt. can be used.
 }; // MVJoinGraphSolution
-#pragma warn(1506)  // warning elimination 
 
 //////////////////////////////////////////////////////////////////////////////
 // Holds the state of the graph during the traverse.

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MavRelRootBuilder.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MavRelRootBuilder.cpp b/core/sql/optimizer/MavRelRootBuilder.cpp
index 52e7bb8..66a980e 100644
--- a/core/sql/optimizer/MavRelRootBuilder.cpp
+++ b/core/sql/optimizer/MavRelRootBuilder.cpp
@@ -91,9 +91,7 @@ void MavRelRootBuilder::init()
   // Divide the MAV columns to groups:
   for (CollIndex i=0; i<mavCols_.entries(); i++)
   {
-#pragma nowarn(1506)   // warning elimination 
     MVColumnInfo *currentCol = mavCols_[i];
-#pragma warn(1506)  // warning elimination 
 
     if (currentCol->getColType() != COM_MVCOL_AGGREGATE)
     {  
@@ -965,7 +963,6 @@ ItemExpr *MavRelRootBuilder::buildExtraMinMaxExpr(const ItemExpr  *pMinMaxExpr,
 // than op2 (called delVsInsertRelation) is the same as op1. Otherwise it 
 // does not cover the = case (which means it is < instead of <=, and > instead
 // of >=).
-#pragma nowarn(262)   // warning elimination 
 ItemExpr *MavRelRootBuilder::buildMinMaxRecomputeOnUpdateCondition(const NAString&  mavColName,
 								   ColReference    *deltaInsCol,
 								   ColReference    *deltaDelCol,
@@ -1021,7 +1018,6 @@ ItemExpr *MavRelRootBuilder::buildMinMaxRecomputeOnUpdateCondition(const NAStrin
 
   return finalCondition;
 }  // MavRelRootBuilder::buildMinMaxRecomputeOnUpdateCondition()
-#pragma warn(262)  // warning elimination 
 
 //----------------------------------------------------------------------------
 // Build the conditional expression for deciding if the min/max value of a

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MultiJoin.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MultiJoin.cpp b/core/sql/optimizer/MultiJoin.cpp
index 7eae8f3..ac271a0 100644
--- a/core/sql/optimizer/MultiJoin.cpp
+++ b/core/sql/optimizer/MultiJoin.cpp
@@ -68,9 +68,7 @@ MultiJoin::MultiJoin(const JBBSubset & jbbSubset,
   }
 
   lsrC_ = new (oHeap) LSRConfidence(oHeap);
-#pragma warning (disable : 4018)  //warning elimination
   CMPASSERT (getArity() == jbbcs.entries());
-#pragma warning (default : 4018)  //warning elimination
 }
 
 NABoolean MultiJoin::isSymmetricMultiJoin() const
@@ -473,9 +471,7 @@ RelExpr* MultiJoin::getJBBCRelExpr(CANodeId jbbc) const
     result = exprGroupId.getPtr();
   else
   {
-#pragma nowarn(1506)   // warning elimination
     result = new (outHeap) CutOp(exprGroupId.getGroupId(), outHeap);
-#pragma warn(1506)  // warning elimination
     ((CutOp*)result)->setGroupIdAndAttr(exprGroupId.getGroupId());
     // may be we should re-use existing cut-op rather than creating
     // new one.
@@ -786,9 +782,7 @@ const ExprGroupId &
   JBBCExprGroupMap::getExprGroupIdOfJBBC(CANodeId jbbc) const
 {
 
-#pragma nowarn(1506)   // warning elimination
   Int32 entries = array_.entries();
-#pragma warn(1506)  // warning elimination
   for (Int32 i = 0; i < entries; i++)
   {
     CMPASSERT(array_.used(i));

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MultiJoin.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MultiJoin.h b/core/sql/optimizer/MultiJoin.h
index 1e539b2..8449a81 100644
--- a/core/sql/optimizer/MultiJoin.h
+++ b/core/sql/optimizer/MultiJoin.h
@@ -93,7 +93,6 @@ private:
 // JBBCExprGroupMap :
 // -----------------------------------------------------------------------
 
-#pragma nowarn(1506)  // warning elimination
 class JBBCExprGroupMap
 {
 public:
@@ -145,7 +144,6 @@ private:
   CollHeap*                        heap_;
 
 };
-#pragma warn(1506)  // warning elimination
 
 // -----------------------------------------------------------------------
 // member functions for class LSRConfidence

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MvLog.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvLog.cpp b/core/sql/optimizer/MvLog.cpp
index bc99cad..cdaa98d 100644
--- a/core/sql/optimizer/MvLog.cpp
+++ b/core/sql/optimizer/MvLog.cpp
@@ -49,9 +49,7 @@
 
 // MVLOG command is not supported
 
-#pragma nowarn(1000)   // warning elimination 
 const MvLogInternalNames MvLog::internalNames_;
-#pragma warn(1000)  // warning elimination 
 
 const char MvLogInternalNames::beginRangeSuffix_[] = "_BEGIN";
 const char MvLogInternalNames::endRangeSuffix_[]   = "_FIRST";
@@ -304,7 +302,6 @@ NABoolean MvLog::isTableRangePartitioned() const
 // 1. The columns from the MVLOG command line.
 // 2. The base table clustering index columns.
 // 3. The base table columns that are not in the clustering index.
-#pragma nowarn(262)   // warning elimination 
 void MvLog::buildBaseTableColumnNamesLists()
 {
   CMPASSERT(NULL != pNaTable_);
@@ -364,7 +361,6 @@ void MvLog::buildBaseTableColumnNamesLists()
     }
   }
 } // MvLog::buildBaseTableColumnNamesLists
-#pragma warn(262)  // warning elimination 
 
 //----------------------------------------------------------------------------
 // Verify that the list of columns from the MVLOG command line are a prefix
@@ -516,9 +512,7 @@ void MvLog::getColumnsPositionsInCI(const NAFileSet * pCiFileSet)
 
     if(ciColName == colRefName)
     {
-#pragma nowarn(1506)   // warning elimination 
       pRelevantCiPositionsList_.insert(inputColIndex);
-#pragma warn(1506)  // warning elimination 
     }
     else // not a CI prefix
     {
@@ -566,9 +560,7 @@ void MvLog::addRangePartitionBoundries(
        boundryIndex++)
   {
     const ItemExprList* pBoundry = 
-#pragma nowarn(1506)   // warning elimination 
       pBoundries->getBoundaryValues(boundryIndex);
-#pragma warn(1506)  // warning elimination 
     CMPASSERT(NULL != pBoundry);
 
     ItemExprList *pBoundryCopy = new(heap_)ItemExprList(heap_);

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MvLog.h
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvLog.h b/core/sql/optimizer/MvLog.h
index ed9314c..6d8a969 100644
--- a/core/sql/optimizer/MvLog.h
+++ b/core/sql/optimizer/MvLog.h
@@ -166,9 +166,7 @@ private:
 private:
   // Copy Ctor and = operator are not implemented.
   MvLog(const MvLog& other);
-#pragma nowarn(1026)   // warning elimination 
   MvLog& operator=(const MvLog& other);
-#pragma warn(1026)  // warning elimination 
 
   const QualifiedName	*tableName_;
   const ItemExpr	*pColumnNamesItem_;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/781d97e6/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MvMultiTxnMavBuilder.cpp b/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
index 0ae276f..cdd7a52 100644
--- a/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
+++ b/core/sql/optimizer/MvMultiTxnMavBuilder.cpp
@@ -369,7 +369,6 @@ ItemExpr *MvMultiTxnMavBuilder::buildSelectionPredicateForScanOnIudLog() const
 }  // MvMultiTxnMavBuilder::buildSelectionPredicateForScanOnIudLog()
 
 //----------------------------------------------------------------------------
-#pragma nowarn(262)   // warning elimination 
 ItemExpr *MvMultiTxnMavBuilder::addContextPredicatesOnIUDLog() const
 
 {
@@ -443,7 +442,6 @@ ItemExpr *MvMultiTxnMavBuilder::addContextPredicatesOnIUDLog() const
 
   return CatchupPredicate;
 }  // MvMultiTxnMavBuilder::addContextPredicatesOnIUDLog()
-#pragma warn(262)  // warning elimination 
 
 //----------------------------------------------------------------------------
 // This method is called by Scan::bindNode(), when getting to the Scan on