You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafodion.apache.org by db...@apache.org on 2017/03/28 23:20:27 UTC

[1/2] incubator-trafodion git commit: [TRAFODION-2532] clean up the error message 'monitor.ini not found'

Repository: incubator-trafodion
Updated Branches:
  refs/heads/master 4716b3ae2 -> 3f75c15a6


[TRAFODION-2532] clean up the error message 'monitor.ini not found'


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

Branch: refs/heads/master
Commit: c2704e71d02e459236ae26c81a001b0231598067
Parents: 2aac3f7
Author: Eason <hf...@gmail.com>
Authored: Mon Mar 27 22:14:57 2017 +0800
Committer: Eason <hf...@gmail.com>
Committed: Mon Mar 27 22:27:17 2017 +0800

----------------------------------------------------------------------
 core/sqf/export/include/seabed/ms.h    |   7 --
 core/sqf/monitor/linux/clio.cxx        |   8 ---
 core/sqf/monitor/linux/cluster.cxx     | 100 ----------------------------
 core/sqf/monitor/linux/cluster.h       |   4 --
 core/sqf/monitor/linux/getseq.cxx      |  54 ---------------
 core/sqf/monitor/linux/internal.h      |   1 -
 core/sqf/monitor/linux/makefile        |   2 -
 core/sqf/monitor/linux/mlio.cxx        |   2 -
 core/sqf/monitor/linux/montim.cxx      |  14 ----
 core/sqf/monitor/linux/msgdef.h        |   2 -
 core/sqf/monitor/linux/reqqueue.cxx    |   8 ---
 core/sqf/monitor/linux/reqqueue.h      |  14 ----
 core/sqf/monitor/linux/reqtmseqnum.cxx |  82 -----------------------
 core/sqf/monitor/linux/testspx.cxx     |   3 -
 core/sqf/monitor/linux/testtm.cxx      |   3 -
 core/sqf/monitor/test/tmSyncTest.cxx   |   3 -
 core/sqf/src/seabed/src/apictr.cpp     |   1 -
 core/sqf/src/seabed/src/labelmaps.cpp  |   4 --
 core/sqf/src/seabed/src/msmon.cpp      |  43 ------------
 core/sqf/src/tm/tminfo.cpp             |   4 --
 20 files changed, 359 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/export/include/seabed/ms.h
----------------------------------------------------------------------
diff --git a/core/sqf/export/include/seabed/ms.h b/core/sqf/export/include/seabed/ms.h
index 05bca14..e00bac9 100644
--- a/core/sqf/export/include/seabed/ms.h
+++ b/core/sqf/export/include/seabed/ms.h
@@ -418,7 +418,6 @@ typedef enum {
     MS_ReqType_Stfsd,
     MS_ReqType_TmLeader,
     MS_ReqType_TmReady,
-    MS_ReqType_TmSeqNum,
     MS_ReqType_TmSync,
     MS_ReqType_TransInfo,
     MS_ReqType_MonStats,
@@ -1097,12 +1096,6 @@ SB_DIAG_UNUSED;
 #endif
 
 //
-// Call this to get tm seq number
-//
-SB_Export int msg_mon_get_tm_seq(int *tm_seq)
-SB_DIAG_UNUSED;
-
-//
 // Call this to get trans info for process
 //
 SB_Export int msg_mon_get_trans_info_process(char                   *name,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/clio.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/clio.cxx b/core/sqf/monitor/linux/clio.cxx
index 672c543..b05a874 100644
--- a/core/sqf/monitor/linux/clio.cxx
+++ b/core/sqf/monitor/linux/clio.cxx
@@ -1913,9 +1913,6 @@ int Local_IO_To_Monitor::size_of_msg( struct message_def *pp_msg, bool reply) {
             case ReplyType_Startup:
                 lv_len = lv_preamble + sizeof(pp_msg->u.reply.u.startup_info);
                 break;
-            case ReplyType_TmSeqNum:
-                lv_len = lv_preamble + sizeof(pp_msg->u.reply.u.tm_seqnum);
-                break;
             case ReplyType_TmSync:
                 lv_len = lv_preamble + sizeof(pp_msg->u.reply.u.tm_sync);
                 break;
@@ -2006,9 +2003,6 @@ int Local_IO_To_Monitor::size_of_msg( struct message_def *pp_msg, bool reply) {
             case ReqType_TmReady:
                 lv_len = lv_preamble + sizeof(pp_msg->u.request.u.tm_ready);
                 break;
-            case ReqType_TmSeqNum:
-                lv_len = lv_preamble + sizeof(pp_msg->u.reply.u.tm_seqnum);
-                break;
             case ReqType_TmSync:
                 lv_len = lv_preamble + sizeof(pp_msg->u.request.u.tm_sync);
                 break;
@@ -2251,7 +2245,6 @@ const char * Local_IO_To_Monitor::reqTypes_[] = {
     "Stfsd",
     "TmLeader",
     "TmReady",
-    "TmSeqNum",
     "TmSync",
     "TransInfo",
     "MonStats",
@@ -2269,7 +2262,6 @@ const char * Local_IO_To_Monitor::replyTypes_[] = {
     "ProcessInfo",
     "Open",
     "OpenInfo",
-    "TmSeqNum",
     "TmSync",
     "TransInfo",
     "Stfsd",

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/cluster.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/cluster.cxx b/core/sqf/monitor/linux/cluster.cxx
index 93362a3..647f7c9 100644
--- a/core/sqf/monitor/linux/cluster.cxx
+++ b/core/sqf/monitor/linux/cluster.cxx
@@ -375,26 +375,6 @@ void CCluster::NodeReady( CNode *spareNode )
 }
 
 
-long CCluster::AssignTmSeqNumber( void )
-{
-    struct sync_def sync;
-    
-    const char method_name[] = "CCluster::AssignTmSeqNumber";
-    TRACE_ENTRY;
-
-    sync.type = SyncType_TmSeqNum;
-    sync.length = 0;
-    syncCycle_.lock();
-    exchangeTmSyncData( &sync );
-    syncCycle_.unlock();
-
-    if (trace_settings & TRACE_ENTRY_EXIT)
-        trace_printf("%s@%d" " - Exit - sequence number = "  "%d" "\n", method_name, __LINE__, TmSeqAssigned[MyPNID]);
-    TRACE_EXIT;
-    return TmSeqAssigned[MyPNID];
-}
-
-
 // Assigns a new TMLeader if given pnid is same as TmLeaderNid 
 // TmLeader is a logical node num. 
 // pnid has gone down, so if that node was previously the TM leader, a new one needs to be chosen.
@@ -495,10 +475,8 @@ CCluster::CCluster (void)
       CurProcs (0),
       cfgPNodes_ (-1),
       NodeMap (NULL),
-      LastTmSeqNum (-1),
       TmLeaderNid (0), // nid 0 is the defacto leader. 
       tmReadyCount_(0),
-      TmSeqAssigned (NULL ),
       minRecvCount_(4096),
       recvBuffer_(NULL),
       recvBuffer2_(NULL),
@@ -623,33 +601,6 @@ CCluster::CCluster (void)
     recvBuffer_ = new struct sync_buffer_def[NumNodes];
     recvBuffer2_ = new struct sync_buffer_def[NumNodes];
 
-    TmSeqAssigned = new int [NumNodes];
-
-
-
-    // Read initialization file
-    snprintf(fname, sizeof(fname), "%s/monitor.ini",getenv("MPI_TMPDIR"));
-    ini = fopen(fname, "r");
-    if( ini )
-    {
-        for (i=0; i<=MyPNID; i++)
-        {
-            fgets(buffer,32,ini);
-            LastTmSeqNum = atol( &buffer[13] );
-        }
-        fclose(ini);
-    }
-    if( LastTmSeqNum == -1 )
-    {
-        LastTmSeqNum = 0;
-
-        char buf[MON_STRING_BUF_SIZE];
-        snprintf(buf, sizeof(buf), "[CCluster::CCluster], Error= No monitor.ini found, setting to defaults. \n");
-        mon_log_write(MON_CLUSTER_CLUSTER_2, SQ_LOG_ERR, buf);  
-    }
-    if (trace_settings & TRACE_INIT)
-       trace_printf("%s@%d" " - Initialized LastTmSeqNum="  "%d" "\n", method_name, __LINE__, LastTmSeqNum);
-    
     TRACE_EXIT;
 }
 
@@ -672,32 +623,6 @@ CCluster::~CCluster (void)
         delete [] NodeMap;
         NodeMap = NULL;
     }
-    
-    delete [] TmSeqAssigned;
-
-
-
-    // Read initialization file
-    snprintf(fname,sizeof(fname),"%s/monitor.ini",getenv("MPI_TMPDIR"));
-    ini = open(fname, O_WRONLY | O_SYNC | O_CREAT, S_IRUSR | S_IWUSR );
-    if( ini != -1 )
-    {
-        LOCKFILE(ini);
-        if (ret == -1)
-        {
-            char buf[MON_STRING_BUF_SIZE];
-            snprintf(buf, sizeof(buf), "[CCluster::~CCluster], Error= Can't lock monitor.ini file. \n");
-            mon_log_write(MON_CLUSTER_UCLUSTER, SQ_LOG_ERR, buf); 
-        }
-        pos = lseek(ini,(long)(24*MyPNID),SEEK_SET);
-        if( pos != -1 )
-        {
-            snprintf (buf, sizeof(buf), "%3.3d:TmSeqNum:%10.10d\n", MyPNID, LastTmSeqNum);
-            write(ini,buf,strlen(buf));
-        }
-        UNLOCKFILE(ini);
-        close(ini);
-    }
 
     delete [] recvBuffer2_;
     delete [] recvBuffer_;
@@ -716,21 +641,6 @@ int CCluster::incrGetVerifierNum()
     return verifierNum_;
 }
 
-void CCluster::CoordinateTmSeqNumber( int pnid )
-{
-    const char method_name[] = "CCluster::CoordinateTmSeqNumber";
-    TRACE_ENTRY;
-
-    LastTmSeqNum++;
-    if( LastTmSeqNum >= MAX_SEQ_VALUE )
-    {
-        LastTmSeqNum = 1;
-    }
-    TmSeqAssigned[pnid] = LastTmSeqNum;
-
-    TRACE_EXIT;
-}
-
 // For a reintegrated monitor node, following the first sync cycle, obtain the
 // current sync cycle sequence number.   And verify that all nodes agree
 // on the sequence number.
@@ -2297,11 +2207,6 @@ void CCluster::HandleOtherNodeMsg (struct internal_msg_def *recv_msg,
                          recv_msg->u.sync.type);
         switch (recv_msg->u.sync.type )
         {
-        case SyncType_TmSeqNum:
-            if (trace_settings & (TRACE_SYNC | TRACE_TMSYNC))
-                trace_printf("%s@%d - TMSYNC(TmSeqNum) on Node %s (pnid=%d)\n", method_name, __LINE__, Node[pnid]->GetName(), pnid);
-            CoordinateTmSeqNumber(pnid);
-            break;
         case SyncType_TmData:
             if (trace_settings & (TRACE_SYNC | TRACE_TMSYNC))
                 trace_printf("%s@%d - TMSYNC(TmData) on Node %s (pnid=%d)\n", method_name, __LINE__, Node[pnid]->GetName(), pnid);
@@ -2638,11 +2543,6 @@ void CCluster::HandleMyNodeMsg (struct internal_msg_def *recv_msg,
                          , method_name, __LINE__, Node[pnid]->GetName(), pnid, recv_msg->u.sync.type);
         switch (recv_msg->u.sync.type )
         {
-        case SyncType_TmSeqNum:
-            if (trace_settings & (TRACE_SYNC | TRACE_TMSYNC))
-                trace_printf("%s@%d    - TMSYNC(TmSeqNum) on Node %s (pnid=%d)\n", method_name, __LINE__, Node[MyPNID]->GetName(), MyPNID);
-            CoordinateTmSeqNumber(pnid);
-            break;
         case SyncType_TmData:
             if (trace_settings & (TRACE_SYNC | TRACE_TMSYNC))
                 trace_printf("%s@%d    - TMSYNC(TmData) on Node %s (pnid=%d)\n", method_name, __LINE__, Node[MyPNID]->GetName(), MyPNID);

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/cluster.h
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/cluster.h b/core/sqf/monitor/linux/cluster.h
index eba2d5c..35ac496 100755
--- a/core/sqf/monitor/linux/cluster.h
+++ b/core/sqf/monitor/linux/cluster.h
@@ -108,7 +108,6 @@ public:
     void ArmWakeUpSignal (void);
 #endif
     void AssignTmLeader( int pnid );
-    long AssignTmSeqNumber( void );
     void stats();
     void CompleteSyncCycle()
         { syncCycle_.lock(); syncCycle_.wait(); syncCycle_.unlock(); }
@@ -209,10 +208,8 @@ private:
     int     CurProcs;       // Current # if processes alive in MPI_COMM_WORLD
     int     cfgPNodes_;     // # of physical nodes configured
     int    *NodeMap;        // Mapping of Node ranks to COMM_WORLD ranks
-    int     LastTmSeqNum;   // Last used TM cluster seq. number
     int     TmLeaderNid;    // Nid of currently assigned TM Leader node
     int     tmReadyCount_;  // # of DTM processes ready for transactions
-    int    *TmSeqAssigned;  // TM seq. # collision assignment array
     size_t  minRecvCount_;  // minimum size of receive buffer for allgather
 
     // Pointer to array of "sync_buffer_def" structures.  Used by
@@ -344,7 +341,6 @@ private:
     void setNewSock(int nid);
  
 
-    void CoordinateTmSeqNumber( int nid );
     unsigned long long EnsureAndGetSeqNum(cluster_state_def_t nodestate[]);
 
     void SetupCommWorld( void );

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/getseq.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/getseq.cxx b/core/sqf/monitor/linux/getseq.cxx
index 9342760..5f8f5f3 100644
--- a/core/sqf/monitor/linux/getseq.cxx
+++ b/core/sqf/monitor/linux/getseq.cxx
@@ -192,53 +192,6 @@ void process_startup (int argc, char *argv[])
     }
 }
 
-int get_seq_number (void)
-{
-    int count;
-    MPI_Status status;
-
-    printf ("[%s] sending get TM seq num message.\n", MyName);
-    fflush (stdout);
-
-
-    gp_local_mon_io->acquire_msg( &msg );
-
-    msg->type = MsgType_Service;
-    msg->noreply = false;
-    msg->reply_tag = REPLY_TAG;
-    msg->u.request.type = ReqType_TmSeqNum;
-
-
-    gp_local_mon_io->send_recv( msg );
-    count = sizeof (*msg);
-    status.MPI_TAG = msg->reply_tag;
-
-    if ((status.MPI_TAG == REPLY_TAG) &&
-        (count == sizeof (struct message_def)))
-    {
-        if ((msg->type == MsgType_Service) &&
-            (msg->u.reply.type == ReplyType_TmSeqNum))
-        {
-            return msg->u.reply.u.tm_seqnum;
-        }
-        else
-        {
-            printf
-                ("[%s] Invalid MsgType(%d)/ReplyType(%d) for TM seq num message\n",
-                 MyName, msg->type, msg->u.reply.type);
-        }
-    }
-    else
-    {
-        printf ("[%s] TM seq num reply invalid.\n", MyName);
-    }
-    fflush (stdout);
-
-    gp_local_mon_io->release_msg(msg);
-
-    return -1;
-}
-
 void flush_incoming_msgs( void )
 {
     int count;
@@ -487,13 +440,6 @@ int main (int argc, char *argv[])
 
     process_startup (argc, argv);
 
-    // get and display TM cluster sequence number
-    for( i=0; i<10; i++ )
-    {
-        printf("[%s] TM Seq #=%d\n",MyName,get_seq_number());
-        fflush(stdout);
-    }
-
     // exit my process
     exit_process ();
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/internal.h
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/internal.h b/core/sqf/monitor/linux/internal.h
index 7aeaafb..9b370e7 100644
--- a/core/sqf/monitor/linux/internal.h
+++ b/core/sqf/monitor/linux/internal.h
@@ -66,7 +66,6 @@ enum InternalType
 enum SyncType
 {
     SyncType_NULL,                  // No sync requested
-    SyncType_TmSeqNum,              // sync to exchange TM cluster seq #
     SyncType_TmData,                // sync to exchange TM data amoung TMs
     SyncType_TmSyncState            // sync the current TmSync state across the cluster
 };

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/makefile
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/makefile b/core/sqf/monitor/linux/makefile
index 614b945..4b0c7aa 100755
--- a/core/sqf/monitor/linux/makefile
+++ b/core/sqf/monitor/linux/makefile
@@ -143,7 +143,6 @@ MONITORSRC += reqshutdown.cxx
 MONITORSRC += reqstartup.cxx
 MONITORSRC += reqtmleader.cxx
 MONITORSRC += reqtmready.cxx
-MONITORSRC += reqtmseqnum.cxx
 MONITORSRC += reqtmsync.cxx
 MONITORSRC += reqzoneinfo.cxx
 MONITORSRC += replicate.cxx
@@ -204,7 +203,6 @@ MONITOROBJS += $(OUTDIR)/reqshutdown.o
 MONITOROBJS += $(OUTDIR)/reqstartup.o
 MONITOROBJS += $(OUTDIR)/reqtmleader.o
 MONITOROBJS += $(OUTDIR)/reqtmready.o
-MONITOROBJS += $(OUTDIR)/reqtmseqnum.o
 MONITOROBJS += $(OUTDIR)/reqtmsync.o
 MONITOROBJS += $(OUTDIR)/reqzoneinfo.o
 ifeq ($(USE_FORK_SUSPEND_RESUME),1)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/mlio.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/mlio.cxx b/core/sqf/monitor/linux/mlio.cxx
index 47deba3..033b635 100644
--- a/core/sqf/monitor/linux/mlio.cxx
+++ b/core/sqf/monitor/linux/mlio.cxx
@@ -109,7 +109,6 @@ const int SQ_LocalIOToClient::serviceRequestSize[] = {
    sizeof(REQTYPE) + sizeof( Stfsd_def ),           // ReqType_Stfsd
    sizeof(REQTYPE) + sizeof( TmLeader_def ),        // ReqType_TmLeader
    sizeof(REQTYPE) + sizeof( TmReady_def ),         // ReqType_TmReady
-   sizeof(REQTYPE) + sizeof( int ),                 // ReqType_TmSeqNum
    sizeof(REQTYPE) + sizeof( TmSync_def ),          // ReqType_TmSync
    sizeof(REQTYPE) + sizeof( TransInfo_def ),       // ReqType_TransInfo
    sizeof(REQTYPE) + sizeof( MonStats_def ),        // ReqType_MonStats
@@ -130,7 +129,6 @@ const int SQ_LocalIOToClient::serviceReplySize[] = {
    sizeof(REPLYTYPE) + sizeof( ProcessInfo_reply_def ), // ReplyType_ProcessInfo
    sizeof(REPLYTYPE) + sizeof( Open_reply_def ),        // ReplyType_Open
    sizeof(REPLYTYPE) + sizeof( OpenInfo_reply_def ),    // ReplyType_OpenInfo
-   sizeof(REPLYTYPE) + sizeof( int ),                   // ReplyType_TmSeqNum
    sizeof(REPLYTYPE) + sizeof( TmSync_reply_def ),      // ReplyType_TmSync 
    sizeof(REPLYTYPE) + sizeof( TransInfo_reply_def ),   // ReplyType_TransInfo 
    sizeof(REPLYTYPE) + sizeof( Stfsd_reply_def ),       // ReplyType_Stfsd

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/montim.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/montim.cxx b/core/sqf/monitor/linux/montim.cxx
index 12141f4..3341f78 100644
--- a/core/sqf/monitor/linux/montim.cxx
+++ b/core/sqf/monitor/linux/montim.cxx
@@ -115,7 +115,6 @@ static const string ReqType_Set = " - Set";
 static const string ReqType_Shutdown = " - Shutdown";
 static const string ReqType_Startup = " - Startup";
 static const string ReqType_TmLeader = " - TmLeader";
-static const string ReqType_TmSeqNum = " - TmSeqNum";
 static const string ReqType_TmSync = " - TmSync";
 static const string ReqType_Unknown = " - Unknown request";
 static const string ReplyType_TmSync = " - Unsolicited TmSync Reply";
@@ -521,19 +520,6 @@ processSpecial( ProcessInfo *proc, string intime, string line )
       }
       proc->lastReq = ReqType_TmLeader;
     }
-    else if(line.find(ReqType_TmSeqNum) != string::npos)
-    {
-/*
-      cout << ReqType_TmSeqNum << " was received" 
-           << " with useMPI=" << proc->useMPI << endl;
-*/
-      if ((reqInfo = proc->reqInfoMap[ReqType_TmSeqNum]) == NULL)
-      {
-        proc->reqInfoMap[ReqType_TmSeqNum] = 
-           mkReqInfo( ReqType_TmSeqNum, "ReqType_TmSeqNum" );
-      }
-      proc->lastReq = ReqType_TmSeqNum;
-    }
     else if(line.find(ReqType_TmSync) != string::npos)
     {
 /*

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/msgdef.h
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/msgdef.h b/core/sqf/monitor/linux/msgdef.h
index 9aa0607..d7d6089 100755
--- a/core/sqf/monitor/linux/msgdef.h
+++ b/core/sqf/monitor/linux/msgdef.h
@@ -252,7 +252,6 @@ typedef enum {
     ReqType_Stfsd,                          // process stfsd request
     ReqType_TmLeader,                       // request to become the TM leader
     ReqType_TmReady,                        // request to indicate TM ready for transactions
-    ReqType_TmSeqNum,                       // request the next TM cluster sequence number
     ReqType_TmSync,                         // request to sync data across all TM's in cluster
     ReqType_TransInfo,                      // request transaction enlistment information
     ReqType_MonStats,                       // get monitor statistics
@@ -278,7 +277,6 @@ typedef enum {
     ReplyType_ProcessInfo,                  // reply with info on list of processes
     ReplyType_Open,                         // reply with open server information
     ReplyType_OpenInfo,                     // reply with list of opens for a process
-    ReplyType_TmSeqNum,                     // reply with the next TM cluster sequence number
     ReplyType_TmSync,                       // reply from unsolicited TmSync message
     ReplyType_TransInfo,                    // reply with transaction enlistment process list
     ReplyType_Stfsd,                        // reply with stfsd info

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/reqqueue.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/reqqueue.cxx b/core/sqf/monitor/linux/reqqueue.cxx
index 2684633..907173c 100644
--- a/core/sqf/monitor/linux/reqqueue.cxx
+++ b/core/sqf/monitor/linux/reqqueue.cxx
@@ -2746,11 +2746,6 @@ CExternalReq *CReqQueue::prepExternalReq(CExternalReq::reqQueueMsg_t msgType,
             request->setConcurrent(reqConcurrent[msg->u.request.type]);
             break;
 
-        case ReqType_TmSeqNum:
-            request = new CExtTmSeqNumReq(msgType, pid, msg);
-            request->setConcurrent(reqConcurrent[msg->u.request.type]);
-            break;
-
         case ReqType_TmSync:
             request = new CExtTmSyncReq(msgType, pid, msg);
             request->setConcurrent(reqConcurrent[msg->u.request.type]);
@@ -3617,7 +3612,6 @@ const bool CReqQueue::reqConcurrent[] = {
    true,     // ReqType_Startup
    false,    // ReqType_Stfsd
    false,    // ReqType_TmLeader
-   false,    // ReqType_TmSeqNum
    false,    // ReqType_TmSync
    false,    // ReqType_TransInfo
    true,     // ReqType_MonStats
@@ -3654,7 +3648,6 @@ const bool CReqQueue::reqConcurrent[] = {
    false,    // ReqType_Stfsd
    false,    // ReqType_TmLeader
    false,    // ReqType_TmReady,
-   false,    // ReqType_TmSeqNum
    false,    // ReqType_TmSync
    false,    // ReqType_TransInfo
    false,    // ReqType_MonStats
@@ -3710,7 +3703,6 @@ const char * CReqQueue::svcReqType[] = {
     "Stfsd",
     "TmLeader",
     "TmReady",
-    "TmSeqNum",
     "TmSync",
     "TransInfo",
     "MonStats",

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/reqqueue.h
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/reqqueue.h b/core/sqf/monitor/linux/reqqueue.h
index 4f5a21b..6e2426c 100755
--- a/core/sqf/monitor/linux/reqqueue.h
+++ b/core/sqf/monitor/linux/reqqueue.h
@@ -534,19 +534,6 @@ private:
     int nid_;
 };
 
-class CExtTmSeqNumReq: public CExternalReq
-{
-public:
-    CExtTmSeqNumReq (reqQueueMsg_t msgType, int pid,
-                     struct message_def *msg );
-    virtual ~CExtTmSeqNumReq();
-
-    void performRequest();
-
-private:
-    void populateRequestString( void );
-};
-
 class CExtTmSyncReq: public CExternalReq
 {
 public:
@@ -1182,7 +1169,6 @@ private:
       RQER   CExtShutdownReq
       RQES   CExtStartupReq
       RQET   CExtTmLeaderReq
-      RQEU   CExtTmSeqNumReq
       RQEV   CExtTmSyncReq
       RQEW   CExtZoneInfoReq
       RQEX   (unused)

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/reqtmseqnum.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/reqtmseqnum.cxx b/core/sqf/monitor/linux/reqtmseqnum.cxx
deleted file mode 100755
index c59cd25..0000000
--- a/core/sqf/monitor/linux/reqtmseqnum.cxx
+++ /dev/null
@@ -1,82 +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 @@@
-//
-///////////////////////////////////////////////////////////////////////////////
-
-#include <stdio.h>
-#include "reqqueue.h"
-#include "montrace.h"
-#include "monsonar.h"
-#include "monlogging.h"
-
-extern CMonStats *MonStats;
-extern CMonitor *Monitor;
-
-CExtTmSeqNumReq::CExtTmSeqNumReq (reqQueueMsg_t msgType, int pid,
-                                  struct message_def *msg )
-    : CExternalReq(msgType, pid, msg)
-{
-    // Add eyecatcher sequence as a debugging aid
-    memcpy(&eyecatcher_, "RQEU", 4);
-}
-
-CExtTmSeqNumReq::~CExtTmSeqNumReq()
-{
-    // Alter eyecatcher sequence as a debugging aid to identify deleted object
-    memcpy(&eyecatcher_, "rqeu", 4);
-}
-
-void CExtTmSeqNumReq::populateRequestString( void )
-{
-    char strBuf[MON_STRING_BUF_SIZE/2] = { 0 };
-
-    snprintf( strBuf, sizeof(strBuf), 
-              "ExtReq(%s) req #=%ld requester(pid=%d)"
-              , CReqQueue::svcReqType[reqType_], getId(), pid_ );
-    requestString_.assign( strBuf );
-}
-
-
-void CExtTmSeqNumReq::performRequest()
-{
-    const char method_name[] = "CExtTmSeqNumReq::performRequest";
-    TRACE_ENTRY;
-
-    // Record statistics (sonar counters)
-    if (sonar_verify_state(SONAR_ENABLED | SONAR_MONITOR_ENABLED))
-       MonStats->req_type_tmseqnum_Incr();
-
-    if (trace_settings & (TRACE_REQUEST | TRACE_PROCESS))
-    {
-        trace_printf("%s@%d request #%ld: TmSeqNum\n",
-                     method_name, __LINE__, id_);
-    }
-
-    msg_->u.reply.type = ReplyType_TmSeqNum;
-    msg_->u.reply.u.tm_seqnum = Monitor->AssignTmSeqNumber();
-
-    // Send reply to requester
-    lioreply(msg_, pid_);
-
-    TRACE_EXIT;
-}

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/testspx.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/testspx.cxx b/core/sqf/monitor/linux/testspx.cxx
index 4a19bc3..c0351c4 100644
--- a/core/sqf/monitor/linux/testspx.cxx
+++ b/core/sqf/monitor/linux/testspx.cxx
@@ -782,9 +782,6 @@ const char *RequestTypeString( REQTYPE type )
         case ReqType_TmLeader:
             str = "ReqType_TmLeader";
             break;
-        case ReqType_TmSeqNum:
-            str = "ReqType_TmSeqNum";
-            break;
         case ReqType_TmSync:
             str = "ReqType_TmSync";
             break;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/linux/testtm.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/testtm.cxx b/core/sqf/monitor/linux/testtm.cxx
index ff5a5c6..bd5ec8e 100644
--- a/core/sqf/monitor/linux/testtm.cxx
+++ b/core/sqf/monitor/linux/testtm.cxx
@@ -1346,9 +1346,6 @@ void RequestTypeString( char *str, REQTYPE type )
         case ReqType_TmLeader:
             sprintf(str, "%s", "ReqType_TmLeader" );
             break;
-        case ReqType_TmSeqNum:
-            sprintf(str, "%s", "ReqType_TmSeqNum" );
-            break;
         case ReqType_TmSync:
             sprintf(str, "%s", "ReqType_TmSync" );
             break;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/monitor/test/tmSyncTest.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/test/tmSyncTest.cxx b/core/sqf/monitor/test/tmSyncTest.cxx
index f0b46ee..d833380 100755
--- a/core/sqf/monitor/test/tmSyncTest.cxx
+++ b/core/sqf/monitor/test/tmSyncTest.cxx
@@ -839,9 +839,6 @@ void RequestTypeString( char *str, REQTYPE type )
         case ReqType_TmLeader:
             sprintf(str, "%s", "ReqType_TmLeader" );
             break;
-        case ReqType_TmSeqNum:
-            sprintf(str, "%s", "ReqType_TmSeqNum" );
-            break;
         case ReqType_TmSync:
             sprintf(str, "%s", "ReqType_TmSync" );
             break;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/src/seabed/src/apictr.cpp
----------------------------------------------------------------------
diff --git a/core/sqf/src/seabed/src/apictr.cpp b/core/sqf/src/seabed/src/apictr.cpp
index 5873b98..1bb519c 100644
--- a/core/sqf/src/seabed/src/apictr.cpp
+++ b/core/sqf/src/seabed/src/apictr.cpp
@@ -133,7 +133,6 @@ static const char *ga_sb_api_ctr_names[] = {
         "msg_mon_get_process_info_type",
         "msg_mon_get_process_name",
         "msg_mon_get_process_name2",
-        "msg_mon_get_tm_seq",
         "msg_mon_get_trans_info_process",
         "msg_mon_get_trans_info_transid",
         "msg_mon_get_zone_info",

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/src/seabed/src/labelmaps.cpp
----------------------------------------------------------------------
diff --git a/core/sqf/src/seabed/src/labelmaps.cpp b/core/sqf/src/seabed/src/labelmaps.cpp
index 19fd4d6..133f1d8 100644
--- a/core/sqf/src/seabed/src/labelmaps.cpp
+++ b/core/sqf/src/seabed/src/labelmaps.cpp
@@ -355,7 +355,6 @@ static const char *ga_ms_mon_req_type_labels[] = {
     "MS_ReqType_Stfsd",
     "MS_ReqType_TmLeader",
     "MS_ReqType_TmReady",
-    "MS_ReqType_TmSeqNum",
     "MS_ReqType_TmSync",
     "MS_ReqType_TransInfo",
     "MS_ReqType_MonStats",
@@ -388,7 +387,6 @@ static const char *ga_ms_mon_req_type_short_labels[] = {
     "Stfsd",
     "TmLeader",
     "TmReady",
-    "TmSeqNum",
     "TmSync",
     "TransInfo",
     "MonStats",
@@ -447,7 +445,6 @@ static const char *ga_sb_msmon_reply_type_labels[] = {
     "ProcessInfo",
     "Open",
     "OpenInfo",
-    "TmSeqNum",
     "TmSync",
     "TransInfo",
     "Stfsd",
@@ -565,7 +562,6 @@ static const char *ga_sb_utrace_api_mon_reqtype_labels[] = {
     "ReqType_Stfsd",
     "ReqType_TmLeader",
     "ReqType_TmReady",
-    "ReqType_TmSeqNum",
     "ReqType_TmSync",
     "ReqType_TransInfo",
     "ReqType_MonStats",

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/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 2f41fb5..d4dae3b 100644
--- a/core/sqf/src/seabed/src/msmon.cpp
+++ b/core/sqf/src/seabed/src/msmon.cpp
@@ -3274,49 +3274,6 @@ int msg_mon_get_ref_count(SB_Phandle_Type *pp_phandle) {
 }
 
 //
-// Purpose: get tm seq number
-//
-SB_Export int msg_mon_get_tm_seq(int *pp_tm_seq) {
-    const char   *WHERE = "msg_mon_get_tm_seq";
-    Mon_Msg_Type *lp_msg;
-    int           lv_mpierr;
-    SB_API_CTR   (lv_zctr, MSG_MON_GET_TM_SEQ);
-
-    SB_UTRACE_API_ADD2(SB_UTRACE_API_OP_MSG_MON_GET_TM_SEQ, 0);
-
-    if (gv_ms_trace_mon)
-        trace_where_printf(WHERE, "ENTER tm-seq=%p\n", pfp(pp_tm_seq));
-    if (!gv_ms_mon_calls_ok) // msg_mon_get_tm_seq
-        return ms_err_rtn_msg(WHERE, "msg_init() or startup not called or shutdown",
-                              XZFIL_ERR_INVALIDSTATE);
-
-    Mon_Msg_Auto lv_msg;
-    lp_msg = &lv_msg;
-    lp_msg->type = MsgType_Service;
-    lp_msg->noreply = false;
-    lp_msg->u.request.type = ReqType_TmSeqNum;
-    if (gv_ms_trace_mon)
-        trace_where_printf(WHERE, "send tm-seq-num req to mon\n");
-    lv_mpierr = msg_mon_sendrecv_mon(WHERE,
-                                     "tm-seq-num",
-                                     lp_msg,
-                                     lv_msg.get_error());
-    if (msg_mon_msg_ok(WHERE,
-                       "tm-seq-num req",
-                       &lv_mpierr,
-                       lp_msg,
-                       MsgType_Service,
-                       ReplyType_TmSeqNum)) {
-        int lv_tm_seq = lp_msg->u.reply.u.tm_seqnum;
-        if (gv_ms_trace_mon)
-            trace_where_printf(WHERE, "EXIT OK tm-seq-num req, tm-seq-num=%d\n",
-                               lv_tm_seq);
-        *pp_tm_seq = lv_tm_seq;
-    }
-    return ms_err_mpi_rtn_msg(WHERE, "EXIT", lv_mpierr);
-}
-
-//
 // Purpose: get trans info
 //
 static int msg_mon_get_trans_info_com(const char             *pp_where,

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/c2704e71/core/sqf/src/tm/tminfo.cpp
----------------------------------------------------------------------
diff --git a/core/sqf/src/tm/tminfo.cpp b/core/sqf/src/tm/tminfo.cpp
index 384bae2..7d013e9 100644
--- a/core/sqf/src/tm/tminfo.cpp
+++ b/core/sqf/src/tm/tminfo.cpp
@@ -1363,8 +1363,6 @@ void TM_Info::init_and_recover_rms()
       lv_rmid=(lv_error) ? 0 : (atoi(la_value));
        */   
       lv_rmid.iv_rmid = 0;
-      //if (lv_rmid.iv_rmid == 0) //TODO
-      //    msg_mon_get_tm_seq((int *) &lv_rmid.iv_rmid);
       lv_rmid.s.iv_nid = nid();
       lv_rmid.s.iv_num = lv_index;
 
@@ -4249,8 +4247,6 @@ void TM_Info::CheckFailed_RMs(char *pp_rmname)
       {
          // If no RMID was configured, allocate one now
          if (lv_rmid == 0)
-             //M8_TODO encapsulate and clean up rmid allocation
-             //msg_mon_get_tm_seq(&lv_rmid); 
          {
              RMID llv_rmid;
              llv_rmid.s.iv_nid = nid(); //TMs nid


[2/2] incubator-trafodion git commit: Merge [TRAFODION-2532] PR 1025 Clean up 'monitor.ini not found' logic

Posted by db...@apache.org.
Merge [TRAFODION-2532] PR 1025 Clean up 'monitor.ini not found' logic


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

Branch: refs/heads/master
Commit: 3f75c15a64f9fa8797275f7900c6160942c773f8
Parents: 4716b3a c2704e7
Author: Dave Birdsall <db...@apache.org>
Authored: Tue Mar 28 23:19:20 2017 +0000
Committer: Dave Birdsall <db...@apache.org>
Committed: Tue Mar 28 23:19:20 2017 +0000

----------------------------------------------------------------------
 core/sqf/export/include/seabed/ms.h    |   7 --
 core/sqf/monitor/linux/clio.cxx        |   8 ---
 core/sqf/monitor/linux/cluster.cxx     | 100 ----------------------------
 core/sqf/monitor/linux/cluster.h       |   4 --
 core/sqf/monitor/linux/getseq.cxx      |  54 ---------------
 core/sqf/monitor/linux/internal.h      |   1 -
 core/sqf/monitor/linux/makefile        |   2 -
 core/sqf/monitor/linux/mlio.cxx        |   2 -
 core/sqf/monitor/linux/montim.cxx      |  14 ----
 core/sqf/monitor/linux/msgdef.h        |   2 -
 core/sqf/monitor/linux/reqqueue.cxx    |   8 ---
 core/sqf/monitor/linux/reqqueue.h      |  14 ----
 core/sqf/monitor/linux/reqtmseqnum.cxx |  82 -----------------------
 core/sqf/monitor/linux/testspx.cxx     |   3 -
 core/sqf/monitor/linux/testtm.cxx      |   3 -
 core/sqf/monitor/test/tmSyncTest.cxx   |   3 -
 core/sqf/src/seabed/src/apictr.cpp     |   1 -
 core/sqf/src/seabed/src/labelmaps.cpp  |   4 --
 core/sqf/src/seabed/src/msmon.cpp      |  43 ------------
 core/sqf/src/tm/tminfo.cpp             |   4 --
 20 files changed, 359 deletions(-)
----------------------------------------------------------------------