You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafodion.apache.org by su...@apache.org on 2018/01/22 15:56:48 UTC

[1/9] trafodion git commit: fix the nullpointer error scaned by TScanCode

Repository: trafodion
Updated Branches:
  refs/heads/master b0d0d53a9 -> 0f025ac62


http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sqf/src/seabed/src/fsi.cpp
----------------------------------------------------------------------
diff --git a/core/sqf/src/seabed/src/fsi.cpp b/core/sqf/src/seabed/src/fsi.cpp
index 01c41db..d7b011d 100644
--- a/core/sqf/src/seabed/src/fsi.cpp
+++ b/core/sqf/src/seabed/src/fsi.cpp
@@ -564,7 +564,9 @@ Fs_Open_Thread *Fs_Open_Thread::thread_get(const char *pp_filename,
         lp_entry = new Map_Open_Entry_Type;
         lp_entry->ip_thr = lp_thr;
         cv_map.putv(pp_filename, lp_entry);
-        lp_thr->md_list_add(pp_md);
+        // this only want to fix error checked by tools
+        if (NULL != lp_thr)
+            lp_thr->md_list_add(pp_md);
         lv_status = cv_map_mutex.unlock();
         SB_util_assert_ieq(lv_status, 0);
     }
@@ -572,10 +574,10 @@ Fs_Open_Thread *Fs_Open_Thread::thread_get(const char *pp_filename,
     if (gv_fs_trace) {
         if (lv_reuse)
             trace_where_printf(WHERE, "name=%s, reuse thread, filename=%s\n",
-                               lp_thr->get_name(), pp_filename);
+                    (lp_thr == NULL) ? "NULL" : lp_thr->get_name(), pp_filename);
         else
             trace_where_printf(WHERE, "name=%s, got thread, filename=%s\n",
-                               lp_thr->get_name(), pp_filename);
+                    (lp_thr == NULL) ? "NULL" : lp_thr->get_name(), pp_filename);
     }
 
     lv_status = cv_thread_get_mutex.unlock();

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sqf/src/seabed/src/msmon.cpp
----------------------------------------------------------------------
diff --git a/core/sqf/src/seabed/src/msmon.cpp b/core/sqf/src/seabed/src/msmon.cpp
index 311e099..241c150 100644
--- a/core/sqf/src/seabed/src/msmon.cpp
+++ b/core/sqf/src/seabed/src/msmon.cpp
@@ -4446,7 +4446,7 @@ SB_Export int msg_mon_open_process_self_ic(SB_Phandle_Type *pp_phandle,
 //
 void msg_mon_oc_cbt(MS_Md_Type *pp_md, void *pp_stream) {
     const char   *WHERE = "msg_mon_oc_cbt";
-    Mon_Msg_Type *lp_msg;
+    Mon_Msg_Type *lp_msg = NULL;
     bool          lv_aborted;
     bool          lv_close_dup;
     bool          lv_close_shutdown;
@@ -4550,7 +4550,6 @@ void msg_mon_oc_cbt(MS_Md_Type *pp_md, void *pp_stream) {
         break;
 
     default:
-        lp_msg = NULL;
         SB_util_abort("invalid pp_md->out.iv_msg_type"); // sw fault
         break;
     }
@@ -4592,13 +4591,13 @@ void msg_mon_oc_cbt(MS_Md_Type *pp_md, void *pp_stream) {
                 trace_where_printf(WHERE, "connection-open (aborted)\n");
         }
 
-        if (gv_ms_trace_mon) {
+        if (gv_ms_trace_mon && NULL != lp_msg) {
             const char *lp_msg_type = msg_util_get_msg_type(lp_msg->type);
             trace_where_printf(WHERE, "manufacturing/queueing %s (%d) mon message\n",
                                lp_msg_type, lp_msg->type);
             msg_mon_trace_msg(WHERE, lp_msg);
         }
-        if (gv_ms_enable_messages) {
+        if (gv_ms_enable_messages && NULL != lp_msg) {
             if (lp_msg->type == MsgType_Close) {
 
                 do {

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/cli/Context.cpp
----------------------------------------------------------------------
diff --git a/core/sql/cli/Context.cpp b/core/sql/cli/Context.cpp
index 6eef48f..4ee326f 100644
--- a/core/sql/cli/Context.cpp
+++ b/core/sql/cli/Context.cpp
@@ -3357,7 +3357,8 @@ ExStatisticsArea *ContextCli::getMergedStats(
         break;
       break;
     }
-    *ssmpMsgStream << *rtsQueryId;
+    if (NULL != rtsQueryId)
+      *ssmpMsgStream << *rtsQueryId;
   }
   if (RtsTimeout != 0)
   {

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/cli/ExSqlComp.cpp
----------------------------------------------------------------------
diff --git a/core/sql/cli/ExSqlComp.cpp b/core/sql/cli/ExSqlComp.cpp
index 9d57157..3a514b0 100644
--- a/core/sql/cli/ExSqlComp.cpp
+++ b/core/sql/cli/ExSqlComp.cpp
@@ -89,7 +89,7 @@ void ExSqlComp::clearDiags()
   if (diagArea_)
     diagArea_->clear();
   else
-    diagArea_ = diagArea_->allocate(h_);
+    diagArea_ = ComDiagsArea::allocate(h_);
 }
 
 inline void ExSqlComp::initRequests(Requests& req)

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/cli/Globals.cpp
----------------------------------------------------------------------
diff --git a/core/sql/cli/Globals.cpp b/core/sql/cli/Globals.cpp
index b9dd6e5..1c3a9d0 100644
--- a/core/sql/cli/Globals.cpp
+++ b/core/sql/cli/Globals.cpp
@@ -791,7 +791,7 @@ Lng32 CliGlobals::setEnvVar(const char * name, const char * value,
 	  if (NOT reset)
 	    newEnvvarsLen += strlen(name) + strlen("=") + strlen(value) + 1;
 	}
-      else
+      else if (NULL != envvars_)
 	newEnvvarsLen += str_len(envvars_[count])+1;
     } 
   
@@ -827,7 +827,7 @@ Lng32 CliGlobals::setEnvVar(const char * name, const char * value,
 	      tgtCount++;
 	    }
 	}
-      else
+      else if (NULL != envvars_)
 	{
 	  l = str_len(envvars_[count])+1;
 	  str_cpy_all(newEnvvarsValue, envvars_[count], l);

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/executor/ExExplain.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ExExplain.cpp b/core/sql/executor/ExExplain.cpp
index ba142ec..b0e2a90 100644
--- a/core/sql/executor/ExExplain.cpp
+++ b/core/sql/executor/ExExplain.cpp
@@ -768,9 +768,9 @@ short ExExplainTcb::work()
 
 	  // starts with an '/'. It is an oss pathname.
 	  if ((modDir_) &&
-	      (strlen(modDir_) >= 3) &&
-	      (strncmp(modDir_, "/E/", 3) == 0) ||
-	      (strncmp(modDir_, "/G/", 3) == 0))
+	      ((strlen(modDir_) >= 3) &&
+               (strncmp(modDir_, "/E/", 3) == 0) ||
+               (strncmp(modDir_, "/G/", 3) == 0)))
 	    {
 	      // Pathname cannot be an Expand or a Guardian name.
 	      // Return error.

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/executor/ExStats.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/ExStats.cpp b/core/sql/executor/ExStats.cpp
index 23d9c0d..7093c44 100644
--- a/core/sql/executor/ExStats.cpp
+++ b/core/sql/executor/ExStats.cpp
@@ -8239,7 +8239,8 @@ ExStatisticsArea *ExStatsTcb::sendToSsmp()
         rtsQueryId = NULL;
         break;
     }
-    *ssmpMsgStream << *rtsQueryId;
+    if (NULL != rtsQueryId)
+      *ssmpMsgStream << *rtsQueryId;
   }
   if (RtsTimeout != 0)
   {

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/executor/cluster.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/cluster.cpp b/core/sql/executor/cluster.cpp
index 69e863b..0b82fb1 100644
--- a/core/sql/executor/cluster.cpp
+++ b/core/sql/executor/cluster.cpp
@@ -2395,7 +2395,7 @@ NABoolean Cluster::checkAndSplit(ExeErrorCode * rc)
 				         rc);
   
   if ( !next_ || *rc ) {
-    if ( ! rc ) * rc = EXE_NO_MEM_TO_EXEC;
+    * rc = EXE_NO_MEM_TO_EXEC;
     return TRUE;
   }
 

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/optimizer/BindItemExpr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/BindItemExpr.cpp b/core/sql/optimizer/BindItemExpr.cpp
index dcd6897..8ce0519 100644
--- a/core/sql/optimizer/BindItemExpr.cpp
+++ b/core/sql/optimizer/BindItemExpr.cpp
@@ -8110,6 +8110,12 @@ ItemExpr *ColReference::bindNode(BindWA *bindWA)
     return this;
   }
 
+  if (NULL == xcnmEntry)
+  {
+    bindWA->setErrStatus();
+    return this;
+  }
+
   // Continue with no-error, non-star column reference.
   ValueId valId = xcnmEntry->getValueId();
   setValueId(valId);	// not bound yet, but this makes more informative errmsg
@@ -12216,7 +12222,7 @@ ItemExpr *ZZZBinderFunction::tryToUndoBindTransformation(ItemExpr *expr)
         //                   ...)))
         if (op1->getOperatorType() == ITM_CAST)
           {
-            if (expr->origOpType() == ITM_DATEDIFF_QUARTER &&
+            if (NULL != expr && expr->origOpType() == ITM_DATEDIFF_QUARTER &&
                 op1->child(0)->getOperatorType() == ITM_DIVIDE)
               op1 = op1->child(0)->child(0); // the minus operator
               //    cast   /         -
@@ -12224,7 +12230,7 @@ ItemExpr *ZZZBinderFunction::tryToUndoBindTransformation(ItemExpr *expr)
               op1 = op1->child(0); // the minus operator
               //    cast   -
 
-            if (expr->origOpType() == ITM_DATEDIFF_YEAR)
+            if (NULL != expr && expr->origOpType() == ITM_DATEDIFF_YEAR)
               {
                 if (op1->child(0)->getOperatorType() == ITM_EXTRACT ||
                     op1->child(0)->getOperatorType() == ITM_EXTRACT_ODBC)
@@ -12741,7 +12747,7 @@ ItemExpr *HbaseColumnCreate::bindNode(BindWA *bindWA)
 	  if ((co != hcco->convType()) ||
 	      (! firstType && hcco->naType()) ||
 	      (firstType && ! hcco->naType()) ||
-	      (firstType && (NOT (*firstType == *hcco->naType()))))
+	      (firstType && hcco->naType() && (NOT (*firstType == *hcco->naType()))))
 	    {
 	      *CmpCommon::diags() << DgSqlCode(-4221)
 			       << DgString0("COLUMN_CREATE(list format)")

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/optimizer/MVInfo.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/MVInfo.cpp b/core/sql/optimizer/MVInfo.cpp
index 03e324b..08ba9ee 100644
--- a/core/sql/optimizer/MVInfo.cpp
+++ b/core/sql/optimizer/MVInfo.cpp
@@ -4450,9 +4450,9 @@ void MVInfoForDDL::processNormalizedInformation(BindWA *bindWA)
   {
     // Find the top most Join node (or the Scan node if there is no Join).
     RelExpr *topJoin = rootNode_;
-    while ( topJoin->getOperatorType() != REL_SCAN     &&
-           !topJoin->getOperator().match(REL_ANY_JOIN) &&
-	    topJoin != NULL)
+    while (topJoin != NULL &&
+           topJoin->getOperatorType() != REL_SCAN &&
+           !topJoin->getOperator().match(REL_ANY_JOIN))
       topJoin = topJoin->child(0);
 
     // Check if the Join tree is left linear.

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/optimizer/OptPhysRelExpr.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/OptPhysRelExpr.cpp b/core/sql/optimizer/OptPhysRelExpr.cpp
index 838eae4..f7bb358 100644
--- a/core/sql/optimizer/OptPhysRelExpr.cpp
+++ b/core/sql/optimizer/OptPhysRelExpr.cpp
@@ -6081,9 +6081,9 @@ NABoolean NestedJoin::OCBJoinIsFeasible(const Context* myContext) const
   if ( (myContext->requiresOrder() AND
         partReq AND 
         partReq->isRequirementExactlyOne() == FALSE) OR
-       partReq == NULL OR
-       (partReq->isRequirementApproximatelyN() AND
-         NOT partReq->partitioningKeyIsSpecified()
+       (partReq AND
+        partReq->isRequirementApproximatelyN() AND
+        NOT partReq->partitioningKeyIsSpecified()
        )
      )
   {

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/optimizer/PhyProp.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/PhyProp.cpp b/core/sql/optimizer/PhyProp.cpp
index 892886f..f0d6c8f 100644
--- a/core/sql/optimizer/PhyProp.cpp
+++ b/core/sql/optimizer/PhyProp.cpp
@@ -528,12 +528,12 @@ ReqdPhysicalProperty::compareRequirements(const ReqdPhysicalProperty &other) con
   // can't use any plan if the optimization goals are different
   // $$$$ may apply some fuzzy logic in the future for the number of rows
   if ( (perfGoal_ != NULL) AND
-       ( perfGoal_->isOptimizeForLastRow() AND
+       (( perfGoal_->isOptimizeForLastRow() AND
          (NOT other.perfGoal_->isOptimizeForLastRow()) ) OR
-       ( perfGoal_->isOptimizeForFirstRow() AND
+        ( perfGoal_->isOptimizeForFirstRow() AND
          (NOT other.perfGoal_->isOptimizeForFirstRow()) ) OR
-       ( perfGoal_->isOptimizeForResourceConsumption() AND
-         (NOT other.perfGoal_->isOptimizeForResourceConsumption()) ) )
+        ( perfGoal_->isOptimizeForResourceConsumption() AND
+         (NOT other.perfGoal_->isOptimizeForResourceConsumption()) )) )
     return UNDEFINED;
 
   // if the cost weights are different, the optimal solution is no

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/optimizer/memo.cpp
----------------------------------------------------------------------
diff --git a/core/sql/optimizer/memo.cpp b/core/sql/optimizer/memo.cpp
index 8363b33..b6d4b75 100644
--- a/core/sql/optimizer/memo.cpp
+++ b/core/sql/optimizer/memo.cpp
@@ -1041,10 +1041,10 @@ RelExpr * CascadesMemo::findDuplicate(RelExpr * expr) const
 
 	  // compare characteristic inputs/outputs
 	  if ((ga = expr->getGroupAttr()) != NULL AND
-	      NOT (ga->getCharacteristicInputs() ==
-		   old->getGroupAttr()->getCharacteristicInputs()) OR
-	      NOT (ga->getCharacteristicOutputs() ==
-		   old->getGroupAttr()->getCharacteristicOutputs()))
+	      (NOT (ga->getCharacteristicInputs() ==
+                    old->getGroupAttr()->getCharacteristicInputs()) OR
+               NOT (ga->getCharacteristicOutputs() ==
+                    old->getGroupAttr()->getCharacteristicOutputs())))
 	    goto not_a_duplicate;
 
 	  // compare operators and their arguments

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/parser/ElemDDLNode.cpp
----------------------------------------------------------------------
diff --git a/core/sql/parser/ElemDDLNode.cpp b/core/sql/parser/ElemDDLNode.cpp
index 78225af..4d67199 100644
--- a/core/sql/parser/ElemDDLNode.cpp
+++ b/core/sql/parser/ElemDDLNode.cpp
@@ -3170,7 +3170,7 @@ void ElemDDLDivisionClause::synthesize(ElemDDLNode * pColRefTree)
   {
     columnRefArray_.insert(pColRefTree->castToElemDDLColRef());
   }
-  else if (colRefEntries > 1)
+  else if (colRefEntries > 1 AND pColRefTree NEQ NULL)
   {
     ElemDDLList * pElemDDLList = pColRefTree->castToElemDDLList();
     ElemDDLColRef * pElemDDLColRef = NULL;

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/qms/QmsMVMemo.cpp
----------------------------------------------------------------------
diff --git a/core/sql/qms/QmsMVMemo.cpp b/core/sql/qms/QmsMVMemo.cpp
index 1c9461e..548a04e 100644
--- a/core/sql/qms/QmsMVMemo.cpp
+++ b/core/sql/qms/QmsMVMemo.cpp
@@ -475,7 +475,7 @@ void MVMemo::insert(QRJBBPtr jbb, MVDetailsPtr mv)
     if ( subGraph->isSelfJoin() && 
         !isSelfJoinTooBig       && 
         !isDuplicate            &&
-	(!found || map->isFull()) )
+	(!found || (NULL != map && map->isFull())) )
     {
       // Generate all the equivalent hash keys, and insert them all.
       map->prepareForSelfJoinWork();

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sql/runtimestats/ssmpipc.cpp
----------------------------------------------------------------------
diff --git a/core/sql/runtimestats/ssmpipc.cpp b/core/sql/runtimestats/ssmpipc.cpp
index 56a72e1..857913a 100755
--- a/core/sql/runtimestats/ssmpipc.cpp
+++ b/core/sql/runtimestats/ssmpipc.cpp
@@ -2051,7 +2051,7 @@ void SsmpNewIncomingConnectionStream::actOnCpuStatsReq(IpcConnection *connection
     default:
       break;
     }
-    if (cpuStats != NULL || cpuStats->numEntries() > 0)
+    if (cpuStats != NULL && cpuStats->numEntries() > 0)
        *this << *(cpuStats);
     send(FALSE);
     reply->decrRefCount();

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/win-odbc64/odbcclient/drvr35/charsetconv.cpp
----------------------------------------------------------------------
diff --git a/win-odbc64/odbcclient/drvr35/charsetconv.cpp b/win-odbc64/odbcclient/drvr35/charsetconv.cpp
index 34a2179..f53cc81 100644
--- a/win-odbc64/odbcclient/drvr35/charsetconv.cpp
+++ b/win-odbc64/odbcclient/drvr35/charsetconv.cpp
@@ -27,7 +27,7 @@ SQLRETURN WCharToUTF8(wchar_t *wst, int wstlen, char *st, int stlen, int *transl
 {
 	int len;
 	SQLRETURN rc = SQL_SUCCESS;
-	if (!error)
+	if (NULL != error)
 		error[0] ='\0';
 	if(translen != NULL)
 		*translen = 0;
@@ -42,14 +42,14 @@ SQLRETURN WCharToUTF8(wchar_t *wst, int wstlen, char *st, int stlen, int *transl
 					len = wcslen((const wchar_t *)wst);
 				else // Invalid length, return SQL_ERROR
 				{
-					if (!error)
+					if (NULL != error)
 						strcpy(error,"WCharToUTF8: Invalid Length");
 					return SQL_ERROR;
 				}
 			}
 			if (stlen == 1) // no room for translation, just null terminator
 			{
-				if (!error)
+				if (NULL != error)
 					strcpy(error,"WCharToUTF8: Insufficient Buffer "); 
 				rc = SQL_SUCCESS_WITH_INFO;  
 			}
@@ -69,22 +69,22 @@ SQLRETURN WCharToUTF8(wchar_t *wst, int wstlen, char *st, int stlen, int *transl
 						}
 						strcpyUTF8(st, (const char*)temp, stlen);
 						*translen = strlen(st);
-						if (!error)
+						if (NULL != error)
 							strcpy(error,"WCharToUTF8: Insufficient Buffer "); 
 						delete[] temp;
 						return SQL_SUCCESS_WITH_INFO;
 					}
 					break;
 				case ERROR_INVALID_FLAGS:
-					if (!error)
+					if (NULL != error)
 						strcpy(error,"WCharToUTF8: Invalid Flags");
 					break;
 				case ERROR_INVALID_PARAMETER:
-					if (!error)
+					if (NULL != error)
 						strcpy(error,"WCharToUTF8: Invalid parameter");
 					break;
 				default:
-					if (!error)
+					if (NULL != error)
 						strcpy(error,"WCharToUTF8: Unknown Translation Error");
 					break;
 				}
@@ -112,7 +112,7 @@ SQLRETURN UTF8ToWChar(char *st, int stlen, wchar_t *wst, int wstlen, int *transl
 {
 	short len;
 	SQLRETURN rc = SQL_SUCCESS;
-	if (!error)
+	if (NULL != error)
 		error[0] ='\0';
 	if(translen != NULL)
 		*translen = 0;
@@ -127,14 +127,14 @@ SQLRETURN UTF8ToWChar(char *st, int stlen, wchar_t *wst, int wstlen, int *transl
 					len = strlen((const char *)st);
 				else
 				{
-					if (!error)
+					if (NULL != error)
 						strcpy(error, "UTF8ToWChar: Invalid String Length"); 
 					return SQL_ERROR;
 				}
 			}
 			if (wstlen == 1) // no room for translation, just null terminator
 			{
-				if (!error)
+				if (NULL != error)
 					strcpy(error,"UTF8ToWChar: Insufficient Buffer ");
 				rc = SQL_SUCCESS_WITH_INFO; 
 			}
@@ -155,26 +155,26 @@ SQLRETURN UTF8ToWChar(char *st, int stlen, wchar_t *wst, int wstlen, int *transl
 						wcsncpy(wst, (const wchar_t*)temp, wstlen-1);
 						wst[wstlen-1] = L'\0';
 						*translen = wcslen(wst);
-						if (!error)
+						if (NULL != error)
 							strcpy(error,"UTF8ToWChar: Insufficient Buffer ");
 						delete[] temp;
 						return SQL_SUCCESS_WITH_INFO;
 					}
 					break;
 					case ERROR_INVALID_FLAGS:
-						if (!error)
+						if (NULL != error)
 							strcpy(error,"UTF8ToWChar: Invalid Flags");
 						break;
 					case ERROR_INVALID_PARAMETER:
-						if (!error)	
+						if (NULL != error)	
 							strcpy(error,"UTF8ToWChar: Invalid parameter");
 						break;
 					case ERROR_NO_UNICODE_TRANSLATION:
-						if (!error)
+						if (NULL != error)
 							strcpy(error,"UTF8ToWChar: No Unicode Translation");
 						break;
 					default:
-						if (!error)
+						if (NULL != error)
 							strcpy(error,"UTF8ToWChar: Unknown Translation Error");
 						break;
 				}
@@ -208,7 +208,7 @@ SQLRETURN TranslateUTF8(bool forward, char *inst, int inlen, char *outst, int ou
 
 	if(translen != NULL)
 		*translen = 0;
-	if (!errorMsg)
+	if (NULL != errorMsg)
 		errorMsg[0] ='\0';
 	if (forward)
 	{
@@ -231,23 +231,23 @@ SQLRETURN TranslateUTF8(bool forward, char *inst, int inlen, char *outst, int ou
 				switch (GetLastError())
 				{
 					case ERROR_INSUFFICIENT_BUFFER:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Insufficient Buffer ");  
 						break;
 					case ERROR_INVALID_FLAGS:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Invalid Flags");
 						break;
 					case ERROR_INVALID_PARAMETER:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Invalid parameter");
 						break;
 					case ERROR_NO_UNICODE_TRANSLATION:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: No Unicode Translation");
 						break;
 					default:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Unknown Translation Error");
 						break;
 				}
@@ -260,7 +260,7 @@ SQLRETURN TranslateUTF8(bool forward, char *inst, int inlen, char *outst, int ou
 
 			if (outlen == 1) // no room for translation, just null terminator
 			{
-				if (!errorMsg)
+				if (NULL != errorMsg)
 					strcpy(errorMsg,"TranslateUTF8: Insufficient Buffer "); 
 				rc = SQL_SUCCESS_WITH_INFO; 
 			}
@@ -271,7 +271,7 @@ SQLRETURN TranslateUTF8(bool forward, char *inst, int inlen, char *outst, int ou
 					case ERROR_INSUFFICIENT_BUFFER:
 					{
 						outst[outlen-1] ='\0';
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Insufficient Buffer "); 
 						if (wst != NULL) 
 						{
@@ -282,15 +282,15 @@ SQLRETURN TranslateUTF8(bool forward, char *inst, int inlen, char *outst, int ou
 					}
 					break;
 					case ERROR_INVALID_FLAGS:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Invalid Flags");
 						break;
 					case ERROR_INVALID_PARAMETER:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Invalid parameter");
 						break;
 					default:
-						if (!errorMsg)
+						if (NULL != errorMsg)
 							strcpy(errorMsg,"TranslateUTF8: Unknown Translation Error");
 						break;
 				}
@@ -312,7 +312,7 @@ SQLRETURN TranslateUTF8(bool forward, char *inst, int inlen, char *outst, int ou
 	{
 		if(outst != NULL)
 			*outst = '\0';
-		if (!errorMsg)
+		if (NULL != errorMsg)
 			strcpy(errorMsg,"TranslateUTF8: Out string is NULL ");
 		return SQL_ERROR;
 	}
@@ -325,7 +325,7 @@ SQLRETURN WCharToLocale(wchar_t *wst, int wstlen, char *st, int stlen, int *tran
 {
 	int len;
 	SQLRETURN rc = SQL_SUCCESS;
-	if(!error)
+	if(NULL != error)
 		error[0] ='\0';
 	if(translen != NULL)
 		*translen = 0;
@@ -341,14 +341,14 @@ SQLRETURN WCharToLocale(wchar_t *wst, int wstlen, char *st, int stlen, int *tran
 					len = wcslen((const wchar_t *)wst);
 				else
 				{
-					if(!error)
+					if(NULL != error)
 						strcpy(error, "WCharToLocale: Invalid Length for in WChar string"); 
 					return SQL_ERROR;
 				}
 			}
 			if (stlen == 1) // no room for translation, just null terminator
 			{
-				if(!error)
+				if(NULL != error)
 					strcpy(error,"WCharToLocale: Insufficient Buffer "); 
 				rc = SQL_SUCCESS_WITH_INFO; 
 			}
@@ -361,7 +361,7 @@ SQLRETURN WCharToLocale(wchar_t *wst, int wstlen, char *st, int stlen, int *tran
 						char *temp = new char[len*4+1];
 						if ((*translen=(int)WideCharToMultiByte(CP_ACP, 0, (LPCWSTR)wst, len, temp, len*4, (LPCSTR)replacementChar, NULL)) == 0)
 						{
-							if(!error)
+							if(NULL != error)
 								strcpy(error,"WCharToLocale: Unknown Translation Error");
 							*translen = 0;
 							delete[] temp;
@@ -370,22 +370,22 @@ SQLRETURN WCharToLocale(wchar_t *wst, int wstlen, char *st, int stlen, int *tran
 						strncpy(st, (const char*)temp, stlen-1);
 						st[stlen-1] ='\0';
 						*translen = strlen(st);
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"WCharToLocale: Insufficient Buffer "); 
 						delete[] temp;
 						return SQL_SUCCESS_WITH_INFO;
 					}
 					break;
 					case ERROR_INVALID_FLAGS:
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"WCharToLocale: Invalid Flags");
 						break;
 					case ERROR_INVALID_PARAMETER:
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"WCharToLocale: Invalid parameter");
 						break;
 					default:
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"WCharToLocale: Unknown Translation Error");
 						break;
 				}
@@ -410,7 +410,7 @@ SQLRETURN WCharToLocale(wchar_t *wst, int wstlen, char *st, int stlen, int *tran
 SQLRETURN LocaleToWChar(char *st, int stlen, wchar_t *wst, int wstlen, int *translen, char* error)
 {
 	int len;
-	if(!error)
+	if(NULL != error)
 		error[0] = '\0';
 	SQLRETURN rc = SQL_SUCCESS;
 	if(translen != NULL)
@@ -426,14 +426,14 @@ SQLRETURN LocaleToWChar(char *st, int stlen, wchar_t *wst, int wstlen, int *tran
 					len = strlen((const char *)st);
 				else
 				{
-					if(!error)
+					if(NULL != error)
 						strcpy(error, "LocaleToWChar: Invalid Length for in Locale string"); 
 					return SQL_ERROR;
 				}
 			}
 			if (wstlen == 1) // no room for translation, just null-terminator
 			{
-				if(!error)
+				if(NULL != error)
 					strcpy(error,"LocaleToWChar: Insufficient Buffer ");
 				rc = SQL_SUCCESS_WITH_INFO; 
 			}
@@ -454,22 +454,22 @@ SQLRETURN LocaleToWChar(char *st, int stlen, wchar_t *wst, int wstlen, int *tran
 						wcsncpy(wst, (const wchar_t*)temp, wstlen-1);
 						wst[wstlen-1] =L'\0';
 						*translen = wcslen(wst);
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"LocaleToWChar: Insufficient Buffer "); 
 						delete[]  temp;
 						return SQL_SUCCESS_WITH_INFO;
 					}
 					break;
 					case ERROR_INVALID_FLAGS:
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"LocaleToWChar: Invalid Flags");
 						break;
 					case ERROR_INVALID_PARAMETER:
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"LocaleToWChar: Invalid parameter");
 						break;
 					default:
-						if(!error)
+						if(NULL != error)
 							strcpy(error,"LocaleToWChar: Unknown Translation Error");
 						break;
 				}


[2/9] trafodion git commit: fix the nullpointer error scaned by TScanCode

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/sqf/sql/scripts/DUMPENVS
----------------------------------------------------------------------
diff --git a/core/sqf/sql/scripts/DUMPENVS b/core/sqf/sql/scripts/DUMPENVS
new file mode 100644
index 0000000..deb3c65
--- /dev/null
+++ b/core/sqf/sql/scripts/DUMPENVS
@@ -0,0 +1,884 @@
+ProcessEnv::dumpEnvs() 
+environ[0] ---- SQ_LIO_MAX_BUFFERS ---> 1000
+environ[1] ---- MPI_ROOT ---> /home/wangxz/code/trafodion/core/sqf/opt/hpmpi
+environ[2] ---- MPI_TMPDIR ---> /home/wangxz/code/trafodion/core/sqf/tmp
+environ[3] ---- MPI_FLAGS ---> y0
+environ[4] ---- MPI_IC_ORDER ---> TCP
+environ[5] ---- MPI_TEST_DELAY ---> 2
+environ[6] ---- MPI_ERROR_LEVEL ---> 2
+environ[7] ---- MPI_RDMA_MSGSIZE ---> 32768,131072,4194304
+environ[8] ---- HPMP_SQ ---> 1
+environ[9] ---- MALLOC_ARENA_MAX ---> 1
+environ[10] ---- HPMP_SINGLETON_HA ---> 1
+environ[11] ---- TRAF_CONF ---> /home/wangxz/code/trafodion/core/sqf/conf
+environ[12] ---- TRAF_HOME ---> /home/wangxz/code/trafodion/core/sqf
+environ[13] ---- TRAF_VAR ---> /home/wangxz/code/trafodion/core/sqf/tmp
+environ[14] ---- USER ---> wangxz
+environ[15] ---- HOME ---> /home/wangxz
+environ[16] ---- TERM ---> dumb
+environ[17] ---- CLASSPATH ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/antisamy-1.4.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-core-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-kms-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-s
 3-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-css-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-ext-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-util-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/bsh-core-2.0b4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-core-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-codec-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-configuration-1.6.jar:/home/wangxz/cod
 e/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-daemon-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-fileupload-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-logging-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hba
 se/lib/core-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/disruptor-3.3.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/esapi-2.1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/guava-12.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-aws-2.6.0-cdh5.
 7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-api-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core
 /sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-server-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-client-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-examples-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-external-blockcache-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop2-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodio
 n/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-it-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-prefix-tree-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-procedure-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-resource-bundle-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-rest-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-server-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-shell-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-spark-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/loca
 l_hadoop/hbase/lib/hbase-thrift-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hsqldb-1.8.0.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-annotations-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-databind-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_
 hadoop/hbase/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jamon-runtime-2.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-impl-2.2.3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jcodings-1.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-client-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-core-1.9.jar:/
 home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jettison-1.3.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-sslengine-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/joni-2.1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jruby-cloudera-1.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/l
 ocal_hadoop/hbase/lib/jsp-api-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsr305-1.3.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/junit-4.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/leveldbjni-all-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/libthrift-0.9.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/metrics-core-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/nekohtml-1.9.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/netty-all-4.0.23.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafodion/
 core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/spymemcached-2.11.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xalan-2.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xercesImpl-2.9.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-1.3.03.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-ext-1.3.04.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xom-1.2.5.jar:/home/w
 angxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hado
 op/hadoop/share/hadoop/common/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/had
 oop/share/hadoop/common/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/li
 b/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/guava-11.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/li
 b/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-api-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-impl-2.2.
 3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-core-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jettison-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sq
 f/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/mockito-all-1.8.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/netty-3.6.2.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/slf4j
 -api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/stax-api-1.0-2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/
 hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-plugins-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-nativetask-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-examples-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core
 /sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-core-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-fate-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-start-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-trace-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-2.7.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-runtime-3.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/apache-log4j-extras-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-commons-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-
 tree-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/bonecp-0.8.0.RELEASE.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-avatica-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-core-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-linq4j-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/co
 mmons-compiler-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-dbcp-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-httpclient-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-pool-1.5.4.jar:/home/wangxz/code/
 trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-vfs2-2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-client-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-framework-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-recipes-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-api-jdo-3.2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-core-3.2.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-rdbms-3.2.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/derby-10.11.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/eigenbase-properties-1.1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-annotation_1.0_spec-1.1.1.jar:/home/wangxz/
 code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jaspic_1.0_spec-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jta_1.1_spec-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/groovy-all-2.4.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/guava-14.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hamcrest-core-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-accumulo-handler-1.1.0-cdh5.7.1.jar:/home/wa
 ngxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-ant-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-beeline-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-cli-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-contrib-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-exec-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hbase-handler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hwi-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1-standalone.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/l
 ib/hive-metastore-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-serde-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-service-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-0.23-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-scheduler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-testutils-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpcore-4.2.5.jar:/home/wangxz/code/t
 rafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-annotations-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-core-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-databind-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-jaxrs-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-xc-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jamon-runtime-2.3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/janino-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jcommander-1.32.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jdo-api-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jer
 sey-server-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jersey-servlet-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-server-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jline-2.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/joda-time-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jpam-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jta-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/libfb303-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/libth
 rift-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/log4j-1.2.16.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mail-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-api-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svn-commons-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svnexe-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-core-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-json-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-jvm-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mysql-connector-java-5.1.23-bin.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/opencsv-2.3.jar:/home/wangxz/code/tr
 afodion/core/sqf/sql/local_hadoop/hive/lib/oro-2.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/parquet-hadoop-bundle-1.5.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/pentaho-aggdesigner-algorithm-5.1.5-jhyde.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/plexus-utils-1.5.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/regexp-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/ST4-4.0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stax-api-1.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stringtemplate-3.2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/su
 per-csv-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/tempus-fugit-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/velocity-1.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/etc/hadoop:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/conf:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/conf::/home/wangxz/code/trafodion/core/sqf/export/lib/hbase-trx-cdh5_7-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-dtm-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-sql-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-utility-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT4-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT2.jar:/conf:
+environ[18] ---- XAUTHORITY ---> /home/wangxz/.Xauthority
+environ[19] ---- SQ_IC ---> TCP
+environ[20] ---- SQ_VIRTUAL_NODES ---> 2
+environ[21] ---- SQ_VIRTUAL_NID ---> 0
+environ[22] ---- SQ_LIO_VIRTUAL_NID ---> 0
+environ[23] ---- LD_LIBRARY_PATH ---> /lib64:/usr/lib64:/home/wangxz/code/trafodion/core/sqf/opt/hpmpi/lib/linux_amd64:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/lib/native:/home/wangxz/code/trafodion/core/sqf/export/lib64d:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server:/usr/lib64:.
+environ[24] ---- LD_BIND_NOW ---> true
+environ[25] ---- PWD ---> /home/wangxz/code/trafodion/core/sqf
+environ[26] ---- PATH ---> /home/wangxz/code/trafodion/core/sqf/opt/hpmpi/bin:/home/wangxz/code/trafodion/core/sqf/export/bin64d:/home/wangxz/code/trafodion/core/sqf/sql/scripts:/home/wangxz/code/trafodion/core/sqf/tools:/home/wangxz/code/trafodion/core/sqf/trafci/bin:/home/wangxz/installed_software_tools/apache-maven-3.3.3/bin:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/bin:/usr/lib64/qt-3.3/bin:/usr/local/bin:/bin:/usr/bin:/usr/local/sbin:/usr/sbin:/sbin:/home/wangxz/bin
+environ[27] ---- CLUSTERNAME ---> 
+environ[28] ---- SQ_MBTYPE ---> 64d
+environ[29] ---- MY_NODES ---> 
+environ[30] ---- JAVA_HOME ---> /usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64
+environ[31] ---- MY_CLUSTER_ID ---> 
+environ[32] ---- TRAF_FOUNDATION_READY ---> 1
+environ[33] ---- DTM_RUN_MODE ---> 2
+environ[34] ---- SQ_AUDITSVC_READY ---> 1
+environ[35] ---- DTM_TLOG_PER_TM ---> 0
+environ[36] ---- TRAF_TM_LOCKED ---> 0
+environ[37] ---- DTM_RECOVERING_TX_COUNT ---> 0
+environ[38] ---- SQ_TXNSVC_READY ---> 1
+environ[39] ---- FS_TRACE_PARAMS ---> 1
+environ[40] ---- SEAQUEST_DP2 ---> 1
+environ[41] ---- MS_TRACE_MON ---> 1
+environ[42] ---- FS_ASSERT_ERROR ---> 1
+environ[43] ---- MY_UDR_ROOT ---> /home/wangxz/code/trafodion/core/sqf/udr
+environ[44] ---- TAR_DOWNLOAD_ROOT ---> /home/wangxz/sqllogs
+environ[45] ---- YYERROR_QUIET ---> 1
+environ[46] ---- FS_TRACE_FILE ---> fstrace
+environ[47] ---- LIBHDFS_OPTS ---> -Xmx2048m
+environ[48] ---- STFS_HDD_LOCATION ---> /home/wangxz/code/trafodion/core/sqf/tmp
+environ[49] ---- SEAQUEST_NO_ROLLBACK_TXN ---> 0
+environ[50] ---- TM_ENABLE_DDL_TRANS ---> 1
+environ[51] ---- IPC_LAUNCH_UNHOOKED ---> 1
+environ[52] ---- SQL_MEASURE_ENABLE ---> 0
+environ[53] ---- TM_USE_SSCC ---> 0
+environ[54] ---- SQ_PROPS_TDM_ARKCMP ---> tdm_arkcmp.env
+environ[55] ---- TM_ENABLE_TLOG_WRITES ---> 1
+environ[56] ---- MS_TRACE_ENABLE ---> 0
+environ[57] ---- REST_INSTALL_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/rest-2.3.0
+environ[58] ---- TSE_CONVERT_NOUNDO_TRANS ---> 1
+environ[59] ---- MS_DISC_SEM_ROBUST ---> 1
+environ[60] ---- AM_TRACE_FILE ---> am_trace
+environ[61] ---- TM_TLOG_DISABLE_BLOCK_CACHE ---> 0
+environ[62] ---- FS_TRACE_MON ---> 1
+environ[63] ---- MS_TRACE_FILE_UNIQUE ---> 1
+environ[64] ---- HOOK_ENABLE ---> 0
+environ[65] ---- AM_TRACE_FILE_UNIQUE ---> 1
+environ[66] ---- FS_TRACE_ENABLE ---> 0
+environ[67] ---- AM_TRACE ---> 0
+environ[68] ---- MS_TRACE_FILE ---> mstrace
+environ[69] ---- ABANDON_TX_AFTER_3_RETRIES ---> 0
+environ[70] ---- CMP_NODE_AFFINITY ---> 1
+environ[71] ---- TM_TLOG_NUM_LOGS ---> 16
+environ[72] ---- CACERTS_DIR ---> /home/wangxz/cacerts
+environ[73] ---- SQ_TRANS_SOCK ---> 0
+environ[74] ---- SQLMX_MESSAGEFILE ---> /home/wangxz/code/trafodion/core/sqf/export/bin64d/mxcierrors.cat
+environ[75] ---- MS_TRACE_PARAMS ---> 1
+environ[76] ---- MS_STREAMS_MAX ---> 20000
+environ[77] ---- FS_TRACE_FILE_UNIQUE ---> 1
+environ[78] ---- TM_TLOG_AUTO_FLUSH ---> 0
+environ[79] ---- TM_IDTMSRV_REFRESH_DELAY_SECONDS ---> 3
+environ[80] ---- DCS_INSTALL_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0
+environ[81] ---- SQ_PROPS_TDM_ARKESP ---> tdm_arkesp.env
+environ[82] ---- MS_STREAMS_MIN ---> 20000
+environ[83] ---- TM_TLOG_MAX_VERSIONS ---> 5
+environ[84] ---- AM_TRACE_LEVEL ---> 1
+environ[85] ---- DTM_RM_PARTIC ---> 0
+environ[86] ---- SEAQUEST ---> 1
+environ[87] ---- TRAFODION_LOG_FILENAME_SUFFIX ---> _0.log
+environ[88] ---- NLSPATH ---> /usr/dt/lib/nls/msg/%L/%N.cat
+environ[89] ---- XFILESEARCHPATH ---> /usr/dt/app-defaults/%L/Dt
+environ[90] ---- HIVE_CNF_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/conf
+environ[91] ---- THRIFT_LIB_DIR ---> /home/wangxz/installed_software_tools/thrift-0.9.0/lib
+environ[92] ---- AR ---> ar
+environ[93] ---- MANPATH ---> :/home/wangxz/code/trafodion/core/sqf/export/share/man
+environ[94] ---- SQ_USE_INTC ---> 0
+environ[95] ---- MPI_CXX ---> /usr/bin/g++
+environ[96] ---- DCS_MASTER_PORT ---> 23400
+environ[97] ---- HOSTNAME ---> esgsh-dev-n001.novalocal
+environ[98] ---- HIVE_JAR_FILES ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/share/hadoop/mapreduce/hadoop-mapreduce-client-core-*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/*.jar
+environ[99] ---- MY_ZOOKEEPER_DATA_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/data/zookeeper
+environ[100] ---- SELINUX_ROLE_REQUESTED ---> 
+environ[101] ---- HBVER ---> apache1_2
+environ[102] ---- SHELL ---> /bin/bash
+environ[103] ---- SQPDSHA ---> eval
+environ[104] ---- HISTSIZE ---> 1000
+environ[105] ---- MAKEFLAGS ---> -j4
+environ[106] ---- LSP_POLL_FREQ ---> 60
+environ[107] ---- SSH_CLIENT ---> 10.10.9.22 56598 22
+environ[108] ---- SQ_COVERAGE ---> 0
+environ[109] ---- HADOOP_PID_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/tmp
+environ[110] ---- CMP_POLL_FREQ ---> 10
+environ[111] ---- ENABLE_EMBEDDED_ARKCMP ---> 1
+environ[112] ---- MY_MPI_ROOT ---> /home/wangxz/code/trafodion/core/sqf
+environ[113] ---- LD_PRELOAD ---> /usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/libjsig.so:/home/wangxz/code/trafodion/core/sqf/export/lib64d/libseabasesig.so
+environ[114] ---- SELINUX_USE_CURRENT_RANGE ---> 
+environ[115] ---- SQ_MON_EPOLL_RETRY_COUNT ---> 4
+environ[116] ---- QTDIR ---> /usr/lib64/qt-3.3
+environ[117] ---- OLDPWD ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0
+environ[118] ---- DCS_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/..
+environ[119] ---- QTINC ---> /usr/lib64/qt-3.3/include
+environ[120] ---- HBASE_CNF_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/conf
+environ[121] ---- MY_HBASE_ZOOKEEPER_PROPERTY_CLIENTPORT_NUM ---> 2181
+environ[122] ---- UDIS86 ---> /home/wangxz/installed_software_tools/udis86-1.7.2
+environ[123] ---- DCS_LOG_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/../logs
+environ[124] ---- SSH_TTY ---> /dev/pts/0
+environ[125] ---- TOOLSDIR ---> /home/wangxz/installed_software_tools
+environ[126] ---- DCS_CLASSPATH ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/antisamy-1.4.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-core-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-kms-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-
 sdk-s3-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-css-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-ext-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-util-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/bsh-core-2.0b4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-core-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-codec-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-configuration-1.6.jar:/home/wangx
 z/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-daemon-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-fileupload-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-logging-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoo
 p/hbase/lib/core-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/disruptor-3.3.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/esapi-2.1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/guava-12.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-aws-2.6.0-
 cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-api-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion
 /core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-server-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-client-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-examples-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-external-blockcache-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop2-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/tra
 fodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-it-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-prefix-tree-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-procedure-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-resource-bundle-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-rest-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-server-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-shell-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-spark-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql
 /local_hadoop/hbase/lib/hbase-thrift-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hsqldb-1.8.0.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-annotations-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-databind-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/l
 ocal_hadoop/hbase/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jamon-runtime-2.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-impl-2.2.3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jcodings-1.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-client-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-core-1.9.
 jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jettison-1.3.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-sslengine-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/joni-2.1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jruby-cloudera-1.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/
 sql/local_hadoop/hbase/lib/jsp-api-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsr305-1.3.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/junit-4.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/leveldbjni-all-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/libthrift-0.9.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/metrics-core-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/nekohtml-1.9.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/netty-all-4.0.23.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafo
 dion/core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/spymemcached-2.11.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xalan-2.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xercesImpl-2.9.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-1.3.03.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-ext-1.3.04.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xom-1.2.5.jar:/h
 ome/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local
 _hadoop/hadoop/share/hadoop/common/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoo
 p/hadoop/share/hadoop/common/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/comm
 on/lib/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/guava-11.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/comm
 on/lib/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-api-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-impl
 -2.2.3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-core-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jettison-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/co
 re/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/mockito-all-1.8.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/netty-3.6.2.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/
 slf4j-api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/stax-api-1.0-2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapre
 duce/hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-plugins-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-nativetask-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-examples-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion
 /core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-core-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-fate-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-start-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-trace-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-2.7.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-runtime-3.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/apache-log4j-extras-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-commons-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib
 /asm-tree-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/bonecp-0.8.0.RELEASE.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-avatica-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-core-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-linq4j-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/l
 ib/commons-compiler-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-dbcp-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-httpclient-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-pool-1.5.4.jar:/home/wangxz/
 code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-vfs2-2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-client-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-framework-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-recipes-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-api-jdo-3.2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-core-3.2.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-rdbms-3.2.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/derby-10.11.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/eigenbase-properties-1.1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-annotation_1.0_spec-1.1.1.jar:/home/wa
 ngxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jaspic_1.0_spec-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jta_1.1_spec-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/groovy-all-2.4.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/guava-14.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hamcrest-core-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-accumulo-handler-1.1.0-cdh5.7.1.jar:/ho
 me/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-ant-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-beeline-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-cli-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-contrib-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-exec-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hbase-handler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hwi-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1-standalone.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/h
 ive/lib/hive-metastore-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-serde-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-service-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-0.23-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-scheduler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-testutils-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpcore-4.2.5.jar:/home/wangxz/c
 ode/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-annotations-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-core-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-databind-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-jaxrs-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-xc-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jamon-runtime-2.3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/janino-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jcommander-1.32.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jdo-api-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/li
 b/jersey-server-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jersey-servlet-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-server-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jline-2.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/joda-time-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jpam-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jta-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/libfb303-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/
 libthrift-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/log4j-1.2.16.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mail-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-api-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svn-commons-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svnexe-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-core-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-json-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-jvm-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mysql-connector-java-5.1.23-bin.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/opencsv-2.3.jar:/home/wangxz/co
 de/trafodion/core/sqf/sql/local_hadoop/hive/lib/oro-2.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/parquet-hadoop-bundle-1.5.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/pentaho-aggdesigner-algorithm-5.1.5-jhyde.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/plexus-utils-1.5.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/regexp-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/ST4-4.0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stax-api-1.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stringtemplate-3.2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/l
 ib/super-csv-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/tempus-fugit-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/velocity-1.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/etc/hadoop:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/conf:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/conf::/home/wangxz/code/trafodion/core/sqf/export/lib/hbase-trx-cdh5_7-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-dtm-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-sql-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-utility-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT4-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT2.jar:/conf:
+environ[127] ---- SQ_START_QVP ---> 1
+environ[128] ---- LC_ALL ---> en_US.UTF-8
+environ[129] ---- SQ_BTYPE ---> d
+environ[130] ---- PROTOBUFS_LIB ---> /usr/lib
+environ[131] ---- YARN_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop
+environ[132] ---- EMACS ---> t
+environ[133] ---- LS_COLORS ---> 
+environ[134] ---- JAVA_LIBRARY_PATH ---> /lib64:/usr/lib64:/home/wangxz/code/trafodion/core/sqf/opt/hpmpi/lib/linux_amd64::/home/wangxz/code/trafodion/core/sqf/export/lib64d:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server:/usr/lib64:.
+environ[135] ---- HBASE_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase
+environ[136] ---- DCS_MANAGES_ZK ---> false
+environ[137] ---- SQ_LUNMGR_VERBOSITY ---> 1
+environ[138] ---- PDSH ---> /usr/bin/pdsh -R exec
+environ[139] ---- FLEX ---> flex
+environ[140] ---- JDBCT4_JAR ---> jdbcT4-2.3.0.jar
+environ[141] ---- TERMCAP ---> 
+environ[142] ---- MY_HADOOP_HDFS_PORT_NUM ---> 9000
+environ[143] ---- SQ_SRVMON ---> 1
+environ[144] ---- SQ_MON_EPOLL_WAIT_TIMEOUT ---> 16
+environ[145] ---- HADOOP_JAR_DIRS ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common
+                          /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib
+                          /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce
+                          /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs
+environ[146] ---- SMP_POLL_FREQ ---> 60
+environ[147] ---- COLUMNS ---> 122
+environ[148] ---- DTM_COMMON_JAR ---> trafodion-dtm-cdh-2.3.0.jar
+environ[149] ---- TRAFODION_VER_UPDATE ---> 0
+environ[150] ---- MY_REST_SERVER_PORT ---> 4200
+environ[151] ---- SUFFIXES_TO_SUPPRESS ---> -sources.jar -tests.jar
+environ[152] ---- MAIL ---> /var/spool/mail/wangxz
+environ[153] ---- PDCP ---> /usr/bin/pdcp -R ssh
+environ[154] ---- HBASE_DEP_VER_CDH ---> 1.2.0-cdh5.7.1
+environ[155] ---- SQ_PDSH ---> /usr/bin/pdsh
+environ[156] ---- SQ_STARTUP ---> r
+environ[157] ---- TRAFODION_VER ---> 2.3.0
+environ[158] ---- MY_DRILL_INFO_PORT_NUM ---> 8047
+environ[159] ---- STY ---> 22432.pts-0.esgsh-dev-n001
+environ[160] ---- SQ_MON_SYNC_TIMEOUT ---> 900
+environ[161] ---- HADOOP_DEP_VER ---> 2.6.0
+environ[162] ---- DCS_ROOT_LOGGER ---> INFO,DRFA
+environ[163] ---- HIVE_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive
+environ[164] ---- SQ_MTYPE ---> 64
+environ[165] ---- SQ_IDTMSRV ---> 1
+environ[166] ---- HADOOP_CNF_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/etc/hadoop
+environ[167] ---- HBASE_TRXDIR ---> /home/wangxz/code/trafodion/core/sqf/export/lib
+environ[168] ---- MY_SW_ROOT ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop
+environ[169] ---- SQ_START_RMS ---> 1
+environ[170] ---- HIVE_DEP_VER_APACHE ---> 1.1.0
+environ[171] ---- MPICH_CXX ---> /usr/bin/g++
+environ[172] ---- LOG4CXX_INC_DIR ---> /usr/include/log4cxx
+environ[173] ---- LANG ---> en_US.UTF-8
+environ[174] ---- RH_MAJ_VERS ---> 6
+environ[175] ---- HADOOP_BLD_LIB ---> /home/wangxz/installed_software_tools/hadoop-2.6.0/lib/native
+environ[176] ---- MY_HBASE_ZOOKEEPER_LEADERPORT_NUM ---> 3888
+environ[177] ---- TRAFODION_ENABLE_AUTHENTICATION ---> NO
+environ[178] ---- MY_DB_MGR_PORT ---> 4205
+environ[179] ---- SQ_DTM_PERSISTENT_PROCESS ---> 1
+environ[180] ---- MY_SW_SCRIPTS_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/scripts
+environ[181] ---- HBASE_HEAPSIZE ---> 2048
+environ[182] ---- LLVM ---> /home/wangxz/installed_software_tools/dest-llvm-3.2
+environ[183] ---- SELINUX_LEVEL_REQUESTED ---> 
+environ[184] ---- DCS_MASTER_FLOATING_IP ---> 
+environ[185] ---- UTIL_JAR ---> trafodion-utility-2.3.0.jar
+environ[186] ---- DCS_SECURITY_LOGGER ---> INFO,DRFAS
+environ[187] ---- MY_DCS_SERVER_INFO_PORT ---> 24410
+environ[188] ---- SQ_MON_KEEPCNT ---> 5
+environ[189] ---- HBASE_TRX_JAR ---> hbase-trx-cdh5_7-2.3.0.jar
+environ[190] ---- HISTCONTROL ---> ignoredups
+environ[191] ---- CXX ---> g++
+environ[192] ---- DCS_LOGFILE ---> dcs-wangxz-1-server-esgsh-dev-n001.novalocal.log
+environ[193] ---- MY_DCS_MASTER_PORT ---> 23400
+environ[194] ---- ICU ---> /home/wangxz/installed_software_tools/icu4c_4.4
+environ[195] ---- SHLVL ---> 9
+environ[196] ---- CURL_LIB_DIR ---> /usr/lib64
+environ[197] ---- SQ_MON_KEEPINTVL ---> 6
+environ[198] ---- LANGUAGE ---> zh_CN:zh
+environ[199] ---- SQ_MON_KEEPIDLE ---> 60
+environ[200] ---- SSP_POLL_FREQ ---> 60
+environ[201] ---- TRAFODION_VER_MINOR ---> 3
+environ[202] ---- SQ_MON_KEEPALIVE ---> 1
+environ[203] ---- MPICH_ROOT ---> /home/wangxz/installed_software_tools/dest-mpich-3.0.4
+environ[204] ---- SQ_PHANDLE_VERIFIER ---> 1
+environ[205] ---- BISON ---> /home/wangxz/installed_software_tools/bison_3_linux/bin/bison
+environ[206] ---- HADOOP_JAR_FILES --->  /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/*.jar
+environ[207] ---- LOG4CXX_LIB_DIR ---> /usr/lib64
+environ[208] ---- HADOOP_INC_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/include
+environ[209] ---- TRAFODION_VER_PROD ---> Apache Trafodion
+environ[210] ---- ANT ---> ant
+environ[211] ---- HIVE_DEP_VER_HDP ---> 1.2.1
+environ[212] ---- LOGNAME ---> wangxz
+environ[213] ---- DCS_IDENT_STRING ---> wangxz-1
+environ[214] ---- HIVE_JAR_DIRS ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib
+environ[215] ---- HADOOP_LIB_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/lib/native
+environ[216] ---- WINDOW ---> 2
+environ[217] ---- PROTOBUFS ---> /usr
+environ[218] ---- DCS_LOG_PREFIX ---> dcs-wangxz-1-server-esgsh-dev-n001.novalocal
+environ[219] ---- QTLIB ---> /usr/lib64/qt-3.3/lib
+environ[220] ---- SQ_PIDMAP ---> 1
+environ[221] ---- TRAFODION_VER_MAJOR ---> 2
+environ[222] ---- THRIFT_INC_DIR ---> /home/wangxz/installed_software_tools/thrift-0.9.0/include
+environ[223] ---- CVS_RSH ---> ssh
+environ[224] ---- HBASE_TRX_ID_HDP ---> hbase-trx-hdp2_3
+environ[225] ---- MAVEN ---> mvn
+environ[226] ---- SSH_CONNECTION ---> 10.10.9.22 56598 192.168.0.71 22
+environ[227] ---- THRIFT_DEP_VER ---> 0.9.0
+environ[228] ---- HBASE_TRX_ID_APACHE ---> hbase-trx-apache1_2
+environ[229] ---- HBASE_TRX_ID_CDH ---> hbase-trx-cdh5_7
+environ[230] ---- MY_DB_MGR_SECURE_PORT ---> 4206
+environ[231] ---- MY_HBASE_ZOOKEEPER_PEERPORT_NUM ---> 2888
+environ[232] ---- LOC_JVMLIBS ---> /usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server
+environ[233] ---- SQ_PDCP ---> /usr/bin/pdcp
+environ[234] ---- LESSOPEN ---> ||/usr/bin/lesspipe.sh %s
+environ[235] ---- MY_DRILL_RPC_PORT_NUM ---> 31010
+environ[236] ---- PDSH_SSH_CMD ---> ssh -q -n %h
+environ[237] ---- SQ_MON_ALTLOG ---> 0
+environ[238] ---- SQ_START_QMM ---> 0
+environ[239] ---- CURL_INC_DIR ---> /usr/include
+environ[240] ---- HIVE_DEP_VER_CDH ---> 1.1.0-cdh5.7.1
+environ[241] ---- SQ_NEW_PHANDLE ---> 1
+environ[242] ---- HBASE_DEP_VER_APACHE ---> 1.2.0
+environ[243] ---- MYSQL_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/mysql
+environ[244] ---- SQ_EVLOG_NONE ---> 1
+environ[245] ---- PROTOBUFS_INC ---> /usr/include
+environ[246] ---- MY_DCS_MASTER_INFO_PORT ---> 24400
+environ[247] ---- SQ_WDT_CHECK_CLUSTER_STATE ---> 0
+environ[248] ---- LMP_POLL_FREQ ---> 60
+environ[249] ---- SQL_JAR ---> trafodion-sql-cdh-2.3.0.jar
+environ[250] ---- MY_DRILL_BIT_PORT_NUM ---> 31011
+environ[251] ---- INSIDE_EMACS ---> 23.1.1,comint
+environ[252] ---- PRODUCT_COPYRIGHT_HEADER ---> 2015-2017 Apache Software Foundation
+environ[253] ---- HBASE_JAR_FILES --->  /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/*.jar
+environ[254] ---- DCS_USER_PROGRAM_HOME ---> /home/wangxz/code/trafodion/core/sqf
+environ[255] ---- MY_REST_SERVER_SECURE_PORT ---> 4201
+environ[256] ---- HADOOP_BLD_INC ---> /home/wangxz/installed_software_tools/hadoop-2.6.0/include
+environ[257] ---- HBASE_PID_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/tmp
+environ[258] ---- G_BROKEN_FILENAMES ---> 1
+environ[259] ---- HBASE_DEP_VER_HDP ---> 1.1.2
+environ[260] ---- ZOOKEEPER_DIR ---> /home/wangxz/installed_software_tools/zookeeper-3.4.5
+environ[261] ---- HIVE_DEP_VER ---> 0.13.1
+environ[262] ---- MY_SW_HOME ---> /home/wangxz
+environ[263] ---- DCS_NICENESS ---> 0
+environ[264] ---- CSP_POLL_FREQ ---> 60
+environ[265] ---- DCS_OPTS ---> -XX:+UseConcMarkSweepGC   -Ddcs.log.dir=/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/../logs -Ddcs.log.file=dcs-wangxz-1-server-esgsh-dev-n001.novalocal.log -Ddcs.home.dir=/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/.. -Ddcs.id.str=wangxz-1 -Ddcs.root.logger=INFO,DRFA -Djava.library.path=/lib64:/usr/lib64:/home/wangxz/code/trafodion/core/sqf/opt/hpmpi/lib/linux_amd64::/home/wangxz/code/trafodion/core/sqf/export/lib64d:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server:/usr/lib64:. -Ddcs.user.program.home=/home/wangxz/code/trafodion/core/sqf -Ddcs.conf.dir=/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/../conf -Ddcs.trafodion.home=/home/wangxz/code/trafodion/core/sqf
+environ[266] ---- BASH_FUNC_ncmp() ---> () {  nprocpn_us tdm_arkcmp | pdsh_counter
+}
+environ[267] ---- BASH_FUNC_sqsave_linux_info() ---> () {  lv_node=`uname -n`;
+ dmesg > ${1}/dmesg.${lv_node}.log;
+ df > ${1}/df.${lv_node}.log;
+ ps -ef > ${1}/ps_ef.${lv_node}.log;
+ last reboot > ${1}/last_reboot.${lv_node}.log
+}
+environ[268] ---- BASH_FUNC_collect_cmapt() ---> () {  lv_file_name='cmapt.out';
+ LogHeader "Output of the cmapt function:";
+ cmapt 16 >> $lv_file_name
+}
+environ[269] ---- BASH_FUNC_cmapls() ---> () {  if [ $# == 0 ]; then
+ echo "Enter a string to lookup in all the monitor.map.[0-9]*.* files";
+ return 1;
+ fi;
+ l_lookup=$*;
+ setup_sqpdsh;
+ eval '$SQPDSHA "ngrepmms $l_lookup" 2>/dev/null'
+}
+environ[270] ---- BASH_FUNC_tneprog() ---> () {  if [ $# != 0 ]; then
+ lv_prog=$1;
+ else
+ lv_prog=arkesp;
+ fi;
+ cmapc END $lv_prog | pdsh_counter
+}
+environ[271] ---- BASH_FUNC_nprocpn() ---> () {  setup_sqpdsh;
+ eval '$SQPDSHA "pstat | grep $1 | wc -l" | sort -nk2'
+}
+environ[272] ---- BASH_FUNC_sqsecheck() ---> () {  sediskstatus | grep DOWN
+}
+environ[273] ---- BASH_FUNC_nprocpn_us() ---> () {  setup_sqpdsh;
+ eval '$SQPDSHA "pstat | grep $1 | wc -l"'
+}
+environ[274] ---- BASH_FUNC_tnbprog() ---> () {  if [ $# != 0 ]; then
+ lv_prog=$1;
+ else
+ lv_prog=arkesp;
+ fi;
+ cmapc BEGIN $lv_prog | pdsh_counter
+}
+environ[275] ---- BASH_FUNC_sqmd5l() ---> () {  setup_sqpdsh;
+ eval '$SQPDSHA "cd $TRAF_HOME/export/lib${SQ_MBTYPE}; md5sum $1 2>/dev/null" 2>/dev/null | cut -f2 -d: | sort -u'
+}
+environ[276] ---- BASH_FUNC_chkReturnCodeExit() ---> () {  if [[ $1 != 0 ]]; then
+ echo "$2 returned error $1, exitting...";
+ exit $1;
+ else
+ echo "$2 executed successfully.";
+ fi
+}
+environ[277] ---- BASH_FUNC_cmaplsbec() ---> () {  l_lookup=$*;
+ lv_all=`cmaplsc $*`;
+ lv_begin=`cmaplsbc $*`;
+ lv_end=`cmaplsec $*`;
+ echo "$l_lookup,$lv_all,$lv_begin,$lv_end"
+}
+environ[278] ---- BASH_FUNC_ckillall() ---> () {  export SQ_PS1=$PS1;
+ $TRAF_HOME/sql/scripts/ckillall;
+ unset SQ_PS1
+}
+environ[279] ---- BASH_FUNC_sqchksl() ---> () {  setup_sqpdsh;
+ eval '$SQPDSHA "cd $TRAF_HOME/sql/scripts; grep Executing startup.log 2>/dev/null" 2>/dev/null | sort -k4 -k5'
+}
+environ[280] ---- BASH_FUNC_ndbm() ---> () {  setup_sqpdsh;
+ eval '$SQPDSHA "df -h | grep database" 2>/dev/null | wc -l'
+}
+environ[281] ---- BASH_FUNC_cmaplc() ---> () {  cmapl $* | wc -l
+}
+environ[282] ---- BASH_FUNC_cmaplec() ---> () {  cmapl $* | grep END | wc -l
+}
+environ[283] ---- BASH_FUNC_collect_cstat() ---> () {  lv_file_name='cstat.out';
+ LogHeader "CSTAT";
+ cstat | sort -k13 >> $lv_file_name
+}
+environ[284] ---- BASH_FUNC_nesp() ---> () {  nprocpn_us tdm_arkesp | pdsh_counter
+}
+environ[285] ---- BASH_FUNC_ngrepmms() ---> () {  l_lookup=$*;
+ grep -h "$l_lookup" $TRAF_VAR/monitor.map.[0-9]*.* | grep tdm_arkesp
+}
+environ[286] ---- BASH_FUNC_cmappc() ---> () {  l_nl=arkesp;
+ if [ $# != 0 ]; then
+ l_nl=$1;
+ fi;
+ setup_sqpdsh;
+ eval '$SQPDSHA "grep -h $l_nl $TRAF_VAR/monitor.map.[0-9]*.* | grep BEGIN | wc -l" 2>/dev/null | sort -nk2'
+}
+environ[287] ---- BASH_FUNC_sqchkmpi() ---> () {  pdsh $MY_NODES "cd $TRAF_HOME/logs; egrep -i '(mpi bug|ibv_create)' *.log" 2> /dev/null
+}
+environ[288] ---- BASH_FUNC_sqmd5b() ---> () {  setup_sqpdsh;
+ eval '$SQPDSHA "cd $TRAF_HOME/export/bin${SQ_MBTYPE}; md5sum $1 2>/dev/null" 2>/dev/null | cut -f2 -d: | sort -u'
+}
+environ[289] ---- BASH_FUNC_setup_my_nodes() ---> () {  export MY_NODES=`trafconf -wname`;
+ export NODE_LIST=`trafconf -name`
+}
+environ[290] ---- BASH_FUNC_sqchkvm() ---> () {  vmstat -a | head -2;
+ setup_sqpdsh;
+ eval '$SQPDSHA "vmstat -a" | grep -v swpd | grep -v memory | sort -rnk5'
+}
+environ[291] ---- BASH_FUNC_check_sb_regr() ---> () {  pushd . > /dev/null;
+ cd $TRAF_HOME/rundir;
+ find . -name runregr-sb.log | xargs grep FAIL;
+ popd > /dev/null
+}
+environ[292] ---- BASH_FUNC_sqgdb_doit() ---> () {  OPTIND=1;
+ prog=$1;
+ my_script=$2;
+ host=$3;
+ lv_dir_name=$4;
+ if [ -e $SQ_PDSH ]; then
+ ssh="ssh $host";
+ fi;
+ pids=`$ssh ps -C $prog -o uid,pid |grep $UID | awk '{ print $2 }'`;
+ echo "PIDs: $pids";
+ my_script_basename=`basename ${my_script}`;
+ declare -i lv_count;
+ let lv_count=0;
+ for pid in $pids;
+ do
+ echo "execute: $ssh gdb -p $pid --batch -x $my_script > $lv_dir_name/${host}_${pid}.${my_script_basename}.out ";
+ $ssh gdb -p $pid --batch -x $my_script > $lv_dir_name/${host}_${pid}.${my_script_basename}.out & let ++lv_count;
+ if [ $lv_count == 8 ]; then
+ let lv_count=0;
+ wait;
+ fi;
+ done;
+ wait
+}
+environ[293] ---- BASH_FUNC_lst() ---> () {  ls -lsrt $*
+}
+environ[294] ---- BASH_FUNC_chkReturnCode() ---> () {  if [[ $1 != 0 ]]; then
+ echo "$2 returned error $1...";
+ return $1;
+ else
+ echo "$2 executed successfully.";
+ return 0;
+ fi
+}
+environ[295] ---- BASH_FUNC_cmapt() ---> () {  l_nl=1;
+ if [ $# != 0 ]; then
+ l_nl=$1;
+ fi;
+ setup_sqpdsh;
+ eval '$SQPDSHA "tail --quiet --lines $l_nl $TRAF_VAR/monitor.map.[0-9]*.*" 2>/dev/null | sort -k1'
+}
+environ[296] ---- BASH_FUNC_sqsavelogs() ---> () {  lv_logs_collection_dir=$1;
+ lv_linux_collection_dir=$2;
+ lv_copy_to_dir=${lv_logs_collection_dir}/logs;
+ lv_node=`uname -n`;
+ sqcollectmonmemlog 2> /dev/null;
+ cp -p $TRAF_HOME/logs/master_exec*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/mon.*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/monmem.*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/pstart*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/smstats.*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/sqmo*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/trafodion.*log* ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/tm*.log ${lv_copy_to_dir};
+ cp -p $TRAF_HOME/logs/wdt.*.log ${lv_copy_to_dir};
+ cp -p $TRAF_VAR/monitor.map.[0-9]*.* ${lv_copy_to_dir};
+ cp -p $TRAF_VAR/monitor.trace* ${lv_copy_to_dir};
+ lv_stdout_dir_name=${lv_copy_to_dir}/stdout_${lv_node};
+ mkdir -p ${lv_stdout_dir_name};
+ cp -p $TRAF_HOME/sql/scripts/startup.log ${lv_copy_to_dir}/startup.${lv_node}.log;
+ cp -p $TRAF_HOME/sql/scripts/stdout_* ${lv_stdout_dir_name};
+ cp -p $TRAF_HOME/sql/scripts/hs_err_pid*.log ${lv_stdout_dir_name};
+ lv_config_dir_name=${lv_copy_to_dir}/

<TRUNCATED>

[9/9] trafodion git commit: Merge [TRAFODION-2886] PR-1380 fix the nullpointer error scanned by TScanCode

Posted by su...@apache.org.
Merge [TRAFODION-2886] PR-1380 fix the nullpointer error scanned by TScanCode


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

Branch: refs/heads/master
Commit: 0f025ac624fe45f3cd26718943b78897cb665808
Parents: b0d0d53 1942ea3
Author: Suresh Subbiah <su...@apache.org>
Authored: Mon Jan 22 15:56:23 2018 +0000
Committer: Suresh Subbiah <su...@apache.org>
Committed: Mon Jan 22 15:56:23 2018 +0000

----------------------------------------------------------------------
 core/conn/jdbc_type2/native/SqlInterface.cpp    | 12 +--
 core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp |  6 +-
 core/sqf/src/seabed/src/fsi.cpp                 |  8 +-
 core/sqf/src/seabed/src/msmon.cpp               |  7 +-
 core/sql/cli/Context.cpp                        |  3 +-
 core/sql/cli/ExSqlComp.cpp                      |  2 +-
 core/sql/cli/Globals.cpp                        |  4 +-
 core/sql/executor/ExExplain.cpp                 |  6 +-
 core/sql/executor/ExStats.cpp                   |  3 +-
 core/sql/executor/cluster.cpp                   |  4 +-
 core/sql/optimizer/BindItemExpr.cpp             | 12 ++-
 core/sql/optimizer/MVInfo.cpp                   |  6 +-
 core/sql/optimizer/OptPhysRelExpr.cpp           |  6 +-
 core/sql/optimizer/PhyProp.cpp                  |  8 +-
 core/sql/optimizer/memo.cpp                     |  8 +-
 core/sql/parser/ElemDDLNode.cpp                 |  2 +-
 core/sql/qms/QmsMVMemo.cpp                      |  2 +-
 core/sql/runtimestats/ssmpipc.cpp               |  2 +-
 win-odbc64/odbcclient/drvr35/charsetconv.cpp    | 84 ++++++++++----------
 19 files changed, 99 insertions(+), 86 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafodion/blob/0f025ac6/core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/trafodion/blob/0f025ac6/core/sqf/src/seabed/src/msmon.cpp
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/trafodion/blob/0f025ac6/core/sql/cli/Context.cpp
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/trafodion/blob/0f025ac6/core/sql/cli/Globals.cpp
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/trafodion/blob/0f025ac6/core/sql/optimizer/BindItemExpr.cpp
----------------------------------------------------------------------


[3/9] trafodion git commit: fix the nullpointer error scaned by TScanCode

Posted by su...@apache.org.
fix the nullpointer error scaned by TScanCode


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

Branch: refs/heads/master
Commit: b32351ff93e44a346f8dfb15c0ea9afa748f62a6
Parents: 8e332e5
Author: Kenny <xi...@esgyn.cn>
Authored: Tue Jan 9 05:06:30 2018 +0000
Committer: Kenny <xi...@esgyn.cn>
Committed: Tue Jan 9 05:06:30 2018 +0000

----------------------------------------------------------------------
 core/conn/jdbc_type2/native/SqlInterface.cpp    |  12 +-
 core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp |   6 +-
 core/conn/trafci/Makefile.bak                   |  41 +
 core/sqf/sql/scripts/DUMPENVS                   | 884 +++++++++++++++++++
 core/sqf/src/seabed/src/fsi.cpp                 |   8 +-
 core/sqf/src/seabed/src/msmon.cpp               |   7 +-
 core/sql/cli/Context.cpp                        |   3 +-
 core/sql/cli/ExSqlComp.cpp                      |   2 +-
 core/sql/cli/Globals.cpp                        |   4 +-
 core/sql/executor/ExExplain.cpp                 |   6 +-
 core/sql/executor/ExStats.cpp                   |   3 +-
 core/sql/executor/cluster.cpp                   |   2 +-
 core/sql/optimizer/BindItemExpr.cpp             |  12 +-
 core/sql/optimizer/MVInfo.cpp                   |   6 +-
 core/sql/optimizer/OptPhysRelExpr.cpp           |   6 +-
 core/sql/optimizer/PhyProp.cpp                  |   8 +-
 core/sql/optimizer/memo.cpp                     |   8 +-
 core/sql/parser/ElemDDLNode.cpp                 |   2 +-
 core/sql/qms/QmsMVMemo.cpp                      |   2 +-
 core/sql/runtimestats/ssmpipc.cpp               |   2 +-
 win-odbc64/odbcclient/drvr35/charsetconv.cpp    |  84 +-
 21 files changed, 1023 insertions(+), 85 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/conn/jdbc_type2/native/SqlInterface.cpp
----------------------------------------------------------------------
diff --git a/core/conn/jdbc_type2/native/SqlInterface.cpp b/core/conn/jdbc_type2/native/SqlInterface.cpp
index 48a397b..1076fb3 100644
--- a/core/conn/jdbc_type2/native/SqlInterface.cpp
+++ b/core/conn/jdbc_type2/native/SqlInterface.cpp
@@ -67,11 +67,13 @@ extern int SPJRS;
 }\
 }
 
-#define THREAD_RETURN(pSrvrStmt, return_code) \
-{ \
-	pSrvrStmt->threadReturnCode = return_code; \
-	if (pSrvrStmt->threadReturnCode!=SQL_SUCCESS) pSrvrStmt->processThreadReturnCode(); \
-	CLI_DEBUG_RETURN_SQL(pSrvrStmt->threadReturnCode); \
+#define THREAD_RETURN(pSrvrStmt, return_code)                           \
+{                                                                       \
+    if (NULL != pSrvrStmt)                                              \
+        pSrvrStmt->threadReturnCode = return_code;                      \
+    if (NULL != pSrvrStmt && pSrvrStmt->threadReturnCode!=SQL_SUCCESS)  \
+        pSrvrStmt->processThreadReturnCode();                           \
+    CLI_DEBUG_RETURN_SQL(return_code);                                  \
 }
 
 #define HANDLE_THREAD_ERROR(error_code, warning_flag, pSrvrStmt) \

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp
----------------------------------------------------------------------
diff --git a/core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp b/core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp
index a0aaf26..e4a7b35 100644
--- a/core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp
+++ b/core/conn/odbc/src/odbc/nsksrvr/SrvrConnect.cpp
@@ -1163,10 +1163,12 @@ ImplInit (
 		srvrGlobal = new SRVR_GLOBAL_Def;
 		if (srvrGlobal == NULL)
 		{
+			IDL_OBJECT_def objRef;
+			memset(&objRef, 0, sizeof(IDL_OBJECT_def));
 //LCOV_EXCL_START
 			SendEventMsg(MSG_MEMORY_ALLOCATION_ERROR, EVENTLOG_ERROR_TYPE,
-					srvrGlobal->nskProcessInfo.processId, ODBCMX_SERVER,
-					srvrGlobal->srvrObjRef, 1, "srvrGlobal");
+					GetCurrentProcessId(), ODBCMX_SERVER,
+					objRef, 1, "srvrGlobal");
 			exitServerProcess();
 //LCOV_EXCL_STOP
 		}

http://git-wip-us.apache.org/repos/asf/trafodion/blob/b32351ff/core/conn/trafci/Makefile.bak
----------------------------------------------------------------------
diff --git a/core/conn/trafci/Makefile.bak b/core/conn/trafci/Makefile.bak
new file mode 100644
index 0000000..bc0b26f
--- /dev/null
+++ b/core/conn/trafci/Makefile.bak
@@ -0,0 +1,41 @@
+# @@@ START COPYRIGHT @@@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+# @@@ END COPYRIGHT @@@
+
+# This Makefile is just a thin shell to Maven, which is used to do the real build
+
+include ../../macros.gmk #top level
+
+all:Trafci_deploy
+Trafci_deploy:Trafci_installer
+Trafci_installer:Trafci_jar
+Trafci_jar:
+	mvn clean install -DskipTests$
+Trafci_installer:
+	./getBuildInfo
+	export buildId=`head -n 1 buildId`
+	mvn -f installer_pom.xml -DbldId=${buildId} clean package -DskipTests
+Trafci_deploy:
+	zip -r ../clients/trafci.zip -j target/trafciInstaller.jar utils/README
+	java -jar target/trafciInstaller.jar -silent -installDir ${TRAF_HOME}
+
+clean:
+	mvn -f installer_pom.xml clean
+	mvn -f pom.xml clean


[5/9] trafodion git commit: remove the error file

Posted by su...@apache.org.
remove the error file


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

Branch: refs/heads/master
Commit: 8866368dda821fb26107b3ed439375c8c7b23518
Parents: b32351f
Author: Kenny <xi...@esgyn.cn>
Authored: Tue Jan 9 05:08:28 2018 +0000
Committer: Kenny <xi...@esgyn.cn>
Committed: Tue Jan 9 05:08:28 2018 +0000

----------------------------------------------------------------------
 core/conn/trafci/Makefile.bak |  41 --
 core/sqf/sql/scripts/DUMPENVS | 884 -------------------------------------
 2 files changed, 925 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafodion/blob/8866368d/core/conn/trafci/Makefile.bak
----------------------------------------------------------------------
diff --git a/core/conn/trafci/Makefile.bak b/core/conn/trafci/Makefile.bak
deleted file mode 100644
index bc0b26f..0000000
--- a/core/conn/trafci/Makefile.bak
+++ /dev/null
@@ -1,41 +0,0 @@
-# @@@ START COPYRIGHT @@@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-# @@@ END COPYRIGHT @@@
-
-# This Makefile is just a thin shell to Maven, which is used to do the real build
-
-include ../../macros.gmk #top level
-
-all:Trafci_deploy
-Trafci_deploy:Trafci_installer
-Trafci_installer:Trafci_jar
-Trafci_jar:
-	mvn clean install -DskipTests$
-Trafci_installer:
-	./getBuildInfo
-	export buildId=`head -n 1 buildId`
-	mvn -f installer_pom.xml -DbldId=${buildId} clean package -DskipTests
-Trafci_deploy:
-	zip -r ../clients/trafci.zip -j target/trafciInstaller.jar utils/README
-	java -jar target/trafciInstaller.jar -silent -installDir ${TRAF_HOME}
-
-clean:
-	mvn -f installer_pom.xml clean
-	mvn -f pom.xml clean


[7/9] trafodion git commit: fix the nullpointer error scanned by TScanCode. modify as review

Posted by su...@apache.org.
fix the nullpointer error scanned by TScanCode. modify as review


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

Branch: refs/heads/master
Commit: fbcd84b60e35f6cbe781e89f81313633246ac3ad
Parents: cb11885
Author: Kenny <xi...@esgyn.cn>
Authored: Fri Jan 12 15:33:31 2018 +0000
Committer: Kenny <xi...@esgyn.cn>
Committed: Fri Jan 12 15:33:31 2018 +0000

----------------------------------------------------------------------
 core/sql/executor/cluster.cpp | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafodion/blob/fbcd84b6/core/sql/executor/cluster.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/cluster.cpp b/core/sql/executor/cluster.cpp
index 40a44d4..1c9ed43 100644
--- a/core/sql/executor/cluster.cpp
+++ b/core/sql/executor/cluster.cpp
@@ -2395,7 +2395,7 @@ NABoolean Cluster::checkAndSplit(ExeErrorCode * rc)
 				         rc);
   
   if ( !next_ || *rc ) {
-    if ( !(*rc))* rc = EXE_NO_MEM_TO_EXEC;
+    if (EXE_OK == *rc) *rc = EXE_NO_MEM_TO_EXEC;
     return TRUE;
   }
 


[6/9] trafodion git commit: fix the nullpointer error scanned by TScanCode. modify as review

Posted by su...@apache.org.
fix the nullpointer error scanned by TScanCode. modify as review


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

Branch: refs/heads/master
Commit: cb11885083764000b0b07402e35dd58d20ff1556
Parents: 8866368
Author: Kenny <xi...@esgyn.cn>
Authored: Thu Jan 11 09:07:21 2018 +0000
Committer: Kenny <xi...@esgyn.cn>
Committed: Thu Jan 11 09:07:21 2018 +0000

----------------------------------------------------------------------
 core/sql/executor/cluster.cpp | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafodion/blob/cb118850/core/sql/executor/cluster.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/cluster.cpp b/core/sql/executor/cluster.cpp
index 0b82fb1..40a44d4 100644
--- a/core/sql/executor/cluster.cpp
+++ b/core/sql/executor/cluster.cpp
@@ -2395,7 +2395,7 @@ NABoolean Cluster::checkAndSplit(ExeErrorCode * rc)
 				         rc);
   
   if ( !next_ || *rc ) {
-    * rc = EXE_NO_MEM_TO_EXEC;
+    if ( !(*rc))* rc = EXE_NO_MEM_TO_EXEC;
     return TRUE;
   }
 


[4/9] trafodion git commit: remove the error file

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/trafodion/blob/8866368d/core/sqf/sql/scripts/DUMPENVS
----------------------------------------------------------------------
diff --git a/core/sqf/sql/scripts/DUMPENVS b/core/sqf/sql/scripts/DUMPENVS
deleted file mode 100644
index deb3c65..0000000
--- a/core/sqf/sql/scripts/DUMPENVS
+++ /dev/null
@@ -1,884 +0,0 @@
-ProcessEnv::dumpEnvs() 
-environ[0] ---- SQ_LIO_MAX_BUFFERS ---> 1000
-environ[1] ---- MPI_ROOT ---> /home/wangxz/code/trafodion/core/sqf/opt/hpmpi
-environ[2] ---- MPI_TMPDIR ---> /home/wangxz/code/trafodion/core/sqf/tmp
-environ[3] ---- MPI_FLAGS ---> y0
-environ[4] ---- MPI_IC_ORDER ---> TCP
-environ[5] ---- MPI_TEST_DELAY ---> 2
-environ[6] ---- MPI_ERROR_LEVEL ---> 2
-environ[7] ---- MPI_RDMA_MSGSIZE ---> 32768,131072,4194304
-environ[8] ---- HPMP_SQ ---> 1
-environ[9] ---- MALLOC_ARENA_MAX ---> 1
-environ[10] ---- HPMP_SINGLETON_HA ---> 1
-environ[11] ---- TRAF_CONF ---> /home/wangxz/code/trafodion/core/sqf/conf
-environ[12] ---- TRAF_HOME ---> /home/wangxz/code/trafodion/core/sqf
-environ[13] ---- TRAF_VAR ---> /home/wangxz/code/trafodion/core/sqf/tmp
-environ[14] ---- USER ---> wangxz
-environ[15] ---- HOME ---> /home/wangxz
-environ[16] ---- TERM ---> dumb
-environ[17] ---- CLASSPATH ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/antisamy-1.4.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-core-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-kms-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-s
 3-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-css-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-ext-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-util-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/bsh-core-2.0b4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-core-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-codec-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-configuration-1.6.jar:/home/wangxz/cod
 e/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-daemon-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-fileupload-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-logging-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hba
 se/lib/core-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/disruptor-3.3.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/esapi-2.1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/guava-12.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-aws-2.6.0-cdh5.
 7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-api-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core
 /sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-server-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-client-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-examples-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-external-blockcache-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop2-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodio
 n/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-it-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-prefix-tree-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-procedure-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-resource-bundle-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-rest-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-server-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-shell-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-spark-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/loca
 l_hadoop/hbase/lib/hbase-thrift-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hsqldb-1.8.0.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-annotations-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-databind-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_
 hadoop/hbase/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jamon-runtime-2.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-impl-2.2.3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jcodings-1.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-client-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-core-1.9.jar:/
 home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jettison-1.3.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-sslengine-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/joni-2.1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jruby-cloudera-1.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/l
 ocal_hadoop/hbase/lib/jsp-api-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsr305-1.3.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/junit-4.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/leveldbjni-all-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/libthrift-0.9.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/metrics-core-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/nekohtml-1.9.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/netty-all-4.0.23.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafodion/
 core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/spymemcached-2.11.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xalan-2.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xercesImpl-2.9.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-1.3.03.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-ext-1.3.04.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xom-1.2.5.jar:/home/w
 angxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hado
 op/hadoop/share/hadoop/common/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/had
 oop/share/hadoop/common/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/li
 b/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/guava-11.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/li
 b/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-api-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-impl-2.2.
 3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-core-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jettison-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sq
 f/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/mockito-all-1.8.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/netty-3.6.2.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/slf4j
 -api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/stax-api-1.0-2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/
 hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-plugins-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-nativetask-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-examples-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core
 /sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-core-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-fate-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-start-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-trace-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-2.7.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-runtime-3.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/apache-log4j-extras-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-commons-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-
 tree-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/bonecp-0.8.0.RELEASE.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-avatica-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-core-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-linq4j-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/co
 mmons-compiler-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-dbcp-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-httpclient-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-pool-1.5.4.jar:/home/wangxz/code/
 trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-vfs2-2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-client-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-framework-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-recipes-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-api-jdo-3.2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-core-3.2.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-rdbms-3.2.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/derby-10.11.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/eigenbase-properties-1.1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-annotation_1.0_spec-1.1.1.jar:/home/wangxz/
 code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jaspic_1.0_spec-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jta_1.1_spec-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/groovy-all-2.4.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/guava-14.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hamcrest-core-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-accumulo-handler-1.1.0-cdh5.7.1.jar:/home/wa
 ngxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-ant-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-beeline-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-cli-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-contrib-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-exec-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hbase-handler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hwi-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1-standalone.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/l
 ib/hive-metastore-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-serde-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-service-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-0.23-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-scheduler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-testutils-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpcore-4.2.5.jar:/home/wangxz/code/t
 rafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-annotations-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-core-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-databind-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-jaxrs-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-xc-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jamon-runtime-2.3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/janino-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jcommander-1.32.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jdo-api-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jer
 sey-server-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jersey-servlet-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-server-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jline-2.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/joda-time-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jpam-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jta-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/libfb303-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/libth
 rift-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/log4j-1.2.16.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mail-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-api-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svn-commons-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svnexe-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-core-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-json-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-jvm-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mysql-connector-java-5.1.23-bin.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/opencsv-2.3.jar:/home/wangxz/code/tr
 afodion/core/sqf/sql/local_hadoop/hive/lib/oro-2.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/parquet-hadoop-bundle-1.5.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/pentaho-aggdesigner-algorithm-5.1.5-jhyde.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/plexus-utils-1.5.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/regexp-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/ST4-4.0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stax-api-1.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stringtemplate-3.2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/su
 per-csv-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/tempus-fugit-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/velocity-1.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/etc/hadoop:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/conf:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/conf::/home/wangxz/code/trafodion/core/sqf/export/lib/hbase-trx-cdh5_7-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-dtm-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-sql-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-utility-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT4-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT2.jar:/conf:
-environ[18] ---- XAUTHORITY ---> /home/wangxz/.Xauthority
-environ[19] ---- SQ_IC ---> TCP
-environ[20] ---- SQ_VIRTUAL_NODES ---> 2
-environ[21] ---- SQ_VIRTUAL_NID ---> 0
-environ[22] ---- SQ_LIO_VIRTUAL_NID ---> 0
-environ[23] ---- LD_LIBRARY_PATH ---> /lib64:/usr/lib64:/home/wangxz/code/trafodion/core/sqf/opt/hpmpi/lib/linux_amd64:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/lib/native:/home/wangxz/code/trafodion/core/sqf/export/lib64d:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server:/usr/lib64:.
-environ[24] ---- LD_BIND_NOW ---> true
-environ[25] ---- PWD ---> /home/wangxz/code/trafodion/core/sqf
-environ[26] ---- PATH ---> /home/wangxz/code/trafodion/core/sqf/opt/hpmpi/bin:/home/wangxz/code/trafodion/core/sqf/export/bin64d:/home/wangxz/code/trafodion/core/sqf/sql/scripts:/home/wangxz/code/trafodion/core/sqf/tools:/home/wangxz/code/trafodion/core/sqf/trafci/bin:/home/wangxz/installed_software_tools/apache-maven-3.3.3/bin:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/bin:/usr/lib64/qt-3.3/bin:/usr/local/bin:/bin:/usr/bin:/usr/local/sbin:/usr/sbin:/sbin:/home/wangxz/bin
-environ[27] ---- CLUSTERNAME ---> 
-environ[28] ---- SQ_MBTYPE ---> 64d
-environ[29] ---- MY_NODES ---> 
-environ[30] ---- JAVA_HOME ---> /usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64
-environ[31] ---- MY_CLUSTER_ID ---> 
-environ[32] ---- TRAF_FOUNDATION_READY ---> 1
-environ[33] ---- DTM_RUN_MODE ---> 2
-environ[34] ---- SQ_AUDITSVC_READY ---> 1
-environ[35] ---- DTM_TLOG_PER_TM ---> 0
-environ[36] ---- TRAF_TM_LOCKED ---> 0
-environ[37] ---- DTM_RECOVERING_TX_COUNT ---> 0
-environ[38] ---- SQ_TXNSVC_READY ---> 1
-environ[39] ---- FS_TRACE_PARAMS ---> 1
-environ[40] ---- SEAQUEST_DP2 ---> 1
-environ[41] ---- MS_TRACE_MON ---> 1
-environ[42] ---- FS_ASSERT_ERROR ---> 1
-environ[43] ---- MY_UDR_ROOT ---> /home/wangxz/code/trafodion/core/sqf/udr
-environ[44] ---- TAR_DOWNLOAD_ROOT ---> /home/wangxz/sqllogs
-environ[45] ---- YYERROR_QUIET ---> 1
-environ[46] ---- FS_TRACE_FILE ---> fstrace
-environ[47] ---- LIBHDFS_OPTS ---> -Xmx2048m
-environ[48] ---- STFS_HDD_LOCATION ---> /home/wangxz/code/trafodion/core/sqf/tmp
-environ[49] ---- SEAQUEST_NO_ROLLBACK_TXN ---> 0
-environ[50] ---- TM_ENABLE_DDL_TRANS ---> 1
-environ[51] ---- IPC_LAUNCH_UNHOOKED ---> 1
-environ[52] ---- SQL_MEASURE_ENABLE ---> 0
-environ[53] ---- TM_USE_SSCC ---> 0
-environ[54] ---- SQ_PROPS_TDM_ARKCMP ---> tdm_arkcmp.env
-environ[55] ---- TM_ENABLE_TLOG_WRITES ---> 1
-environ[56] ---- MS_TRACE_ENABLE ---> 0
-environ[57] ---- REST_INSTALL_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/rest-2.3.0
-environ[58] ---- TSE_CONVERT_NOUNDO_TRANS ---> 1
-environ[59] ---- MS_DISC_SEM_ROBUST ---> 1
-environ[60] ---- AM_TRACE_FILE ---> am_trace
-environ[61] ---- TM_TLOG_DISABLE_BLOCK_CACHE ---> 0
-environ[62] ---- FS_TRACE_MON ---> 1
-environ[63] ---- MS_TRACE_FILE_UNIQUE ---> 1
-environ[64] ---- HOOK_ENABLE ---> 0
-environ[65] ---- AM_TRACE_FILE_UNIQUE ---> 1
-environ[66] ---- FS_TRACE_ENABLE ---> 0
-environ[67] ---- AM_TRACE ---> 0
-environ[68] ---- MS_TRACE_FILE ---> mstrace
-environ[69] ---- ABANDON_TX_AFTER_3_RETRIES ---> 0
-environ[70] ---- CMP_NODE_AFFINITY ---> 1
-environ[71] ---- TM_TLOG_NUM_LOGS ---> 16
-environ[72] ---- CACERTS_DIR ---> /home/wangxz/cacerts
-environ[73] ---- SQ_TRANS_SOCK ---> 0
-environ[74] ---- SQLMX_MESSAGEFILE ---> /home/wangxz/code/trafodion/core/sqf/export/bin64d/mxcierrors.cat
-environ[75] ---- MS_TRACE_PARAMS ---> 1
-environ[76] ---- MS_STREAMS_MAX ---> 20000
-environ[77] ---- FS_TRACE_FILE_UNIQUE ---> 1
-environ[78] ---- TM_TLOG_AUTO_FLUSH ---> 0
-environ[79] ---- TM_IDTMSRV_REFRESH_DELAY_SECONDS ---> 3
-environ[80] ---- DCS_INSTALL_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0
-environ[81] ---- SQ_PROPS_TDM_ARKESP ---> tdm_arkesp.env
-environ[82] ---- MS_STREAMS_MIN ---> 20000
-environ[83] ---- TM_TLOG_MAX_VERSIONS ---> 5
-environ[84] ---- AM_TRACE_LEVEL ---> 1
-environ[85] ---- DTM_RM_PARTIC ---> 0
-environ[86] ---- SEAQUEST ---> 1
-environ[87] ---- TRAFODION_LOG_FILENAME_SUFFIX ---> _0.log
-environ[88] ---- NLSPATH ---> /usr/dt/lib/nls/msg/%L/%N.cat
-environ[89] ---- XFILESEARCHPATH ---> /usr/dt/app-defaults/%L/Dt
-environ[90] ---- HIVE_CNF_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/conf
-environ[91] ---- THRIFT_LIB_DIR ---> /home/wangxz/installed_software_tools/thrift-0.9.0/lib
-environ[92] ---- AR ---> ar
-environ[93] ---- MANPATH ---> :/home/wangxz/code/trafodion/core/sqf/export/share/man
-environ[94] ---- SQ_USE_INTC ---> 0
-environ[95] ---- MPI_CXX ---> /usr/bin/g++
-environ[96] ---- DCS_MASTER_PORT ---> 23400
-environ[97] ---- HOSTNAME ---> esgsh-dev-n001.novalocal
-environ[98] ---- HIVE_JAR_FILES ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/share/hadoop/mapreduce/hadoop-mapreduce-client-core-*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/*.jar
-environ[99] ---- MY_ZOOKEEPER_DATA_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/data/zookeeper
-environ[100] ---- SELINUX_ROLE_REQUESTED ---> 
-environ[101] ---- HBVER ---> apache1_2
-environ[102] ---- SHELL ---> /bin/bash
-environ[103] ---- SQPDSHA ---> eval
-environ[104] ---- HISTSIZE ---> 1000
-environ[105] ---- MAKEFLAGS ---> -j4
-environ[106] ---- LSP_POLL_FREQ ---> 60
-environ[107] ---- SSH_CLIENT ---> 10.10.9.22 56598 22
-environ[108] ---- SQ_COVERAGE ---> 0
-environ[109] ---- HADOOP_PID_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/tmp
-environ[110] ---- CMP_POLL_FREQ ---> 10
-environ[111] ---- ENABLE_EMBEDDED_ARKCMP ---> 1
-environ[112] ---- MY_MPI_ROOT ---> /home/wangxz/code/trafodion/core/sqf
-environ[113] ---- LD_PRELOAD ---> /usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/libjsig.so:/home/wangxz/code/trafodion/core/sqf/export/lib64d/libseabasesig.so
-environ[114] ---- SELINUX_USE_CURRENT_RANGE ---> 
-environ[115] ---- SQ_MON_EPOLL_RETRY_COUNT ---> 4
-environ[116] ---- QTDIR ---> /usr/lib64/qt-3.3
-environ[117] ---- OLDPWD ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0
-environ[118] ---- DCS_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/..
-environ[119] ---- QTINC ---> /usr/lib64/qt-3.3/include
-environ[120] ---- HBASE_CNF_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/conf
-environ[121] ---- MY_HBASE_ZOOKEEPER_PROPERTY_CLIENTPORT_NUM ---> 2181
-environ[122] ---- UDIS86 ---> /home/wangxz/installed_software_tools/udis86-1.7.2
-environ[123] ---- DCS_LOG_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/../logs
-environ[124] ---- SSH_TTY ---> /dev/pts/0
-environ[125] ---- TOOLSDIR ---> /home/wangxz/installed_software_tools
-environ[126] ---- DCS_CLASSPATH ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/antisamy-1.4.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-core-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-sdk-kms-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/aws-java-
 sdk-s3-1.10.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-css-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-ext-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/batik-util-1.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/bsh-core-2.0b4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-beanutils-core-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-codec-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-configuration-1.6.jar:/home/wangx
 z/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-daemon-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-fileupload-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-logging-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoo
 p/hbase/lib/core-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/disruptor-3.3.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/esapi-2.1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/guava-12.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-aws-2.6.0-
 cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-api-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion
 /core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-client-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hadoop-yarn-server-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-client-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-examples-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-external-blockcache-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop2-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/tra
 fodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-hadoop-compat-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-it-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-prefix-tree-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-procedure-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-resource-bundle-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-rest-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-server-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-shell-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hbase-spark-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql
 /local_hadoop/hbase/lib/hbase-thrift-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/hsqldb-1.8.0.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-annotations-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-databind-2.2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/l
 ocal_hadoop/hbase/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jamon-runtime-2.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jaxb-impl-2.2.3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jcodings-1.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-client-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-core-1.9.
 jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jettison-1.3.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-sslengine-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/joni-2.1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jruby-cloudera-1.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/
 sql/local_hadoop/hbase/lib/jsp-api-2.1-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/jsr305-1.3.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/junit-4.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/leveldbjni-all-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/libthrift-0.9.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/metrics-core-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/nekohtml-1.9.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/netty-all-4.0.23.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafo
 dion/core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5-6.1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/spymemcached-2.11.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xalan-2.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xercesImpl-2.9.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-1.3.03.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xml-apis-ext-1.3.04.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xom-1.2.5.jar:/h
 ome/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/hadoop-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-i18n-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/apacheds-kerberos-codec-2.0.0-M15.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-asn1-api-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/api-util-1.0.0-M20.jar:/home/wangxz/code/trafodion/core/sqf/sql/local
 _hadoop/hadoop/share/hadoop/common/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoo
 p/hadoop/share/hadoop/common/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-httpclient-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-math3-3.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/commons-net-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-client-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/comm
 on/lib/curator-framework-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/curator-recipes-2.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/guava-11.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-annotations-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hadoop-auth-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/hamcrest-core-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/htrace-core4-4.0.1-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/comm
 on/lib/httpcore-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-core-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-jaxrs-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-mapper-asl-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jackson-xc-1.8.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/java-xmlbuilder-0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-api-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jaxb-impl
 -2.2.3-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-core-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-json-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jersey-server-1.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jets3t-0.9.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jettison-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jetty-util-6.1.26.cloudera.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsch-0.1.42.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/co
 re/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/log4j-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/mockito-all-1.8.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/netty-3.6.2.Final.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/protobuf-java-2.5.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/
 slf4j-api-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/slf4j-log4j12-1.7.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/stax-api-1.0-2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xmlenc-0.52.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-app-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-common-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapre
 duce/hadoop-mapreduce-client-core-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-hs-plugins-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-jobclient-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-nativetask-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-client-shuffle-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/hadoop-mapreduce-examples-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion
 /core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/hadoop-hdfs-nfs-2.6.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-core-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-fate-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-start-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/accumulo-trace-1.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/activation-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-2.7.7.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/antlr-runtime-3.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/apache-log4j-extras-1.2.17.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-3.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/asm-commons-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib
 /asm-tree-3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/avro-1.7.6-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/bonecp-0.8.0.RELEASE.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-avatica-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-core-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/calcite-linq4j-1.0.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-1.7.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-beanutils-core-1.8.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-cli-1.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-codec-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-collections-3.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/l
 ib/commons-compiler-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-compress-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-configuration-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-dbcp-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-digester-1.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-el-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-httpclient-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-io-2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-lang-2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-logging-1.1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-math-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-pool-1.5.4.jar:/home/wangxz/
 code/trafodion/core/sqf/sql/local_hadoop/hive/lib/commons-vfs2-2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-client-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-framework-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/curator-recipes-2.6.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-api-jdo-3.2.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-core-3.2.10.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/datanucleus-rdbms-3.2.9.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/derby-10.11.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/eigenbase-properties-1.1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/findbugs-annotations-1.3.9-1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-annotation_1.0_spec-1.1.1.jar:/home/wa
 ngxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jaspic_1.0_spec-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/geronimo-jta_1.1_spec-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/groovy-all-2.4.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/gson-2.2.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/guava-14.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hamcrest-core-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-annotations-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-common-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hbase-protocol-1.2.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/high-scale-lib-1.1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-accumulo-handler-1.1.0-cdh5.7.1.jar:/ho
 me/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-ant-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-beeline-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-cli-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-contrib-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-exec-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hbase-handler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-hwi-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-jdbc-1.1.0-cdh5.7.1-standalone.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/h
 ive/lib/hive-metastore-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-serde-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-service-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-0.23-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-common-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-shims-scheduler-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/hive-testutils-1.1.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/htrace-core-3.2.0-incubating.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpclient-4.2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/httpcore-4.2.5.jar:/home/wangxz/c
 ode/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-annotations-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-core-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-databind-2.2.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-jaxrs-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jackson-xc-1.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jamon-runtime-2.3.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/janino-2.7.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-compiler-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jasper-runtime-5.5.23.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jcommander-1.32.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jdo-api-3.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/li
 b/jersey-server-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jersey-servlet-1.14.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jetty-all-server-7.6.0.v20120127.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jline-2.12.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/joda-time-1.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jpam-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsp-api-2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jsr305-3.0.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/jta-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/junit-4.11.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/libfb303-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/
 libthrift-0.9.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/log4j-1.2.16.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/logredactor-1.0.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mail-1.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-api-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svn-commons-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/maven-scm-provider-svnexe-1.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-core-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-json-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/metrics-jvm-3.0.2.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/mysql-connector-java-5.1.23-bin.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/opencsv-2.3.jar:/home/wangxz/co
 de/trafodion/core/sqf/sql/local_hadoop/hive/lib/oro-2.0.8.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/paranamer-2.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/parquet-hadoop-bundle-1.5.0-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/pentaho-aggdesigner-algorithm-5.1.5-jhyde.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/plexus-utils-1.5.6.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/regexp-1.3.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/servlet-api-2.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/snappy-java-1.0.4.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/ST4-4.0.4.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stax-api-1.0.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/stringtemplate-3.2.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/l
 ib/super-csv-2.2.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/tempus-fugit-1.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/velocity-1.5.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/xz-1.0.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib/zookeeper-3.4.5-cdh5.7.1.jar:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/etc/hadoop:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/conf:/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/conf::/home/wangxz/code/trafodion/core/sqf/export/lib/hbase-trx-cdh5_7-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-dtm-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-sql-cdh-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/trafodion-utility-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT4-2.3.0.jar:/home/wangxz/code/trafodion/core/sqf/export/lib/jdbcT2.jar:/conf:
-environ[127] ---- SQ_START_QVP ---> 1
-environ[128] ---- LC_ALL ---> en_US.UTF-8
-environ[129] ---- SQ_BTYPE ---> d
-environ[130] ---- PROTOBUFS_LIB ---> /usr/lib
-environ[131] ---- YARN_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop
-environ[132] ---- EMACS ---> t
-environ[133] ---- LS_COLORS ---> 
-environ[134] ---- JAVA_LIBRARY_PATH ---> /lib64:/usr/lib64:/home/wangxz/code/trafodion/core/sqf/opt/hpmpi/lib/linux_amd64::/home/wangxz/code/trafodion/core/sqf/export/lib64d:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server:/usr/lib64:.
-environ[135] ---- HBASE_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase
-environ[136] ---- DCS_MANAGES_ZK ---> false
-environ[137] ---- SQ_LUNMGR_VERBOSITY ---> 1
-environ[138] ---- PDSH ---> /usr/bin/pdsh -R exec
-environ[139] ---- FLEX ---> flex
-environ[140] ---- JDBCT4_JAR ---> jdbcT4-2.3.0.jar
-environ[141] ---- TERMCAP ---> 
-environ[142] ---- MY_HADOOP_HDFS_PORT_NUM ---> 9000
-environ[143] ---- SQ_SRVMON ---> 1
-environ[144] ---- SQ_MON_EPOLL_WAIT_TIMEOUT ---> 16
-environ[145] ---- HADOOP_JAR_DIRS ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common
-                          /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib
-                          /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce
-                          /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs
-environ[146] ---- SMP_POLL_FREQ ---> 60
-environ[147] ---- COLUMNS ---> 122
-environ[148] ---- DTM_COMMON_JAR ---> trafodion-dtm-cdh-2.3.0.jar
-environ[149] ---- TRAFODION_VER_UPDATE ---> 0
-environ[150] ---- MY_REST_SERVER_PORT ---> 4200
-environ[151] ---- SUFFIXES_TO_SUPPRESS ---> -sources.jar -tests.jar
-environ[152] ---- MAIL ---> /var/spool/mail/wangxz
-environ[153] ---- PDCP ---> /usr/bin/pdcp -R ssh
-environ[154] ---- HBASE_DEP_VER_CDH ---> 1.2.0-cdh5.7.1
-environ[155] ---- SQ_PDSH ---> /usr/bin/pdsh
-environ[156] ---- SQ_STARTUP ---> r
-environ[157] ---- TRAFODION_VER ---> 2.3.0
-environ[158] ---- MY_DRILL_INFO_PORT_NUM ---> 8047
-environ[159] ---- STY ---> 22432.pts-0.esgsh-dev-n001
-environ[160] ---- SQ_MON_SYNC_TIMEOUT ---> 900
-environ[161] ---- HADOOP_DEP_VER ---> 2.6.0
-environ[162] ---- DCS_ROOT_LOGGER ---> INFO,DRFA
-environ[163] ---- HIVE_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive
-environ[164] ---- SQ_MTYPE ---> 64
-environ[165] ---- SQ_IDTMSRV ---> 1
-environ[166] ---- HADOOP_CNF_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/etc/hadoop
-environ[167] ---- HBASE_TRXDIR ---> /home/wangxz/code/trafodion/core/sqf/export/lib
-environ[168] ---- MY_SW_ROOT ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop
-environ[169] ---- SQ_START_RMS ---> 1
-environ[170] ---- HIVE_DEP_VER_APACHE ---> 1.1.0
-environ[171] ---- MPICH_CXX ---> /usr/bin/g++
-environ[172] ---- LOG4CXX_INC_DIR ---> /usr/include/log4cxx
-environ[173] ---- LANG ---> en_US.UTF-8
-environ[174] ---- RH_MAJ_VERS ---> 6
-environ[175] ---- HADOOP_BLD_LIB ---> /home/wangxz/installed_software_tools/hadoop-2.6.0/lib/native
-environ[176] ---- MY_HBASE_ZOOKEEPER_LEADERPORT_NUM ---> 3888
-environ[177] ---- TRAFODION_ENABLE_AUTHENTICATION ---> NO
-environ[178] ---- MY_DB_MGR_PORT ---> 4205
-environ[179] ---- SQ_DTM_PERSISTENT_PROCESS ---> 1
-environ[180] ---- MY_SW_SCRIPTS_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/scripts
-environ[181] ---- HBASE_HEAPSIZE ---> 2048
-environ[182] ---- LLVM ---> /home/wangxz/installed_software_tools/dest-llvm-3.2
-environ[183] ---- SELINUX_LEVEL_REQUESTED ---> 
-environ[184] ---- DCS_MASTER_FLOATING_IP ---> 
-environ[185] ---- UTIL_JAR ---> trafodion-utility-2.3.0.jar
-environ[186] ---- DCS_SECURITY_LOGGER ---> INFO,DRFAS
-environ[187] ---- MY_DCS_SERVER_INFO_PORT ---> 24410
-environ[188] ---- SQ_MON_KEEPCNT ---> 5
-environ[189] ---- HBASE_TRX_JAR ---> hbase-trx-cdh5_7-2.3.0.jar
-environ[190] ---- HISTCONTROL ---> ignoredups
-environ[191] ---- CXX ---> g++
-environ[192] ---- DCS_LOGFILE ---> dcs-wangxz-1-server-esgsh-dev-n001.novalocal.log
-environ[193] ---- MY_DCS_MASTER_PORT ---> 23400
-environ[194] ---- ICU ---> /home/wangxz/installed_software_tools/icu4c_4.4
-environ[195] ---- SHLVL ---> 9
-environ[196] ---- CURL_LIB_DIR ---> /usr/lib64
-environ[197] ---- SQ_MON_KEEPINTVL ---> 6
-environ[198] ---- LANGUAGE ---> zh_CN:zh
-environ[199] ---- SQ_MON_KEEPIDLE ---> 60
-environ[200] ---- SSP_POLL_FREQ ---> 60
-environ[201] ---- TRAFODION_VER_MINOR ---> 3
-environ[202] ---- SQ_MON_KEEPALIVE ---> 1
-environ[203] ---- MPICH_ROOT ---> /home/wangxz/installed_software_tools/dest-mpich-3.0.4
-environ[204] ---- SQ_PHANDLE_VERIFIER ---> 1
-environ[205] ---- BISON ---> /home/wangxz/installed_software_tools/bison_3_linux/bin/bison
-environ[206] ---- HADOOP_JAR_FILES --->  /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/common/lib/*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/mapreduce/*.jar /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/share/hadoop/hdfs/*.jar
-environ[207] ---- LOG4CXX_LIB_DIR ---> /usr/lib64
-environ[208] ---- HADOOP_INC_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/include
-environ[209] ---- TRAFODION_VER_PROD ---> Apache Trafodion
-environ[210] ---- ANT ---> ant
-environ[211] ---- HIVE_DEP_VER_HDP ---> 1.2.1
-environ[212] ---- LOGNAME ---> wangxz
-environ[213] ---- DCS_IDENT_STRING ---> wangxz-1
-environ[214] ---- HIVE_JAR_DIRS ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hive/lib
-environ[215] ---- HADOOP_LIB_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hadoop/lib/native
-environ[216] ---- WINDOW ---> 2
-environ[217] ---- PROTOBUFS ---> /usr
-environ[218] ---- DCS_LOG_PREFIX ---> dcs-wangxz-1-server-esgsh-dev-n001.novalocal
-environ[219] ---- QTLIB ---> /usr/lib64/qt-3.3/lib
-environ[220] ---- SQ_PIDMAP ---> 1
-environ[221] ---- TRAFODION_VER_MAJOR ---> 2
-environ[222] ---- THRIFT_INC_DIR ---> /home/wangxz/installed_software_tools/thrift-0.9.0/include
-environ[223] ---- CVS_RSH ---> ssh
-environ[224] ---- HBASE_TRX_ID_HDP ---> hbase-trx-hdp2_3
-environ[225] ---- MAVEN ---> mvn
-environ[226] ---- SSH_CONNECTION ---> 10.10.9.22 56598 192.168.0.71 22
-environ[227] ---- THRIFT_DEP_VER ---> 0.9.0
-environ[228] ---- HBASE_TRX_ID_APACHE ---> hbase-trx-apache1_2
-environ[229] ---- HBASE_TRX_ID_CDH ---> hbase-trx-cdh5_7
-environ[230] ---- MY_DB_MGR_SECURE_PORT ---> 4206
-environ[231] ---- MY_HBASE_ZOOKEEPER_PEERPORT_NUM ---> 2888
-environ[232] ---- LOC_JVMLIBS ---> /usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server
-environ[233] ---- SQ_PDCP ---> /usr/bin/pdcp
-environ[234] ---- LESSOPEN ---> ||/usr/bin/lesspipe.sh %s
-environ[235] ---- MY_DRILL_RPC_PORT_NUM ---> 31010
-environ[236] ---- PDSH_SSH_CMD ---> ssh -q -n %h
-environ[237] ---- SQ_MON_ALTLOG ---> 0
-environ[238] ---- SQ_START_QMM ---> 0
-environ[239] ---- CURL_INC_DIR ---> /usr/include
-environ[240] ---- HIVE_DEP_VER_CDH ---> 1.1.0-cdh5.7.1
-environ[241] ---- SQ_NEW_PHANDLE ---> 1
-environ[242] ---- HBASE_DEP_VER_APACHE ---> 1.2.0
-environ[243] ---- MYSQL_HOME ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/mysql
-environ[244] ---- SQ_EVLOG_NONE ---> 1
-environ[245] ---- PROTOBUFS_INC ---> /usr/include
-environ[246] ---- MY_DCS_MASTER_INFO_PORT ---> 24400
-environ[247] ---- SQ_WDT_CHECK_CLUSTER_STATE ---> 0
-environ[248] ---- LMP_POLL_FREQ ---> 60
-environ[249] ---- SQL_JAR ---> trafodion-sql-cdh-2.3.0.jar
-environ[250] ---- MY_DRILL_BIT_PORT_NUM ---> 31011
-environ[251] ---- INSIDE_EMACS ---> 23.1.1,comint
-environ[252] ---- PRODUCT_COPYRIGHT_HEADER ---> 2015-2017 Apache Software Foundation
-environ[253] ---- HBASE_JAR_FILES --->  /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/hbase/lib/*.jar
-environ[254] ---- DCS_USER_PROGRAM_HOME ---> /home/wangxz/code/trafodion/core/sqf
-environ[255] ---- MY_REST_SERVER_SECURE_PORT ---> 4201
-environ[256] ---- HADOOP_BLD_INC ---> /home/wangxz/installed_software_tools/hadoop-2.6.0/include
-environ[257] ---- HBASE_PID_DIR ---> /home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/tmp
-environ[258] ---- G_BROKEN_FILENAMES ---> 1
-environ[259] ---- HBASE_DEP_VER_HDP ---> 1.1.2
-environ[260] ---- ZOOKEEPER_DIR ---> /home/wangxz/installed_software_tools/zookeeper-3.4.5
-environ[261] ---- HIVE_DEP_VER ---> 0.13.1
-environ[262] ---- MY_SW_HOME ---> /home/wangxz
-environ[263] ---- DCS_NICENESS ---> 0
-environ[264] ---- CSP_POLL_FREQ ---> 60
-environ[265] ---- DCS_OPTS ---> -XX:+UseConcMarkSweepGC   -Ddcs.log.dir=/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/../logs -Ddcs.log.file=dcs-wangxz-1-server-esgsh-dev-n001.novalocal.log -Ddcs.home.dir=/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/.. -Ddcs.id.str=wangxz-1 -Ddcs.root.logger=INFO,DRFA -Djava.library.path=/lib64:/usr/lib64:/home/wangxz/code/trafodion/core/sqf/opt/hpmpi/lib/linux_amd64::/home/wangxz/code/trafodion/core/sqf/export/lib64d:/usr/lib/jvm/java-1.7.0-openjdk-1.7.0.161.x86_64/jre/lib/amd64/server:/usr/lib64:. -Ddcs.user.program.home=/home/wangxz/code/trafodion/core/sqf -Ddcs.conf.dir=/home/wangxz/code/trafodion/core/sqf/sql/local_hadoop/dcs-2.3.0/bin/../conf -Ddcs.trafodion.home=/home/wangxz/code/trafodion/core/sqf
-environ[266] ---- BASH_FUNC_ncmp() ---> () {  nprocpn_us tdm_arkcmp | pdsh_counter
-}
-environ[267] ---- BASH_FUNC_sqsave_linux_info() ---> () {  lv_node=`uname -n`;
- dmesg > ${1}/dmesg.${lv_node}.log;
- df > ${1}/df.${lv_node}.log;
- ps -ef > ${1}/ps_ef.${lv_node}.log;
- last reboot > ${1}/last_reboot.${lv_node}.log
-}
-environ[268] ---- BASH_FUNC_collect_cmapt() ---> () {  lv_file_name='cmapt.out';
- LogHeader "Output of the cmapt function:";
- cmapt 16 >> $lv_file_name
-}
-environ[269] ---- BASH_FUNC_cmapls() ---> () {  if [ $# == 0 ]; then
- echo "Enter a string to lookup in all the monitor.map.[0-9]*.* files";
- return 1;
- fi;
- l_lookup=$*;
- setup_sqpdsh;
- eval '$SQPDSHA "ngrepmms $l_lookup" 2>/dev/null'
-}
-environ[270] ---- BASH_FUNC_tneprog() ---> () {  if [ $# != 0 ]; then
- lv_prog=$1;
- else
- lv_prog=arkesp;
- fi;
- cmapc END $lv_prog | pdsh_counter
-}
-environ[271] ---- BASH_FUNC_nprocpn() ---> () {  setup_sqpdsh;
- eval '$SQPDSHA "pstat | grep $1 | wc -l" | sort -nk2'
-}
-environ[272] ---- BASH_FUNC_sqsecheck() ---> () {  sediskstatus | grep DOWN
-}
-environ[273] ---- BASH_FUNC_nprocpn_us() ---> () {  setup_sqpdsh;
- eval '$SQPDSHA "pstat | grep $1 | wc -l"'
-}
-environ[274] ---- BASH_FUNC_tnbprog() ---> () {  if [ $# != 0 ]; then
- lv_prog=$1;
- else
- lv_prog=arkesp;
- fi;
- cmapc BEGIN $lv_prog | pdsh_counter
-}
-environ[275] ---- BASH_FUNC_sqmd5l() ---> () {  setup_sqpdsh;
- eval '$SQPDSHA "cd $TRAF_HOME/export/lib${SQ_MBTYPE}; md5sum $1 2>/dev/null" 2>/dev/null | cut -f2 -d: | sort -u'
-}
-environ[276] ---- BASH_FUNC_chkReturnCodeExit() ---> () {  if [[ $1 != 0 ]]; then
- echo "$2 returned error $1, exitting...";
- exit $1;
- else
- echo "$2 executed successfully.";
- fi
-}
-environ[277] ---- BASH_FUNC_cmaplsbec() ---> () {  l_lookup=$*;
- lv_all=`cmaplsc $*`;
- lv_begin=`cmaplsbc $*`;
- lv_end=`cmaplsec $*`;
- echo "$l_lookup,$lv_all,$lv_begin,$lv_end"
-}
-environ[278] ---- BASH_FUNC_ckillall() ---> () {  export SQ_PS1=$PS1;
- $TRAF_HOME/sql/scripts/ckillall;
- unset SQ_PS1
-}
-environ[279] ---- BASH_FUNC_sqchksl() ---> () {  setup_sqpdsh;
- eval '$SQPDSHA "cd $TRAF_HOME/sql/scripts; grep Executing startup.log 2>/dev/null" 2>/dev/null | sort -k4 -k5'
-}
-environ[280] ---- BASH_FUNC_ndbm() ---> () {  setup_sqpdsh;
- eval '$SQPDSHA "df -h | grep database" 2>/dev/null | wc -l'
-}
-environ[281] ---- BASH_FUNC_cmaplc() ---> () {  cmapl $* | wc -l
-}
-environ[282] ---- BASH_FUNC_cmaplec() ---> () {  cmapl $* | grep END | wc -l
-}
-environ[283] ---- BASH_FUNC_collect_cstat() ---> () {  lv_file_name='cstat.out';
- LogHeader "CSTAT";
- cstat | sort -k13 >> $lv_file_name
-}
-environ[284] ---- BASH_FUNC_nesp() ---> () {  nprocpn_us tdm_arkesp | pdsh_counter
-}
-environ[285] ---- BASH_FUNC_ngrepmms() ---> () {  l_lookup=$*;
- grep -h "$l_lookup" $TRAF_VAR/monitor.map.[0-9]*.* | grep tdm_arkesp
-}
-environ[286] ---- BASH_FUNC_cmappc() ---> () {  l_nl=arkesp;
- if [ $# != 0 ]; then
- l_nl=$1;
- fi;
- setup_sqpdsh;
- eval '$SQPDSHA "grep -h $l_nl $TRAF_VAR/monitor.map.[0-9]*.* | grep BEGIN | wc -l" 2>/dev/null | sort -nk2'
-}
-environ[287] ---- BASH_FUNC_sqchkmpi() ---> () {  pdsh $MY_NODES "cd $TRAF_HOME/logs; egrep -i '(mpi bug|ibv_create)' *.log" 2> /dev/null
-}
-environ[288] ---- BASH_FUNC_sqmd5b() ---> () {  setup_sqpdsh;
- eval '$SQPDSHA "cd $TRAF_HOME/export/bin${SQ_MBTYPE}; md5sum $1 2>/dev/null" 2>/dev/null | cut -f2 -d: | sort -u'
-}
-environ[289] ---- BASH_FUNC_setup_my_nodes() ---> () {  export MY_NODES=`trafconf -wname`;
- export NODE_LIST=`trafconf -name`
-}
-environ[290] ---- BASH_FUNC_sqchkvm() ---> () {  vmstat -a | head -2;
- setup_sqpdsh;
- eval '$SQPDSHA "vmstat -a" | grep -v swpd | grep -v memory | sort -rnk5'
-}
-environ[291] ---- BASH_FUNC_check_sb_regr() ---> () {  pushd . > /dev/null;
- cd $TRAF_HOME/rundir;
- find . -name runregr-sb.log | xargs grep FAIL;
- popd > /dev/null
-}
-environ[292] ---- BASH_FUNC_sqgdb_doit() ---> () {  OPTIND=1;
- prog=$1;
- my_script=$2;
- host=$3;
- lv_dir_name=$4;
- if [ -e $SQ_PDSH ]; then
- ssh="ssh $host";
- fi;
- pids=`$ssh ps -C $prog -o uid,pid |grep $UID | awk '{ print $2 }'`;
- echo "PIDs: $pids";
- my_script_basename=`basename ${my_script}`;
- declare -i lv_count;
- let lv_count=0;
- for pid in $pids;
- do
- echo "execute: $ssh gdb -p $pid --batch -x $my_script > $lv_dir_name/${host}_${pid}.${my_script_basename}.out ";
- $ssh gdb -p $pid --batch -x $my_script > $lv_dir_name/${host}_${pid}.${my_script_basename}.out & let ++lv_count;
- if [ $lv_count == 8 ]; then
- let lv_count=0;
- wait;
- fi;
- done;
- wait
-}
-environ[293] ---- BASH_FUNC_lst() ---> () {  ls -lsrt $*
-}
-environ[294] ---- BASH_FUNC_chkReturnCode() ---> () {  if [[ $1 != 0 ]]; then
- echo "$2 returned error $1...";
- return $1;
- else
- echo "$2 executed successfully.";
- return 0;
- fi
-}
-environ[295] ---- BASH_FUNC_cmapt() ---> () {  l_nl=1;
- if [ $# != 0 ]; then
- l_nl=$1;
- fi;
- setup_sqpdsh;
- eval '$SQPDSHA "tail --quiet --lines $l_nl $TRAF_VAR/monitor.map.[0-9]*.*" 2>/dev/null | sort -k1'
-}
-environ[296] ---- BASH_FUNC_sqsavelogs() ---> () {  lv_logs_collection_dir=$1;
- lv_linux_collection_dir=$2;
- lv_copy_to_dir=${lv_logs_collection_dir}/logs;
- lv_node=`uname -n`;
- sqcollectmonmemlog 2> /dev/null;
- cp -p $TRAF_HOME/logs/master_exec*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/mon.*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/monmem.*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/pstart*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/smstats.*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/sqmo*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/trafodion.*log* ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/tm*.log ${lv_copy_to_dir};
- cp -p $TRAF_HOME/logs/wdt.*.log ${lv_copy_to_dir};
- cp -p $TRAF_VAR/monitor.map.[0-9]*.* ${lv_copy_to_dir};
- cp -p $TRAF_VAR/monitor.trace* ${lv_copy_to_dir};
- lv_stdout_dir_name=${lv_copy_to_dir}/stdout_${lv_node};
- mkdir -p ${lv_stdout_dir_name};
- cp -p $TRAF_HOME/sql/scripts/startup.log ${lv_copy_to_dir}/startup.${lv_node}.log;
- cp -p $TRAF_HOME/sql/scripts/stdout_* ${lv_stdout_dir_name};
- cp -p $TRAF_HOME/sql/scripts/hs_err_pid*.log ${lv_stdout_dir_name};
- lv_config_dir_name=${lv_copy_to_d

<TRUNCATED>

[8/9] trafodion git commit: fix the nullpointer error scanned by TScanCode. modify as review

Posted by su...@apache.org.
fix the nullpointer error scanned by TScanCode. modify as review


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

Branch: refs/heads/master
Commit: 1942ea3231f5ee74358781f2b0d5c8a19d0e0cd7
Parents: fbcd84b
Author: Kenny <xi...@esgyn.cn>
Authored: Fri Jan 12 17:03:06 2018 +0000
Committer: Kenny <xi...@esgyn.cn>
Committed: Fri Jan 12 17:03:06 2018 +0000

----------------------------------------------------------------------
 core/sql/executor/cluster.cpp | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafodion/blob/1942ea32/core/sql/executor/cluster.cpp
----------------------------------------------------------------------
diff --git a/core/sql/executor/cluster.cpp b/core/sql/executor/cluster.cpp
index 1c9ed43..f9ceb86 100644
--- a/core/sql/executor/cluster.cpp
+++ b/core/sql/executor/cluster.cpp
@@ -2394,7 +2394,7 @@ NABoolean Cluster::checkAndSplit(ExeErrorCode * rc)
 			        	 next_,
 				         rc);
   
-  if ( !next_ || *rc ) {
+  if ( !next_ || (*rc != EXE_OK) ) {
     if (EXE_OK == *rc) *rc = EXE_NO_MEM_TO_EXEC;
     return TRUE;
   }