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/11/30 22:54:09 UTC

[5/6] incubator-trafodion git commit: TRAFODION-2731 removed obsolete comments based on review feedback

TRAFODION-2731 removed obsolete comments based on review feedback


Project: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/commit/4722203e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/tree/4722203e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/diff/4722203e

Branch: refs/heads/master
Commit: 4722203e9e1020c57bc3ab5ae794da76219308ee
Parents: 665def4
Author: Anoop Sharma <an...@esgyn.com>
Authored: Thu Nov 30 02:43:22 2017 +0000
Committer: Anoop Sharma <an...@esgyn.com>
Committed: Thu Nov 30 02:43:22 2017 +0000

----------------------------------------------------------------------
 core/sql/sqlcomp/DefaultConstants.h | 213 +------------------------------
 core/sql/sqlcomp/nadefaults.cpp     | 124 ------------------
 2 files changed, 1 insertion(+), 336 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/4722203e/core/sql/sqlcomp/DefaultConstants.h
----------------------------------------------------------------------
diff --git a/core/sql/sqlcomp/DefaultConstants.h b/core/sql/sqlcomp/DefaultConstants.h
index 6293539..3f837c8 100644
--- a/core/sql/sqlcomp/DefaultConstants.h
+++ b/core/sql/sqlcomp/DefaultConstants.h
@@ -164,7 +164,7 @@ enum DefaultConstants
   DP2_CACHE_2048_BLOCKS,
   DP2_CACHE_4096_BLOCKS,
 
-  // The size of the DP2 cache in KB:
+
 
   // Constants needed to estimate the cost of communication
   // between DP2 and exeInDp2:
@@ -175,17 +175,6 @@ enum DefaultConstants
   CPUCOST_SCAN_DSK_TO_DP2_PER_KB,
   CPUCOST_SCAN_DSK_TO_DP2_PER_SEEK,
 
-  // Configured_memory_for defaults are all measured in KB
-  //  Configured_memory values are for calculating the memory
-  //  limit for large memory operations.
-  //  ARKESP is the minimum size without hash tables
-  //  BASE is the memory used by tmf, nsk-l and NT
-  //  DAM is the memory used by each DP2
-  //  MINIMUM_HASH is the least amount of memory we will use
-
-  // This is an executor constant used in costing,
-  // as of 3/23/98 it is 12 bytes. Change when executor
-  // changes.
 
   // Used in estimating blocks to read per scan access:
   COST_PROBE_DENSITY_THRESHOLD,
@@ -206,15 +195,6 @@ enum DefaultConstants
   // This number must be between 0 and 1.
   IO_TRANSFER_COST_PREFETCH_MISSES_FRACTION,
 
-  // When blocks are being read in order
-  // (i.e. they are not read more than once) the seeks are
-  // less expensive. Take this into account using the
-  // the IO_SEEKS_INORDER_FACTOR, a number greater
-  // than zero and less than or equal to 1:
-
-
-  // Used in sqlcomp/NADefaults.cpp
-
   DEF_CHUNK_SIZE,
   DEF_CPU_ARCHITECTURE,
   DEF_DISCS_ON_CLUSTER,
@@ -257,7 +237,6 @@ enum DefaultConstants
   EX_OP_ALLOCATE_TUPLE,
   EX_OP_COPY_ATP,
 
-  // optimization of data movement in DP2
 
   FIND_COMMON_SUBEXPRS_IN_OR,
 
@@ -273,13 +252,11 @@ enum DefaultConstants
   // Operator defaults used by the Generator:
   // buffer size, number of buffers, and queue sizes (down, up).
   // --------------------------------------------------------------------------
-  // Create buf.
   // DDL.
   GEN_DDL_BUFFER_SIZE,
   GEN_DDL_NUM_BUFFERS,
   GEN_DDL_SIZE_DOWN,
   GEN_DDL_SIZE_UP,
-  // Delete.
   // Describe.
   GEN_DESC_BUFFER_SIZE,
   GEN_DESC_NUM_BUFFERS,
@@ -290,17 +267,12 @@ enum DefaultConstants
   GEN_DP2I_NUM_BUFFERS,
   GEN_DP2I_SIZE_DOWN,
   GEN_DP2I_SIZE_UP,
-  // DP2 Delete Unique.
-  // DP2 Range Operator.
   // DP2 Subset Operator.
   GEN_DPSO_BUFFER_SIZE,
   GEN_DPSO_SIZE_DOWN,
   GEN_DPSO_SIZE_UP,
   // DP2 Unique Operator.
   GEN_DPUO_NUM_BUFFERS,
-  // DP2 VSBB Insert.
-  // Executor in DP2.
-  // Fast Sort.
   // Hash GroupBy.
   GEN_HGBY_BUFFER_SIZE,
   GEN_HGBY_NUM_BUFFERS,
@@ -311,10 +283,6 @@ enum DefaultConstants
   GEN_HSHJ_NUM_BUFFERS,
   GEN_HSHJ_SIZE_DOWN,
   GEN_HSHJ_SIZE_UP,
-  // Index Maintenance.
-  // Insert.
-  // Lock.
-  // Materialize.
   // Memory pressure Threshold
   GEN_MEM_PRESSURE_THRESHOLD,
   // Merge Join.
@@ -330,8 +298,6 @@ enum DefaultConstants
   // Partition Access.
   GEN_PA_BUFFER_SIZE,
   GEN_PA_NUM_BUFFERS,
-  // Recurse.
-  // Root.
    // Sample node
   GEN_SAMPLE_SIZE_DOWN,
   GEN_SAMPLE_SIZE_UP,
@@ -341,7 +307,6 @@ enum DefaultConstants
   GEN_SEQFUNC_NUM_BUFFERS,
   GEN_SEQFUNC_SIZE_DOWN,
   GEN_SEQFUNC_SIZE_UP,
-  // Sequence.
   // Sort GroupBy.
   GEN_SGBY_BUFFER_SIZE,
   GEN_SGBY_NUM_BUFFERS,
@@ -366,7 +331,6 @@ enum DefaultConstants
   // Split Bottom.
   // Split Top.
   GEN_SPLT_SIZE_UP,
-  // Stored Procedure.
   // Tuple Flow.
   GEN_TFLO_BUFFER_SIZE,
   GEN_TFLO_NUM_BUFFERS,
@@ -395,14 +359,11 @@ enum DefaultConstants
   GEN_TUPL_NUM_BUFFERS,
   GEN_TUPL_SIZE_DOWN,
   GEN_TUPL_SIZE_UP,
-  // Unordered NLJ.
   // Union.
   GEN_UN_BUFFER_SIZE,
   GEN_UN_NUM_BUFFERS,
   GEN_UN_SIZE_DOWN,
   GEN_UN_SIZE_UP,
-  // Update.
-  // Explain.
   // Compound Stmt.
   GEN_CS_BUFFER_SIZE,
   GEN_CS_NUM_BUFFERS,
@@ -589,7 +550,6 @@ enum DefaultConstants
   // For HashJoin.
   // -------------------------------------------------------------------------
   HJ_CPUCOST_INITIALIZE,
-  //  HJ_BUFFER_SIZE,
   HJ_INITIAL_BUCKETS_PER_CLUSTER,
   HJ_SCAN_TO_NJ_PROBE_SPEED_RATIO,
   HJ_TYPE,
@@ -696,27 +656,6 @@ enum DefaultConstants
   MSCF_OV_IO,
   MSCF_OV_MSG,
 
-  // -------------------------------------------------------------------------
-  // Factors used in determining how much concurrency occurs between
-  // similar simultaneous activities.  E.g., within the same process
-  // how much the I/O of one operator is overlappable with the I/O of
-  // another (whether parent, child, or sibling) operator that is
-  // executing concurrently.
-  // -------------------------------------------------------------------------
-
-  // -------------------------------------------------------------------------
-  // Factors that describe the current hardware/system platform.  To
-  // be used Only Until we've interfaced with the resource governor.
-  // Note: primitives like MSCF_SYSTEM_CPUS, and MSCF_STREAMS_PER_CPU,
-  // are not needed since PhysicalProperty::getCountOfCPUs(), and
-  // PhysicalProperty::getCountOfPlanFragmentsPerCPU(), already exist
-  // and can be used to derive that information.
-  //
-  // Note: ReqdPhysicalProperty::getCountOfAvailableCPUs() and
-  // ReqdPhysicalProperty::getCountOfPlanFragmentsPerCPU() also exist.
-  // Do you have Any opinion regarding Which class should be used to
-  // provide the needed information??
-  // -------------------------------------------------------------------------
 
   // -----------------------------------------------------------------------
   // Big memory usage
@@ -883,14 +822,6 @@ enum DefaultConstants
   MULTI_JOIN_PROBE_HASH_TABLE,
 
   //------------------------------------------------------------------------
-  // MultiJoin complexity threshold
-  //------------------------------------------------------------------------
-
-  //------------------------------------------------------------------------
-  // MultiJoin work threshold
-  //------------------------------------------------------------------------
-
-  //------------------------------------------------------------------------
   // Specifies if ASM cache should be available.
   //------------------------------------------------------------------------
   ASM_ALLOWED,
@@ -1033,11 +964,6 @@ enum DefaultConstants
   // -----------------------------------------------------------------------
   PCODE_OPT_LEVEL,
 
-  // -----------------------------------------------------------------------
-  // Partition Management.
-  // Number of rows processed per transaction.
-  // -----------------------------------------------------------------------
-
   //--------------------------------------------------------------------------
   // The group by reduction for pushing a partial group by past the
   //  right side of the TSJ must be at least this much.  If 0.0, then
@@ -1105,10 +1031,6 @@ enum DefaultConstants
   // ------------------------------------------------------------------------
   READONLY_CURSOR,
 
-  // -------------------------------------------------------------------------
-  // Pass an indicator of stream's idleness in a diagnostics area.
-  // -------------------------------------------------------------------------
-
   // multiplicative factor used to inflate cost of risky operators.
   RISK_PREMIUM_MJ,
   RISK_PREMIUM_NJ,
@@ -1118,10 +1040,6 @@ enum DefaultConstants
   ROBUST_QUERY_OPTIMIZATION,
   ROBUST_SORTGROUPBY,
 
-  //  ------------------------------------------------------------------------
-  //  For Drop Table
-  // -------------------------------------------------------------------------
-
   // -------------------------------------------------------------------------
   // For Scratch files
   // -------------------------------------------------------------------------
@@ -1146,10 +1064,6 @@ enum DefaultConstants
   SORT_EX_BUFFER_SIZE,            // Executor buffer size.
   SORT_TREE_NODE_SIZE,            // Internal node size of Tournament Tree.
   // -------------------------------------------------------------------------
-  // For Triggers Temporary Table's LOCATION and PARTITIONS   
-  // -------------------------------------------------------------------------
-
-  // -------------------------------------------------------------------------
   // For Node Maps
   // -------------------------------------------------------------------------
   FAKE_VOLUME_ASSIGNMENTS, // Force num of DP2 vols = num of partitions? ON/OFF
@@ -1200,11 +1114,6 @@ enum DefaultConstants
   NOT_NULL_CONSTRAINT_DROPPABLE_OPTION,
   PRIMARY_KEY_CONSTRAINT_DROPPABLE_OPTION,
 
-  // -------------------------------------------------------------------------
-  // To decide whether we should optimize a VP Join during optimization or
-  // just expand it during pre code generation.
-  // -------------------------------------------------------------------------
-
   CATALOG,
   SCHEMA,
 
@@ -1267,10 +1176,6 @@ enum DefaultConstants
   NATIONAL_CHARSET,
   TERMINAL_CHARSET,
 
-  // to use dense sql buffers for communication between
-  // FS and EID. Default is ON.
-  // If turned off, sparse sql_buffers are used.
-
 
   //--------------------------------------------------------------------------
   // Enable character set inference for ODBC 2.X.
@@ -1308,10 +1213,6 @@ enum DefaultConstants
   NSK_DBG_PRINT_TASK,
   NSK_DBG_PRINT_TASK_STACK,
 
-  // --------------------------------------------------------------------------
-  // Index creation defaults.
-  // --------------------------------------------------------------------------
-
   // -----------------------------------------------------------------------
   // for IUD operations, this default, if set, indicates that the Xn needs
   // to be rolled back on error.
@@ -1330,10 +1231,6 @@ enum DefaultConstants
   // -------------------------------------------------------------------
   UPD_SAVEPOINT_ON_ERROR,
 
-  // ----------------------------------------------------------------------
-  // this default indicates the max number of rows which will be locked
-  // when stable access is being used. Default is 32.
-  // ----------------------------------------------------------------------
 
   // ----------------------------------------------------------------------
   // User-defined routines
@@ -1489,12 +1386,7 @@ enum DefaultConstants
   GEN_SORT_TOPN,
 
   SORT_ALGO,            // Sort algorithm choice
-  // Not used anymore. OVERRIDE_SYSKEY takes its place.
 
-  // ----------------------------------------------------------------------
-  // If enabled (ON), indicates that it is OK to compile IUD queries
-  // against ODBC metadata tables.
-  // ----------------------------------------------------------------------
 
   // -------------------------------------------------------------------------
   // Specifies what percentage of smaller table in join, should be used as
@@ -1511,7 +1403,6 @@ enum DefaultConstants
   // -------------------------------------------------------------------------
   USE_CCMPASSERT_AS_CMPASSERT,
 
-  // share opens if reference count of table is greater than 5.
 
   NEW_OPT_DRIVER,
   FORCE_PASS_ONE,
@@ -1575,9 +1466,6 @@ enum DefaultConstants
   INTERACTIVE_ACCESS,
   //10-040621-7139-end
 
-
-  // Specifies locations for CREATE statements that don't have a
-  // LOCATION clause
   
   //Support transactions for DDL operations.
   DDL_TRANSACTIONS,
@@ -1650,9 +1538,6 @@ enum DefaultConstants
   HIST_DEFAULT_SAMPLE_MAX,
   HIST_DEFAULT_SAMPLE_RATIO,
 
-  // if set to ON, then dp2 splits blocks as if inserts are sequential.
-  // if set to ENABLE, then blocks are split depending on whether
-  // sequential inserts are detected.
 
   // EMS events
   USER_EXPERIENCE_LEVEL,
@@ -1662,9 +1547,6 @@ enum DefaultConstants
   DYN_PA_QUEUE_RESIZE_INIT_DOWN,
   DYN_PA_QUEUE_RESIZE_INIT_UP,
 
-  // if set, DDL allows users to make tables audited or unaudited.
-  // Used to enable user issued sidetree inserts.
-
   // if this default is set to ON, then the max precision of a numeric
   // expression(arithmetic, aggregate) is limited to MAX_NUMERIC_PRECISION
   // (= 18). If this is set to OFF, the default value, then the max precision
@@ -1691,8 +1573,6 @@ enum DefaultConstants
 
   MERGE_JOIN_WITH_POSSIBLE_DEADLOCK,
 
-  // priority and delta of msgs sent by fs to dp2.
-
   ALLOW_RANGE_PARTITIONING,
 
 
@@ -1704,8 +1584,6 @@ enum DefaultConstants
 
   MVGROUP_AUTOMATIC_CREATION,
 
-  // If this CQD is set to TRUE, POS will create HASH2 tables when hash1
-  // syntax is used.
 
   // Allow RequireApproximatelyNPartitions::realize() to use one of three
   // hash partitioning schemes: 0 - HashPartitioningFunction,
@@ -1875,7 +1753,6 @@ enum DefaultConstants
   GEN_HGBY_PARTIAL_GROUP_FLUSH_THRESHOLD,
   GEN_HGBY_PARTIAL_GROUP_ROWS_PER_CLUSTER,
 
-  // Controls for utility testware support (query plan logging and testpoints)
 
   ALLOW_DP2_ROW_SAMPLING,
 
@@ -1886,12 +1763,6 @@ enum DefaultConstants
 
   USE_PARALLEL_FOR_NUM_PARTITIONS,
 
-  // create table with filecode indicating it is a "temp" table so RDF
-  // ignore it on the backup system
-
-  // Force creation of definition schemas to be different than the current
-  // schema version, e.g. version 1200 instead of version 2000
-
   EXE_DIAGNOSTIC_EVENTS,    // Sends various executor diagnostics to EMS
 
   SHARE_TEMPLATE_CACHED_PLANS,
@@ -1922,15 +1793,6 @@ enum DefaultConstants
 
   HIST_DEFAULT_NUMBER_OF_INTERVALS,
 
-  // ignore_duplicate_keys is no more valid. It is still
-  // here as dummy for compatibility with existing scripts.
-
-  // in mode_special1, duplicate rows are ignored if inserting a row in the
-  // base table which has a user defined primary key. If this default is set
-  // to OFF in mode_special_1, then duplicate rows are not ignored.
-  //
-  // If not in mode_special_1, and this default is ON, then duplicate rows
-  // are ignored.
 
  SESSION_USERNAME,
 
@@ -1958,17 +1820,12 @@ enum DefaultConstants
 
   ALLOW_UNEXTERNALIZED_MAINTAIN_OPTIONS,
 
-  // For OPI, this is the minimum number of seconds it will retry error 73
-  // that occurs in the commit phase; default is 120 seconds.
-
   EXE_MEMORY_AVAILABLE_IN_MB, // Mem size (MB) in ESP available for BMOs
 
   EXE_MEMORY_FOR_PARTIALHGB_IN_MB, // Mem size (MB) in ESP available
                                    // for partial hash groupby.
   SSD_BMO_MAX_MEM_THRESHOLD_IN_MB,
 
-  // The following were added as part of the Wal*Mart changes to improve concurrency
-  // when DDL and DML operations are run concurrently
   NAR_DEPOBJ_ENABLE ,
 
   // For Adaptive Segmentation (aka Virtual Segmentation, Adaptive
@@ -1984,10 +1841,6 @@ enum DefaultConstants
   WORK_UNIT_ESP_DATA_COPY_COST,
 
 
-  // opens are distributed among all partitions instead of just root.
-  // 0: no distribution, only use root.
-  // -1: max distribution, all partitions
-  // <number>: num of partitions per segment
 
 
   MV_REFRESH_MDELTA_MAX_DELTAS_THRESHOLD,
@@ -2112,8 +1965,6 @@ enum DefaultConstants
   USTAT_FETCHCOUNT_ACTIVE,
 
   SEMIJOIN_TO_INNERJOIN_TRANSFORMATION,
-
-  // Enables or disables sending the plan fragment to DP2 nowaited.
   POS_NUM_DISK_POOLS,
   POS_DISKS_IN_SEGMENT,
 
@@ -2127,9 +1978,6 @@ enum DefaultConstants
   // Compress plan fragments downloaded to ESPs (ESP and DP2 frags)
   FRAG_COMPRESSION_THRESHOLD,
 
-  // During the creation of Schema Security this specifies if a schema label
-  // (surrogate file) is created on all segments of a registered catalog.
-  // CQD CAT_ENABLE_SCHEMA_SECURITY must be set to "ON" for this to take effect.
 
   // Display only externalized information in SHOWDDL if set to EXTERNAL
   SHOWDDL_DISPLAY_FORMAT,
@@ -2138,7 +1986,6 @@ enum DefaultConstants
   GEN_LEANER_EXPRESSIONS,
 
 
-  // see executor/ExDp2Trace.h for usage notes
 
   POS_DISK_POOL,
 
@@ -2171,8 +2018,6 @@ enum DefaultConstants
   // Units are in MegaBytes; zero (default) means that this CQD is OFF !!
   EXE_MEM_LIMIT_PER_BMO_IN_MB,
 
-  // Control how many times update statistics will retry the SECURITY checks.
-
   // Disables use of ProbeCache
   NESTED_JOIN_CACHE,
 
@@ -2248,9 +2093,6 @@ enum DefaultConstants
   // to be the clustering key.
   VOLATILE_TABLE_FIND_SUITABLE_KEY,
 
-  // if this is set, and there is no user specified primary key or
-  // store by clause, then make the first column of the volatile table
-  // to be the clustering key.
 
 // Allows pcodes for varchars
   VARCHAR_PCODE,
@@ -2324,18 +2166,8 @@ enum DefaultConstants
   ROUTINE_JOINS_SPOIL_JBB,
   
 
-  // Specifies whether sample tables should be created for fetch count
-
-
-  // The following 3 CQDs are used when using POS in OSIM mode
-
-  // Allow the use of POS with OSIM
-
-  // Specify the disk size
 
-  // Specify the names of the nodes in the cluster
 
-  // Priority of update stats when run by USAS (for automation).
 
   // Specify the node
   UNIQUE_HASH_JOINS,
@@ -2354,8 +2186,6 @@ enum DefaultConstants
  // Specify the file that logs certain MXCMP errors.
   CMP_ERR_LOG_FILE,
 
-  // an MJ query with a greater query
-  // complexity will be considered complex
 
   // override the source schema with the target schema
   // SOURCE_SCHEMA:TARGET_SCHEMA
@@ -2382,8 +2212,6 @@ enum DefaultConstants
 
   DISABLE_READ_ONLY,
 
-  // Allow drop and alter schema level privileges when ON
-
   // perform substring transformation (ICBC PoC)
   SUBSTRING_TRANSFORMATION,
 
@@ -2430,12 +2258,7 @@ enum DefaultConstants
   // If set to OFF, place all metadata tables on the same volume.
   CAT_DISTRIBUTE_METADATA,
 
-  // Skip version compatibility check in catman to allow ddl on lower version
-  // schema. This is to allow problems to be fixed after UPGRADE failed
-  // due to metadata corruption.
 
-  // By default (ON), online populate index is performed.
-  // OFF then means offline populate index
 
   // Pubsub holdable cursor is not closed on rollback by default
   // But, ANSI standard expects the holdable cursor to be closed on rollback 
@@ -2445,18 +2268,11 @@ enum DefaultConstants
   // condition by default
   PSHOLD_UPDATE_BEFORE_FETCH,
 
-  // This will allow create operations on a catalog if set to 'ON'
-
-  // This will make schema owner the default object owner if set to 'ON'
-
-  // Added to test lazy update issues
 
 
   // Update statistics automation CQDs to allow for automation settings.
   USTAT_AUTO_READTIME_UPDATE_INTERVAL,
   USTAT_AUTO_FOR_VOLATILE_TABLES,
-  // This allows us to skip metadata views creation during regression run
-  // and avoid any possible delay due to views creation for every new catalog
 
   // Use a compressed data format internally rather than current
   // SQLARK_EXPLODED_FORMAT
@@ -2467,7 +2283,6 @@ enum DefaultConstants
   // and variable length column values.
   BULK_MOVE_NULL_VARCHAR,
 
-  // use variable sized rows in hash buffers
 
   // display detailed MV information. Default is OFF
   MV_DUMP_DEBUG_INFO,
@@ -2601,9 +2416,7 @@ enum DefaultConstants
   // for schema access control
   DEFAULT_SCHEMA_ACCESS_ONLY,
 
-  // PUBLISH/UNPUBLISH command
 
-  // default used to test catman features
 
   // To control ESP exchange memory usage
   GEN_EXCHANGE_MAX_MEM_IN_KB,
@@ -2628,9 +2441,6 @@ enum DefaultConstants
   // QUERY STRATEGIZER RELATED
   QUERY_STRATEGIZER,
   EXPLAIN_STRATEGIZER_PARAMETERS,
-// The system-wide schema containing the universal functions
-  // SAS_PUT and SAS_SCORE and other functions set up for
-  // system-wide use.
 
   CASCADED_GROUPBY_TRANSFORMATION,
 
@@ -2761,14 +2571,11 @@ enum DefaultConstants
   COMPRESSED_INTERNAL_FORMAT_BMO_AFFINITY,
   COMPRESSED_INTERNAL_FORMAT_EXPLAIN,
   COMPRESSED_INTERNAL_FORMAT_DEFRAG_RATIO,
-  // access counter reset
 
-  // Control whether authorization caches immutable users
 
   // Enable the query invalidation processing in catman
   CAT_ENABLE_QUERY_INVALIDATION,
   
-  // Control creation of column privileges for object-level privileges
   
   MC_SKEW_SENSITIVITY_THRESHOLD, // multi-column skew threshold value
 
@@ -2810,14 +2617,6 @@ enum DefaultConstants
   MERGE_JOIN_ACCEPT_MULTIPLE_NJ_PROBES, // merge join accepts multiple NJ probes
 
 
-  // number of esps used to perform parallel ddl operation.
-  // If set to SYSTEM (the default), compiler will choose a value.
-
-  // number of esps used to perform parallel purgedata operation.
-  // If set to SYSTEM (the default), compiler will choose a value.
-
-  // enable dp2 transactions for unique requests
-
   // queries coming in from mariaDB interface
   MARIAQUEST_PROCESS,
 
@@ -2912,11 +2711,6 @@ enum DefaultConstants
   USTAT_USE_GROUPING_FOR_SAMPLING,
 
   USTAT_IUS_NO_BLOCK,
-
-  // Collect reorg stats. Default is ON and stats are collected. 
-  // This cqd is added in case
-  // one need to go back to the old behavior of no reorg stats, or if a problem
-  // need to be debugged.
   
   HIVE_MAX_STRING_LENGTH_IN_BYTES,
   HIVE_USE_FAKE_TABLE_DESC,
@@ -3026,14 +2820,12 @@ enum DefaultConstants
   // all DDL statements.
   HBASE_SERIALIZATION,
 
-  // for testing only. Creates metadata with old structures. Used to test upgrade.
 
   SQLMX_REGRESS,
 
   // For PCODE - Native Expressions work
   PCODE_NE_DBG_LEVEL,
    
-  // To set Reorg verify command for REORG CHECK command
 
   HBASE_ZOOKEEPER_PORT,
 
@@ -3080,9 +2872,6 @@ enum DefaultConstants
   HBASE_MAX_ESPS,
 
 
-  // Default is ON. If ON will use JNI and the Java API provided
-  // by Hive to access metadata for Hive which could be in any 
-  // DB that supports JDBC
 
   // for testing setjmp/longjmp compiler logic
   MEMORY_LIMIT_CMPCTXT_UPPER_KB,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/4722203e/core/sql/sqlcomp/nadefaults.cpp
----------------------------------------------------------------------
diff --git a/core/sql/sqlcomp/nadefaults.cpp b/core/sql/sqlcomp/nadefaults.cpp
index c88c445..70c7036 100644
--- a/core/sql/sqlcomp/nadefaults.cpp
+++ b/core/sql/sqlcomp/nadefaults.cpp
@@ -501,7 +501,6 @@ SDDkwd__(ALLOW_DP2_ROW_SAMPLING,               "SYSTEM"),
 
  DDkwd__(CAT_ALLOW_NEW_FEATUREX, "OFF"),
 
-// Control whether authorization caches immutable users
 
 
  DDkwd__(CAT_DEFAULT_COMPRESSION, "NONE"),
@@ -518,44 +517,20 @@ SDDkwd__(CAT_DISTRIBUTE_METADATA,             "ON"),
 SDDkwd__(CAT_ENABLE_QUERY_INVALIDATION, "ON"),
 
 
- // Throw an error if a column is part of the store by clause and
- // is not defined as NOT NULL return an error
 
 
- // Used to make ignore "already exists" error in Create and
- // "does not exist" error in Drop.
-
- // Used to make catman test134 predictable
-
- // Catalog Manager internal support for REPLICATE AUTHORIZATION
-
 // This enables the DB Limits functionality.  If set to OFF, then blocksize
 // is restricted to 4096 and clustering key size is limited to 255 bytes.
 // DB Limits checking is turned off on NT since NT's DP2 does not support
 // large blocks or keys.
   DDkwd__(CAT_LARGE_BLOCKS_LARGE_KEYS, "ON"),
 
-// If DB Limits is enabled, then increase the default blocksize to 32K
-// on NSK if the object's clustering key length is larger than this value.
-
-
-// If DB Limits is enabled, then increase the default blocksize to 32K
-// on NSK if the object's row size is larger than this value.
-
-
 // Controls how pathnames for routines/procedures/SPJs are interpreted
   DDkwd__(CAT_LIBRARY_PATH_RELATIVE, "OFF"),
 
 
 
 
-// This forces an rcb to be created with a different version number
-// A "0" means to take the current mxv version
-
-// Controls creation of column privileges for object-level privileges
-
-// If schema owner is object owner is ON, then the default owner for objects is the
-//  schema owner.
 
 
   // CMP_ERR_LOG_FILE indicates where to save a log for certain errors.
@@ -573,9 +548,6 @@ SDDkwd__(CAT_ENABLE_QUERY_INVALIDATION, "ON"),
   DD_____(COMPILE_TIME_MONITOR_LOG_ALLTIME_ONLY, "OFF"),
   DD_____(COMPILE_TIME_MONITOR_OUTPUT_FILE,	"NONE"),
 
-  // complexity threshold beyond which a
-  // MultiJoin query is considered too complex
-
 
   // Switch between new aligned internal format and exploded format
   DDkwd__(COMPRESSED_INTERNAL_FORMAT,                           "SYSTEM"),
@@ -891,9 +863,6 @@ SDDkwd__(CAT_ENABLE_QUERY_INVALIDATION, "ON"),
   DDint__(COMP_INT_80,         "3"),
 
 
-  // max num of retries after parl purgedata open/control call errs.Default 25.
-  // delay between each paral pd error retry. Default is 2 seconds.
-
   DDint__(COMP_INT_89,         "2"),
   DDint__(COMP_INT_9,         "0"),
   DDint__(COMP_INT_90,         "0"),
@@ -905,14 +874,11 @@ SDDkwd__(CAT_ENABLE_QUERY_INVALIDATION, "ON"),
   DD_____(COMP_STRING_2,	    ""),
   DD_____(COMP_STRING_5,	    ""),
 
-  // Configured_memory_for defaults are all measured in KB
 
   DDkwd__(CONSTANT_FOLDING,                     "OFF"),
 
   DDkwd__(COSTING_SHORTCUT_GROUPBY_FIX,                "ON"),
   DDflt0_(COST_PROBE_DENSITY_THRESHOLD, ".25"),
-  // As of 3/23/98 the tupp desc. length is 12 bytes. Change when executor
-  // changes.
 
   DDflt0_(CPUCOST_COMPARE_COMPLEX_DATA_TYPE_OVERHEAD,	"10."),
   DDflt0_(CPUCOST_COMPARE_COMPLEX_DATA_TYPE_PER_BYTE,	".1"),
@@ -1065,12 +1031,10 @@ SDDui___(CYCLIC_ESP_PLACEMENT,                  "1"),
   // if it's "OFF" then the defaults of the two heuristics will be used
   DDkwd__(DATA_FLOW_OPTIMIZATION,		"ON"),
 
-  // DDL Default location support
 
   DDkwd__(DDL_EXPLAIN,                           "OFF"),
   DDkwd__(DDL_TRANSACTIONS,         "ON"),
 
-    // We ignore this setting for the first (SYSTEM_DEFAULTS) table open+read.
 
  SDDkwd__(DEFAULT_CHARSET,           (char *)SQLCHARSETSTRING_ISO88591),
  XDDui1__(DEFAULT_DEGREE_OF_PARALLELISM,    "2"),
@@ -1110,27 +1074,12 @@ SDDui___(CYCLIC_ESP_PLACEMENT,                  "1"),
   DD_____(DISPLAY_DATA_FLOW_GRAPH,		"OFF"),
  XDDkwd__(DISPLAY_DIVISION_BY_COLUMNS,          "OFF"),
 
- // opens are distributed among all partitions instead of just root.
- // 0: no distribution, only use root.
- // -1: max distribution, all partitions
- // <number>: num of partitions per segment
 
   // temp. disable dop reduction logic
   DDflt0_(DOP_REDUCTION_ROWCOUNT_THRESHOLD,	"0.0"),
 
 
 
-  // if set, then space needed for executor structures at runtime is
-  // optimized such that the allocation starts with a low number and then
-  // is allocated on a need basis. This means that we may have to allocate
-  // more smaller chunks if much space is needed. But it helps in the case
-  // where many plans are being used and each one only takes a small amount
-  // of space. This optimization especially helps in case of Dp2 fragments
-  // as there is only a finite amount of space available there. Once that
-  // limit is reached, and a new plan is shipped, it means that an existing
-  // eid plan from dp2 memory need to be swapped out and then refixed up.
-  // By reducing space utilization, we end up with more eid sessions in
-  // use inside of dp2.
 
 
   // DP2 Cache defaults as of 06/08/98.
@@ -1141,7 +1090,6 @@ SDDui___(CYCLIC_ESP_PLACEMENT,                  "1"),
   DDui1__(DP2_CACHE_4096_BLOCKS,              "4096"),
   DDui1__(DP2_CACHE_512_BLOCKS,			"152"),
   DDui1__(DP2_CACHE_8K_BLOCKS,                  "2048"),
-  // The cache size is about 2000 pages @ 4k each page
   // Exchange Costing
   // 6/12/98.
   // End of buffer header is 32 bytes or .0313 KB.
@@ -1170,7 +1118,6 @@ SDDui___(CYCLIC_ESP_PLACEMENT,                  "1"),
 
   DDkwd__(EID_SPACE_USAGE_OPT,			"OFF"),
 
- // For both of these CQDs see executor/ExDp2Trace.h for values.
   DDkwd__(ELIMINATE_REDUNDANT_JOINS,             "ON"),
 
 
@@ -1457,8 +1404,6 @@ SDDkwd__(EXE_DIAGNOSTIC_EVENTS,		"OFF"),
   DDui1__(GEN_UN_SIZE_DOWN,			"8"),
   DDui1__(GEN_UN_SIZE_UP,			"16"),
 
-  // Used when Compressed_Internal_Format is on to reduce space in the
-  // hash buffers (Hash Join and Hash Groupby) and sort buffers.
 
 
   // When less or equal to this CQD (5000 rows by default), a partial root 
@@ -1715,7 +1660,6 @@ SDDkwd__(EXE_DIAGNOSTIC_EVENTS,		"OFF"),
 
  // -------------------------------------------------------------------------
 
- //  DDui2__(HJ_BUFFER_SIZE,			"32"),
   DDflt0_(HJ_CPUCOST_INITIALIZE,		"1."),
   DDui1__(HJ_INITIAL_BUCKETS_PER_CLUSTER,	"4."),
   DDkwd__(HJ_NEW_MCSB_PLAN,			"OFF"),
@@ -1728,15 +1672,7 @@ SDDkwd__(EXE_DIAGNOSTIC_EVENTS,		"OFF"),
   DDkwd__(HYBRID_QUERY_CACHE, "ON"),
   DDkwd__(IF_LOCKED,				"WAIT"),
 
-    // ignore_duplicate_keys is no more valid. It is still
-  // here as dummy for compatibility with existing scripts.
 
- // in mode_special_1, duplicate rows are ignored if inserting a row in the
- // base table which has a user defined primary key. If this default is set
- // to OFF in mode_special_1, then duplicate rows are not ignored.
- //
- // If not in mode_special_1, and this default is ON, then duplicate rows
- // are ignored.
 
   DDkwd__(IMPLICIT_DATETIME_INTERVAL_HOSTVAR_CONVERSION,   "FALSE"),
   DDkwd__(IMPLICIT_HOSTVAR_CONVERSION,		"FALSE"),
@@ -1848,7 +1784,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
 
   DDui1__(MAX_ACCESS_NODES_PER_ESP,	"1024"),
 
- // this is the default length of a param which is typed as a VARCHAR.
 
   DDint__(MAX_DEPTH_TO_CHECK_FOR_CYCLIC_PLAN,   "1"),
 
@@ -1873,8 +1808,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
 
   DD18_128(MAX_NUMERIC_PRECISION_ALLOWED,        "128"),
 
-  // The max number of vertical partitions for optimization to be done under
-  // a VPJoin.
 
 
   // The max number of skewed values detected - skew buster
@@ -2073,8 +2006,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   // Units of MSCF_ET_LOCAL_MSG_TRANSFER are seconds/Kb
 
   DDflte_(MSCF_ET_LOCAL_MSG_TRANSFER,		"0.000046"),
-  // $$$ This should be removed. It is only used by preliminary costing
-  // for the materialize operator, which should not be using it.
   // : for calibration on 04/08/2004
   // Seek time will be derived from disk type.
 
@@ -2124,13 +2055,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   // outer subtree for NJ into fact table.
   DDflt0_(MULTI_JOIN_PROBE_HASH_TABLE,	       "0.000001"),
 
-  // threshold above which a query is considered complex
-  // this only applies to queries that can be rewritten
-  // as Multi Joins
-
-  // threshold above which a query is considered to do
-  // a lot of work his only applies to queries that can be
-  // rewritten as Multi Joins
 
  SDDint__(MULTI_JOIN_THRESHOLD,			"3"),
 
@@ -2282,21 +2206,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   DDkwd__(NEW_MDAM,		"ON"),
   DDkwd__(NEW_OPT_DRIVER,		"ON"),
 
-  // Ansi name of the next DEFAULTS table to read in.
-  // Contains blanks, or the name of a DEFAULTS table to read values from next,
-  // after reading all values from this DEFAULTS table.  The name may contain
-  // format strings of '%d' and '%u', which are replaced with the domain name
-  // and user name, respectively, of the current user.  The name may begin with
-  // '$', in which it is replaced by its value as a SYSTEM environment variable.
-  // This value in turn may contain '%d' and '%u' formats.  When these
-  // replacements are complete, the resulting name is qualified by the current
-  // default catalog and schema, if necessary, and the resulting three-part ANSI
-  // table's default values are read in.  This table may contain another
-  // NEXT_DEFAULTS_TABLE value, and different default CATALOG and
-  // SCHEMA values to qualify the resulting table name, and so on, allowing a
-  // chain of tables to be read; combined with the format and environment
-  // variable replacements, this allows per-domain, per-system, and per-user
-  // customization of SQL/MX default values.
 
 
   DDflt0_(NJ_CPUCOST_INITIALIZE,		".1"),
@@ -2476,7 +2385,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   DDint__(OR_PRED_TO_SEMIJOIN_TABLE_MIN_SIZE,                 "10000"),
 
 
-  // The Optimizer Simulator (OSIM) CQDs
 
   DDui2__(OS_MESSAGE_BUFFER_SIZE,    "32"),
  // if set to "ansi", datetime output is in ansi format. Currently only
@@ -2523,13 +2431,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   // optimizer will compute the number of ESPs.
  XDDui1__(PARALLEL_NUM_ESPS,			"SYSTEM"),
 
-  // If PARALLEL_NUM_ESPS is "SYSTEM",
-  // optimizer will compute the number of ESPs to be used for parallel ddl
-  // operations.
-
-  // If PARALLEL_NUM_ESPS is "SYSTEM",
-  // optimizer will compute the number of ESPs to be used for parallel purgedata
-  // operation.
 
   // is partial sort applicable; if so adjust sort cost accordingly
   DDflt0_(PARTIAL_SORT_ADJST_FCTR,        "1"),
@@ -2561,10 +2462,6 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   DDint__(PCODE_NE_ENABLED,   "1" ), // Native Expressions Enabled
   DDkwd__(PCODE_NE_IN_SHOWPLAN, "ON"), // Native Expression in Showplan output
 
-  // This PCODE_NE_LOG_PATH cqd is now obsolete. Use PCODE_DEBUG_LOGDIR instead.
-  // Would delete the following line except that would also mean deleting the
-  // corresponding line in DefaultConstants.h which would change the values for
-  // the following definitions in the same enum.
 
   DDint__(PCODE_OPT_FLAGS,                      "60"),
  
@@ -2573,13 +2470,9 @@ SDDkwd__(ISO_MAPPING,           (char *)SQLCHARSETSTRING_ISO88591),
   DDint__(PHY_MEM_CONTINGENCY_MB,     "3072"),
 
   DDkwd__(PLAN_STEALING,			"ON"),
-  // Not in use anymore. OVERRIDE_SYSKEY is used instead.
 
   // Partition OVerlay Support (POS) options
   SDDkwd__(POS,                                 "DISK_POOL"),
-   // default to 300 GB
-
-   // default to 72GB 
    DD_____(POS_DISKS_IN_SEGMENT,                 ""),
    DD_____(POS_DISK_POOL,			"0"),
   SDDui___(POS_NUM_DISK_POOLS,                  "0"),
@@ -2641,7 +2534,6 @@ SDDflt0_(QUERY_CACHE_SELECTIVITY_TOLERANCE,       "0"),
  XDDint__(QUERY_LIMIT_SQL_PROCESS_CPU,         "0"),
  // Extra debugging info for QUERY_LIMIT feature.
  DDkwd__(QUERY_LIMIT_SQL_PROCESS_CPU_DEBUG,              "OFF"),
- // How many iterations in scheduler subtask list before evaluating limits.
   // For X-prod HJ: (# of rows joined * LIMIT) before preempt.
  DDint__(QUERY_LIMIT_SQL_PROCESS_CPU_XPROD,         "10000"),
  // controls various expr optimizations based on bit flags.
@@ -2716,16 +2608,12 @@ SDDflt0_(QUERY_CACHE_SELECTIVITY_TOLERANCE,       "0"),
   DDkwd__(REPLICATE_COMPRESSION_TYPE,           "SYSTEM"),
   // Determines if DISK POOL setting should be passed with DDL when replicating
   DDkwd__(REPLICATE_DISK_POOL,                  "ON"),
-  // Display a BDR-internally-generated command before executing it
-  // Executing commands generated internally by BDR
   // VERSION of the message from the source system to maintain compatibility
   // This version should be same as REPL_IO_VERSION_CURR in executor/ExeReplInterface.h
   // Make changes accordingly in validataorReplIoVersion validator
   DDrver_(REPLICATE_IO_VERSION,                 "17"),
 
 
-  // max num of retries after replicate server(mxbdrdrc) returns an error
-
 
 
   DDkwd__(REUSE_BASIC_COST,			"ON"),
@@ -3278,10 +3166,6 @@ XDDkwd__(SUBQUERY_UNNESTING,			"ON"),
   // to be the clustering key.
   DDkwd__(VOLATILE_TABLE_FIND_SUITABLE_KEY,     "SYSTEM"),
 
-  // if this is set, and there is no user specified primary key or
-  // store by clause, then make the first column of the volatile table
-  // to be the clustering key.
-  // Default is ON.
 
   DDkwd__(VSBB_TEST_MODE,			"OFF"),
  XDDkwd__(WMS_CHILD_QUERY_MONITORING,                       "OFF"),
@@ -3474,11 +3358,6 @@ void NADefaults::initCurrentDefaultsWithDefaultDefaults()
 {
   deleteMe();
 
-  Lng32 ij = 0;
-  while (ij)
-    {
-      ij = 2 - ij;
-    }
 
   const size_t numAttrs = numDefaultAttributes();
   if (numAttrs != sizeof(defaultDefaults) / sizeof(DefaultDefault))
@@ -3696,8 +3575,6 @@ void NADefaults::initCurrentDefaultsWithDefaultDefaults()
 
   if(resetNeoDefaults)
   {
-    // turn on ALL stats during regressions run.
-    //    currentDefaults_[COMP_BOOL_157] = "ON";a
 
     // turn on INTERNAL format for SHOWDDL statements
     currentDefaults_[SHOWDDL_DISPLAY_FORMAT] = "INTERNAL";
@@ -4827,7 +4704,6 @@ NABoolean NADefaults::isNonResetableAttribute(const char* attrName) const
 NABoolean NADefaults::isSetOnceAttribute(Int32 attrEnum) const
 {
   if ( attrEnum == DEFAULT_SCHEMA_ACCESS_ONLY )
-    //        attrEnum == PUBLISHING_ROLES )
     return TRUE;
   
    return FALSE;