You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by zw...@apache.org on 2010/08/04 01:22:35 UTC

svn commit: r982077 - in /trafficserver/traffic/trunk/proxy: ./ mgmt2/cluster/ mgmt2/cop/ mgmt2/preparse/ mgmt2/tools/ mgmt2/utils/ mgmt2/web2/

Author: zwoop
Date: Tue Aug  3 23:22:34 2010
New Revision: 982077

URL: http://svn.apache.org/viewvc?rev=982077&view=rev
Log:
TS-400 Checkpoint 10 in cleanup.

Modified:
    trafficserver/traffic/trunk/proxy/DiagsConfig.cc
    trafficserver/traffic/trunk/proxy/mgmt2/cluster/ClusterCom.cc
    trafficserver/traffic/trunk/proxy/mgmt2/cluster/VMap.cc
    trafficserver/traffic/trunk/proxy/mgmt2/cop/TrafficCop.cc
    trafficserver/traffic/trunk/proxy/mgmt2/preparse/IPRange.cc
    trafficserver/traffic/trunk/proxy/mgmt2/preparse/StoreReadConfig.cc
    trafficserver/traffic/trunk/proxy/mgmt2/tools/SysAPI.cc
    trafficserver/traffic/trunk/proxy/mgmt2/utils/WebMgmtUtils.cc
    trafficserver/traffic/trunk/proxy/mgmt2/utils/XmlUtils.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/MgmtAllow.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttp.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpRender.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpSession.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpTree.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/WebIntrMain.cc
    trafficserver/traffic/trunk/proxy/mgmt2/web2/WebOverview.cc

Modified: trafficserver/traffic/trunk/proxy/DiagsConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/DiagsConfig.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/DiagsConfig.cc (original)
+++ trafficserver/traffic/trunk/proxy/DiagsConfig.cc Tue Aug  3 23:22:34 2010
@@ -190,6 +190,9 @@ DiagsConfig::reconfigure_diags()
 static int
 diags_config_callback(const char *name, RecDataT data_type, RecData data, void *opaque_token)
 {
+  NOWARN_UNUSED(name);
+  NOWARN_UNUSED(data_type);
+  NOWARN_UNUSED(data);
   DiagsConfig *diagsConfig;
 
   diagsConfig = (DiagsConfig *) opaque_token;

Modified: trafficserver/traffic/trunk/proxy/mgmt2/cluster/ClusterCom.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/cluster/ClusterCom.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/cluster/ClusterCom.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/cluster/ClusterCom.cc Tue Aug  3 23:22:34 2010
@@ -56,7 +56,6 @@ long LastHighestDelta = -1L;
 void *
 drainIncomingChannel(void *arg)
 {
-  int nbytes;
   char message[61440];
   fd_set fdlist;
   void *ret = arg;
@@ -147,7 +146,7 @@ drainIncomingChannel(void *arg)
     if (lmgmt->ccom->cluster_type != NO_CLUSTER &&
         lmgmt->ccom->receive_fd > 0 &&
         FD_ISSET(lmgmt->ccom->receive_fd, &fdlist) &&
-        (nbytes = lmgmt->ccom->receiveIncomingMessage(message, 61440)) > 0) {
+        (lmgmt->ccom->receiveIncomingMessage(message, 61440) > 0)) {
       lmgmt->ccom->handleMultiCastMessage(message);
     } else if (FD_ISSET(lmgmt->ccom->reliable_server_fd, &fdlist)) {
 
@@ -344,6 +343,9 @@ drainIncomingChannel(void *arg)
 int
 cluster_com_port_watcher(const char *name, RecDataT data_type, RecData data, void *cookie)
 {
+  NOWARN_UNUSED(data_type);
+  NOWARN_UNUSED(cookie);
+
   ink_assert(!name);
 
   ink_mutex_acquire(&(lmgmt->ccom->mutex));     /* Grab cluster lock */
@@ -709,13 +711,12 @@ void
 ClusterCom::handleMultiCastMessage(char *message)
 {
   int peer_cluster_port, ccom_port;
-  long delta = 0;
   char *last, *line, ip[1024], hostname[1024];
   char tsver[128] = "Before 2.X";
   char cluster_name[1024] = "UNKNOWN";
   RecordType type;
   ClusterPeerInfo *p;
-  time_t peer_wall_clock, peer_update_time, t;
+  time_t peer_wall_clock,t;
   InkHashTableValue hash_value;
 
   ++MultiCastMessages;
@@ -846,7 +847,6 @@ ClusterCom::handleMultiCastMessage(char 
     mgmt_elog("[ClusterCom::handleMultiCastMessage] Invalid message-line(%d) '%s'\n", __LINE__, line);
     return;
   }
-  peer_update_time = (time_t)tt;
 
   /* Have we see this guy before? */
   ink_mutex_acquire(&(mutex));  /* Grab cluster lock to access hash table */
@@ -885,7 +885,7 @@ ClusterCom::handleMultiCastMessage(char 
   p->ccom_port = ccom_port;
   p->idle_ticks = p->manager_idle_ticks = our_wall_clock;
   p->last_time_recorded = peer_wall_clock;
-  p->delta = delta = peer_wall_clock - our_wall_clock;
+  p->delta = peer_wall_clock - our_wall_clock;
   p->manager_alive = 1;
 
   ink_assert(type == CLUSTER);
@@ -975,12 +975,12 @@ ClusterCom::handleMultiCastStatPacket(ch
         break;
       }
     case RECD_STRING:{         /* String stats not supported for cluster passing */
-        int ccons, test;
+        int ccons;
         char *tmp_msg_val = NULL;
 
         // the types specified are all have a defined constant size
         // coverity[secure_coding]
-        if ((test = sscanf(line, "%d:%d: %n", &tmp_id, (int *) &tmp_type, &ccons)) != 2) {
+        if (sscanf(line, "%d:%d: %n", &tmp_id, (int *) &tmp_type, &ccons) != 2) {
           mgmt_elog("[ClusterCom::handleMultiCastStatPacket] Invalid message-line(%d) '%s'\n", __LINE__, line);
           return;
         }
@@ -1142,7 +1142,6 @@ ClusterCom::handleMultiCastFilePacket(ch
 {
   char *line, file[1024];
   version_t ver, our_ver;
-  time_t mod;
   int64 tt;
   InkHashTableValue hash_value;
   bool file_update_failure;
@@ -1156,7 +1155,7 @@ ClusterCom::handleMultiCastFilePacket(ch
       mgmt_elog("[ClusterCom::handleMultiCastFilePacket] Invalid message-line(%d) '%s'\n", __LINE__, line);
       return;
     }
-    mod = (time_t)tt;
+
     if (configFiles->getRollbackObj(file, &rb)) {
 
       our_ver = rb->getCurrentVersion();
@@ -1409,8 +1408,6 @@ ClusterCom::constructSharedGenericPacket
   int running_sum = 0;          /* Make sure we never go over max */
   char tmp[1024];
   struct in_addr resolved_addr;
-  time_t t;
-  Records *the_records;
 
   /* Insert the standard packet header */
   resolved_addr.s_addr = our_ip;
@@ -1460,7 +1457,7 @@ ClusterCom::constructSharedGenericPacket
   ink_release_assert(running_sum < max);
 
   /* Current time stamp, for xntp like synching */
-  if ((t = time(NULL)) > 0) {
+  if (time(NULL) > 0) {
     snprintf(tmp, sizeof(tmp), "time: %lld\n", (int64)time(NULL));
     ink_strncpy(&message[running_sum], tmp, (max - running_sum));
     running_sum += strlen(tmp);
@@ -1478,12 +1475,6 @@ ClusterCom::constructSharedGenericPacket
    */
   ink_mutex_acquire(&lmgmt->record_data->mutex[packet_type]);
 
-  if (packet_type == CONFIG) {
-    the_records = &(lmgmt->record_data->config_data);
-  } else {
-    the_records = &(lmgmt->record_data->node_data);
-  }
-
   snprintf(tmp, sizeof(tmp), "ctime: %lld\n", (int64)lmgmt->record_data->time_last_config_change);
   ink_strncpy(&message[running_sum], tmp, (max - running_sum));
   running_sum += strlen(tmp);

Modified: trafficserver/traffic/trunk/proxy/mgmt2/cluster/VMap.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/cluster/VMap.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/cluster/VMap.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/cluster/VMap.cc Tue Aug  3 23:22:34 2010
@@ -44,6 +44,8 @@
 int
 vmapEnableHandler(const char *tok, RecDataT data_type, RecData data, void *cookie)
 {
+  NOWARN_UNUSED(data_type);
+  NOWARN_UNUSED(cookie);
   bool before = true;
   ink_assert(!tok);
   if (!lmgmt->virt_map->enabled)

Modified: trafficserver/traffic/trunk/proxy/mgmt2/cop/TrafficCop.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/cop/TrafficCop.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/cop/TrafficCop.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/cop/TrafficCop.cc Tue Aug  3 23:22:34 2010
@@ -201,6 +201,7 @@ chown_file_to_user(const char *file, con
 static void
 sig_child(int signum)
 {
+  NOWARN_UNUSED(signum);
   int pid = 0;
   int status = 0;
 
@@ -266,6 +267,7 @@ sig_alarm_warn(int signum, siginfo_t * t
 sig_alarm_warn(int signum)
 #endif
 {
+  NOWARN_UNUSED(signum);
 #ifdef TRACE_LOG_COP
   cop_log(COP_DEBUG, "Entering sig_alarm_warn(%d)\n", signum);
 #endif
@@ -281,6 +283,7 @@ sig_alarm_warn(int signum)
 static void
 sig_ignore(int signum)
 {
+  NOWARN_UNUSED(signum);
 #ifdef TRACE_LOG_COP
   cop_log(COP_DEBUG, "Entering sig_ignore(%d)\n", signum);
 #endif
@@ -1231,16 +1234,12 @@ test_manager_http_port()
 static int
 heartbeat_manager()
 {
-  uint64 start;
   int err;
 
 #ifdef TRACE_LOG_COP
   cop_log(COP_DEBUG, "Entering heartbeat_manager()\n");
 #endif
-  start = milliseconds();
   err = test_rs_port();
-//     fprintf (stderr, "heartbeat_manager[variable]() [%d ms]\n",
-//              (int) (milliseconds () - start));
 
   if (err < 0) {
     manager_failures += 1;
@@ -1257,10 +1256,7 @@ heartbeat_manager()
     return err;
   }
 #ifndef NO_WEBUI
-  start = milliseconds();
   err = test_manager_http_port();
-//     fprintf (stderr, "heartbeat_manager[http]() [%d ms]\n",
-//              (int) (milliseconds () - start));
 
   if (err < 0) {
     manager_failures += 1;
@@ -1295,17 +1291,12 @@ heartbeat_server()
 // Don't heartbeat the server if we
 // are running in rni only mode
 #ifndef RNI_ONLY
-
-  uint64 start;
   int err;
 
 #ifdef TRACE_LOG_COP
   cop_log(COP_DEBUG, "Entering heartbeat_server()\n");
 #endif
-  start = milliseconds();
   err = test_server_http_port();
-//     fprintf (stderr, "heartbeat_server() [%d ms]\n",
-//              (int) (milliseconds () - start));
 
   if (err < 0) {
     // If the test failed, increment the count of the number of

Modified: trafficserver/traffic/trunk/proxy/mgmt2/preparse/IPRange.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/preparse/IPRange.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/preparse/IPRange.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/preparse/IPRange.cc Tue Aug  3 23:22:34 2010
@@ -87,6 +87,7 @@ read_an_ip(char *line, unsigned int *ip,
 char *
 IPRange::read_table_from_file(int fd, const char *identifier_str, bool localip)
 {
+  NOWARN_UNUSED(localip);
   int i, j, n, rc, s, line_no;
   char c, line[MAXLINESIZE];
   bool end_of_file;

Modified: trafficserver/traffic/trunk/proxy/mgmt2/preparse/StoreReadConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/preparse/StoreReadConfig.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/preparse/StoreReadConfig.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/preparse/StoreReadConfig.cc Tue Aug  3 23:22:34 2010
@@ -53,8 +53,6 @@ parseStorageFile(int fd)
     // parse
 
     char *e = strpbrk(n, " \t\n");
-    int len = e ? e - n : strlen(n);
-    (void) len;
     int64 size = -1;
     while (*e && !isdigit(*e))
       e++;

Modified: trafficserver/traffic/trunk/proxy/mgmt2/tools/SysAPI.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/tools/SysAPI.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/tools/SysAPI.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/tools/SysAPI.cc Tue Aug  3 23:22:34 2010
@@ -1349,12 +1349,14 @@ Net_SetEncryptedRootPassword(char *passw
 int
 Net_SetSMTP_Server(char *server)
 {
+  NOWARN_UNUSED(server);
   return 0;
 }
 
 int
 Net_GetSMTP_Server(char *server)
 {
+  NOWARN_UNUSED(server);
   return 0;
 }
 

Modified: trafficserver/traffic/trunk/proxy/mgmt2/utils/WebMgmtUtils.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/utils/WebMgmtUtils.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/utils/WebMgmtUtils.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/utils/WebMgmtUtils.cc Tue Aug  3 23:22:34 2010
@@ -311,9 +311,9 @@ varFloatFromName(const char *varName, Re
 {
   RecDataT varDataType = RECD_NULL;
   bool found = true;
-  int err = REC_ERR_FAIL;
 
-  err = RecGetRecordDataType((char *) varName, &varDataType);
+  // TODO: should we check for return code / error here?
+  RecGetRecordDataType((char *) varName, &varDataType);
 
   switch (varDataType) {
   case RECD_INT:{
@@ -1255,6 +1255,7 @@ processSpawn(const char *args[],
              EnvBlock * env,
              textBuffer * input_buf, textBuffer * output_buf, bool nowait, bool run_as_root, bool * truncated)
 {
+  NOWARN_UNUSED(run_as_root);
   int status = 0;
 
 #ifndef _WIN32

Modified: trafficserver/traffic/trunk/proxy/mgmt2/utils/XmlUtils.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/utils/XmlUtils.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/utils/XmlUtils.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/utils/XmlUtils.cc Tue Aug  3 23:22:34 2010
@@ -27,7 +27,9 @@
 #include "ink_platform.h"
 #include <sys/types.h>
 #include <sys/stat.h>
+
 #include "XmlUtils.h"
+#include "ink_defs.h"
 
 /****************************************************************************
  *
@@ -417,6 +419,7 @@ elementStart(void *pObj, const char *el,
 void /*XMLDom:: */
 elementEnd(void *pObj, const char *el)
 {
+  NOWARN_UNUSED(el);
   /*ASSERT(strcmp(el, pCur->pNodeName) == 0); */
   XMLDom *pDom = (XMLDom *) pObj;
   pDom->m_pCur = pDom->m_pCur->m_pParentNode;

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/MgmtAllow.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/MgmtAllow.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/MgmtAllow.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/MgmtAllow.cc Tue Aug  3 23:22:34 2010
@@ -62,7 +62,6 @@ err_allow_all(false)
   char *config_file = NULL;
   char *config_dir = NULL;
   struct stat s;
-  int err;
 
   config_file_var = xstrdup(config_var);
   config_file_path[0] = '\0';
@@ -80,10 +79,10 @@ err_allow_all(false)
     return;
   }
 
-  if ((err = stat(config_dir, &s)) < 0) {
+  if (stat(config_dir, &s) < 0) {
     xfree(config_dir);
     config_dir = xstrdup(system_config_directory);
-    if ((err = stat(config_dir, &s)) < 0) {
+    if (stat(config_dir, &s) < 0) {
       mgmt_log(stderr, "%s WARNING: Unable to locate config dir %s.  All IP Addresses will be blocked\n",config_dir);
       return;
     }

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttp.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttp.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttp.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttp.cc Tue Aug  3 23:22:34 2010
@@ -446,7 +446,6 @@ spawn_cgi(WebHttpContext * whc, const ch
   if (whc->request_state & WEB_HTTP_STATE_PLUGIN) {
     // notify server plugin to update its config
     if (success == true && query_string != NULL) {
-      int i;
       char *plugin_name = new char[qlen];
       const char *tmp = strstr(query_string, "INK_PLUGIN_NAME=");
       if (tmp != NULL) {
@@ -478,6 +477,7 @@ spawn_cgi(WebHttpContext * whc, const ch
 char *
 encryptToFileAuth_malloc(const char *password)
 {
+  NOWARN_UNUSED(password);
   RecString dir_path;
   RecGetRecordString_Xmalloc("proxy.config.auth.password_file_path", &dir_path);
 
@@ -510,6 +510,7 @@ encryptToFileAuth_malloc(const char *pas
 static int
 handle_cgi_extn(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err;
   char *cgi_path;
   whc->response_hdr->setCachable(0);
@@ -544,7 +545,7 @@ handle_ink_extn(WebHttpContext * whc, co
 static int
 handle_chart(WebHttpContext * whc, const char *file)
 {
-
+  NOWARN_UNUSED(file);
   //-----------------------------------------------------------------------
   // FIXME: HARD-CODED HTML HELL!!!
   //-----------------------------------------------------------------------
@@ -1155,36 +1156,42 @@ handle_record_info(WebHttpContext * whc,
 static int
 handle_record_stats(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   return handle_record_info(whc, true, false);
 }
 
 static int
 handle_record_configs(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   return handle_record_info(whc, false, false);
 }
 
 static int
 handle_record_stats_rec(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   return handle_record_info(whc, true, true);
 }
 
 static int
 handle_record_configs_rec(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   return handle_record_info(whc, false, true);
 }
 
 static int
 handle_config_files(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   return WebHttpRender(whc, HTML_FILE_ALL_CONFIG);
 }
 
 static int
 handle_debug_logs(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   return WebHttpRender(whc, HTML_VIEW_DEBUG_LOGS_FILE);
 }
 
@@ -1195,6 +1202,7 @@ handle_debug_logs(WebHttpContext * whc, 
 static int
 handle_synthetic(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   char buffer[28];
   char cur = 'a';
   whc->response_hdr->setContentType(TEXT_PLAIN);
@@ -1218,6 +1226,7 @@ handle_synthetic(WebHttpContext * whc, c
 static int
 handle_submit_alarm(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   resolveAlarm(whc->post_data_ht);
   whc->top_level_render_file = xstrdup(HTML_ALARM_FILE);
   return handle_ink_extn(whc, HTML_ALARM_FILE);
@@ -1302,7 +1311,7 @@ set_admin_passwd(WebHttpContext * whc)
 static int
 handle_submit_mgmt_auth(WebHttpContext * whc, const char *file)
 {
-
+  NOWARN_UNUSED(file);
   bool recs_out_of_date;
   char *value;
   char *cancel;
@@ -1514,6 +1523,7 @@ Ldone:
 static int INK_UNUSED
 handle_submit_snapshot(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err = 0;
   SnapResult snap_result = SNAP_OK;
   char *submit_from_page;
@@ -1527,7 +1537,6 @@ handle_submit_snapshot(WebHttpContext * 
   char *ftp_password;
   char *snapDirFromRecordsConf;
   bool found = false;
-  int ret_val;
   struct stat snapDirStat;
   char config_dir[PATH_NAME_MAX];
   struct stat s;
@@ -1613,7 +1622,7 @@ handle_submit_snapshot(WebHttpContext * 
                   ink_assert(absoluteDir != NULL);
                   snprintf(absoluteDir, newLen, "/%s", tok);
 
-                  if ((ret_val = mkdir(absoluteDir, DIR_MODE)) < 0) {
+                  if (mkdir(absoluteDir, DIR_MODE) < 0) {
                     perror("Absolute snapPath Directory creation:");
                   }
                   delete[]absoluteDir;
@@ -1633,7 +1642,7 @@ handle_submit_snapshot(WebHttpContext * 
                   //perror("Absolute snapPath Directory creation:");
                   //}
                   //delete [] absoluteDir;
-                  if ((ret_val = mkdir(tok, DIR_MODE)) < 0) {
+                  if (mkdir(tok, DIR_MODE) < 0) {
                     perror("Relative snapPath Directory creation:");
                   }
                 }
@@ -1760,7 +1769,7 @@ handle_submit_snapshot(WebHttpContext * 
           ink_assert(newStr != NULL);
           snprintf(newStr, newLen, "%s%s%s", ftp_remote_dir, DIR_SEP, snap_name);
 
-          if ((ret_val = mkdir(snapDirFromRecordsConf, DIR_MODE)) < 0) {
+          if (mkdir(snapDirFromRecordsConf, DIR_MODE) < 0) {
             mgmt_log(stderr, "Cannot create %s\n", snapDirFromRecordsConf);
           }
           INKMgmtFtp("get", ftp_server_name, ftp_login, ftp_password, snapDirFromRecordsConf, newStr, NULL);
@@ -1861,6 +1870,7 @@ handle_submit_snapshot(WebHttpContext * 
 static int
 handle_submit_snapshot_to_filesystem(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err = 0;
   SnapResult snap_result = SNAP_OK;
   char *submit_from_page;
@@ -1870,10 +1880,8 @@ handle_submit_snapshot_to_filesystem(Web
   char *snapDirFromRecordsConf;
   char *cancel;
   bool found = false;
-  int ret_val;
   struct stat snapDirStat;
   char config_dir[256];
-  bool recs_out_of_date;
   char *record_version;
   ExpandingArray snap_list(25, true);
   int num_snaps;
@@ -1896,9 +1904,9 @@ handle_submit_snapshot_to_filesystem(Web
     goto Ldone;
   }
   // check for record_version
-  recs_out_of_date = true;
   if (ink_hash_table_lookup(whc->post_data_ht, "record_version", (void **) &record_version)) {
-    recs_out_of_date = !record_version_valid(record_version);
+    // TODO: Check return value?
+    record_version_valid(record_version);
     ink_hash_table_delete(whc->post_data_ht, "record_version");
     xfree(record_version);
   }
@@ -2029,9 +2037,9 @@ handle_submit_snapshot_to_filesystem(Web
               snprintf(absoluteDir, newLen, "/%s", tok);
 
 #ifndef _WIN32
-              if ((ret_val = mkdir(absoluteDir, DIR_MODE)) < 0) {
+              if (mkdir(absoluteDir, DIR_MODE) < 0) {
 #else
-              if ((ret_val = mkdir(absoluteDir)) < 0) {
+              if (mkdir(absoluteDir) < 0) {
 #endif
                 perror("[WebHttp::handle_submit_snapshot_to_filesystem] Absolute snapPath Directory creation:");
               }
@@ -2039,9 +2047,9 @@ handle_submit_snapshot_to_filesystem(Web
             } else {
               const char *tok = snapDirPathTok.getNext(i);
 #ifndef _WIN32
-              if ((ret_val = mkdir(tok, DIR_MODE)) < 0) {
+              if (mkdir(tok, DIR_MODE) < 0) {
 #else
-              if ((ret_val = mkdir(tok)) < 0) {
+              if (mkdir(tok) < 0) {
 #endif
                 perror("[WebHttp::handle_submit_snapshot_to_filesystem] Relative snapPath Directory creation:");
               }
@@ -2201,8 +2209,8 @@ Ldone:
 static int
 handle_submit_snapshot_to_ftpserver(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err = 0;
-  SnapResult snap_result = SNAP_OK;
   char *submit_from_page;
   char *snap_name;
   char *ftp_server_name;
@@ -2213,11 +2221,9 @@ handle_submit_snapshot_to_ftpserver(WebH
   char *tempDirFromRecordsConf;
   char *cancel;
   bool found;
-  int ret_val;
   // Doesn't seem to be used.
   //struct stat snapDirStat;
   char config_dir[256];
-  bool recs_out_of_date;
   char *record_version;
   ExpandingArray snap_list(25, true);
 
@@ -2239,9 +2245,9 @@ handle_submit_snapshot_to_ftpserver(WebH
     goto Ldone;
   }
   // check for record_version
-  recs_out_of_date = true;
   if (ink_hash_table_lookup(whc->post_data_ht, "record_version", (void **) &record_version)) {
-    recs_out_of_date = !record_version_valid(record_version);
+    // TODO: Check return value?
+    record_version_valid(record_version);
     ink_hash_table_delete(whc->post_data_ht, "record_version");
     xfree(record_version);
   }
@@ -2350,7 +2356,7 @@ handle_submit_snapshot_to_ftpserver(WebH
       ink_assert(newStr != NULL);
       snprintf(newStr, newLen, "%s%s%s", ftp_remote_dir, DIR_SEP, snap_name);
 
-      if ((ret_val = mkdir(tmp_ftp_snap, DIR_MODE)) < 0) {
+      if (mkdir(tmp_ftp_snap, DIR_MODE) < 0) {
         mgmt_log(stderr, "[WebHttp::handle_submit_snapshot_to_ftpsystem] Cannot create %s\n", tmp_ftp_snap);
       }
       char ftpOutput[4096];
@@ -2359,11 +2365,9 @@ handle_submit_snapshot_to_ftpserver(WebH
         mgmt_log(stderr, "[WebHttp::handle_submit_snapshot_to_ftpsystem] FTP get failed : %s", ftpOutput);
         goto Ldone;
       }
-      snap_result = configFiles->restoreSnap(snap_name, tempDirFromRecordsConf);
-      snap_result = configFiles->removeSnap(snap_name, tempDirFromRecordsConf);
-
-
-
+      // TODO: Check return values?
+      configFiles->restoreSnap(snap_name, tempDirFromRecordsConf);
+      configFiles->removeSnap(snap_name, tempDirFromRecordsConf);
     }
   }
 
@@ -2383,7 +2387,7 @@ handle_submit_snapshot_to_ftpserver(WebH
       ink_assert(ftp_remote_dir_name != NULL);
       snprintf(newStr, localDirLength, "/tmp%s%s", DIR_SEP, snap_name);
       snprintf(ftp_remote_dir_name, remoteDirLength, "%s%s%s", ftp_remote_dir, DIR_SEP, snap_name);
-      snap_result = configFiles->takeSnap(snap_name, "/tmp");
+      configFiles->takeSnap(snap_name, "/tmp");
       char ftpOutput[4096];
       INKMgmtFtp("put", ftp_server_name, ftp_login, ftp_password, newStr, ftp_remote_dir_name, ftpOutput);
       if (!strncmp(ftpOutput, "ERROR:", 6)) {
@@ -2423,6 +2427,7 @@ Ldone:
 static int
 handle_submit_snapshot_to_floppy(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err = 0;
   SnapResult snap_result = SNAP_OK;
   char *submit_from_page;
@@ -2434,7 +2439,6 @@ handle_submit_snapshot_to_floppy(WebHttp
   // Not used here.
   //struct stat snapDirStat;
   char config_dir[256];
-  bool recs_out_of_date;
   char *record_version;
   char *UnmountFloppy;
   int old_euid;
@@ -2459,9 +2463,9 @@ handle_submit_snapshot_to_floppy(WebHttp
     goto Ldone;
   }
   // check for record_version
-  recs_out_of_date = true;
   if (ink_hash_table_lookup(whc->post_data_ht, "record_version", (void **) &record_version)) {
-    recs_out_of_date = !record_version_valid(record_version);
+    // TODO: Check return value?
+    record_version_valid(record_version);
     ink_hash_table_delete(whc->post_data_ht, "record_version");
     xfree(record_version);
   }
@@ -2652,6 +2656,7 @@ Ldone:
 static int
 handle_submit_inspector(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err = 0;
   char *submit_from_page;
   char *regex;
@@ -2721,6 +2726,7 @@ handle_submit_inspector(WebHttpContext *
 static int
 handle_submit_inspector_display(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   int err = 0;
   char *url;
   char *url_action;
@@ -2768,7 +2774,7 @@ handle_submit_inspector_display(WebHttpC
 static int
 handle_submit_view_logs(WebHttpContext * whc, const char *file)
 {
-
+  NOWARN_UNUSED(file);
   int err;
   char *submit_from_page;
   char *nlines;
@@ -2887,7 +2893,7 @@ Ldone:
 static int
 handle_submit_update(WebHttpContext * whc, const char *file)
 {
-
+  NOWARN_UNUSED(file);
   int err;
   char *submit_from_page;
   bool recs_out_of_date;
@@ -2950,6 +2956,7 @@ handle_submit_update(WebHttpContext * wh
   // check for record_version
   recs_out_of_date = true;
   if (ink_hash_table_lookup(whc->post_data_ht, "record_version", (void **) &record_version)) {
+    // TODO: Check return value?
     recs_out_of_date = !record_version_valid(record_version);
     ink_hash_table_delete(whc->post_data_ht, "record_version");
     xfree(record_version);
@@ -3083,6 +3090,7 @@ Ldone:
 static int
 handle_submit_update_config(WebHttpContext * whc, const char *file)
 {
+  NOWARN_UNUSED(file);
   char **rules = NULL;
   char name[10];                // "rule#"
   char *close;
@@ -3254,7 +3262,7 @@ Lerror:
 static int
 handle_submit_config_display(WebHttpContext * whc, const char *file)
 {
-
+  NOWARN_UNUSED(file);
   // same HTML_CONFIG_DISPLAY_FILE for all config files
   return WebHttpRender(whc, HTML_CONFIG_DISPLAY_FILE);
 }
@@ -3303,7 +3311,7 @@ SetWarning(WebHttpContext * whc, char *a
 static int
 handle_submit_net_config(WebHttpContext * whc, const char *file)
 {
-  bool recs_out_of_date;
+  NOWARN_UNUSED(file);
   char *cancel;
   char *record_version;
   char *submit_from_page;
@@ -3323,9 +3331,9 @@ handle_submit_net_config(WebHttpContext 
     return WebHttpRender(whc, submit_from_page);
 
   // check for record_version
-  recs_out_of_date = true;
   if (ink_hash_table_lookup(whc->post_data_ht, "record_version", (void **) &record_version)) {
-    recs_out_of_date = !record_version_valid(record_version);
+    // TODO: Check return value?
+    record_version_valid(record_version);
     ink_hash_table_delete(whc->post_data_ht, "record_version");
     xfree(record_version);
   }
@@ -3342,19 +3350,19 @@ handle_submit_net_config(WebHttpContext 
   int nic_change[5];
   //  int nic_up[5];
   char *dns_ip[3], old_value[265], old_hostname[80], old_gw_ip[80];
-  char nic_name[5][10], *nic[5][6], interface[80], *param, *old_ip[5];
+  char nic_name[5][10], *nic[5][6], interface[80], *param;
   char *hostname = 0, *gw_ip = 0;
   const char *dn = 0;
   int i, j, no;
   char dns_ips[80];
-  bool warning, fail, rni;
+  bool warning, fail;
 
   //This will be used as flags to verify whether anything changed by the user
   hn_change = 0;
   gw_change = 0;
   dn_change = 0;
   dns_change = 0;
-  warning = (fail = (rni = false));
+  warning = (fail = false);
   //FIXNOW - we need to use SysAPI to find the numver of NICs instead of just constant 5
   for (i = 0; i < 5; i++) {
     nic_change[i] = 0;
@@ -3510,7 +3518,6 @@ handle_submit_net_config(WebHttpContext 
         if (!Config_GetNIC_IP(interface, old_value, sizeof(old_value))) {
           if (nic[no][3] != NULL && strcmp(nic[no][3], old_value) != 0) {
             nic_change[no] = 1;
-            old_ip[no] = old_value;
           }
           //For dhcp start, the static IP maybe same with the dhcp value
           else {
@@ -3679,7 +3686,7 @@ handle_submit_net_config(WebHttpContext 
 static int
 handle_submit_otw_upgrade(WebHttpContext * whc, const char *file)
 {
-
+  NOWARN_UNUSED(file);
   int err = WEB_HTTP_ERR_OKAY;
   char *action;
   char *working_dir;

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpRender.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpRender.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpRender.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpRender.cc Tue Aug  3 23:22:34 2010
@@ -129,6 +129,8 @@ WebHttpGetIntFromQuery(WebHttpContext * 
 static int
 handle_alarm_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   overviewGenerator->generateAlarmsTable(whc);
   return WEB_HTTP_ERR_OKAY;
 }
@@ -140,6 +142,8 @@ handle_alarm_object(WebHttpContext * whc
 static int
 handle_alarm_summary_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   overviewGenerator->generateAlarmsSummary(whc);
   return WEB_HTTP_ERR_OKAY;
 }
@@ -156,6 +160,7 @@ handle_alarm_summary_object(WebHttpConte
 static int
 handle_config_table_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   INKFileNameT type;
   int err = WEB_HTTP_ERR_OKAY;
 
@@ -218,6 +223,8 @@ handle_config_table_object(WebHttpContex
 static int
 handle_help_config_link(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   INKFileNameT type;
   char *ink_file = NULL;
 
@@ -291,6 +298,8 @@ handle_help_config_link(WebHttpContext *
 static int
 handle_dynamic_javascript(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   int err = WEB_HTTP_ERR_OKAY;
   INKFileNameT type;
   char *ink_file;
@@ -391,6 +400,8 @@ Ldone:
 static int
 handle_config_input_form(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char *ink_file;
   char *frecord;
   INKFileNameT type;
@@ -500,6 +511,7 @@ HtmlRndrSelectList(textBuffer * html, co
 static int
 handle_file_edit(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   Rollback *rb;
   char target_file[FILE_NAME_MAX + 1];
   char *formatText;
@@ -595,6 +607,8 @@ handle_include_cgi(WebHttpContext * whc,
 static int
 handle_overview_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   overviewGenerator->generateTable(whc);
   return WEB_HTTP_ERR_OKAY;
 }
@@ -606,6 +620,8 @@ handle_overview_object(WebHttpContext * 
 static int
 handle_overview_details_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   int err;
   if (whc->request_state & WEB_HTTP_STATE_MORE_DETAIL)
     // if currently showing more detail, render link to show less
@@ -622,6 +638,7 @@ handle_overview_details_object(WebHttpCo
 static int
 handle_post_data(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   char *value;
   if (arg && whc->post_data_ht) {
     if (ink_hash_table_lookup(whc->post_data_ht, arg, (void **) &value)) {
@@ -698,6 +715,8 @@ handle_record(WebHttpContext * whc, char
 static int
 handle_record_version(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   int id;
   char id_str[256];
   id = RecGetRecordUpdateCount(RECT_CONFIG);
@@ -718,7 +737,8 @@ handle_record_version(WebHttpContext * w
 static int
 handle_summary_object(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char dateBuf[40];
   char tmpBuf[256];
   time_t uptime_secs, d, h, m, s;
@@ -784,6 +804,8 @@ handle_summary_object(WebHttpContext * w
 static int
 handle_tab_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   int err = WEB_HTTP_ERR_OKAY;
   int active_mode;
 
@@ -802,6 +824,8 @@ handle_tab_object(WebHttpContext * whc, 
 static int
 handle_html_tab_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char *file = NULL;
   int err = WEB_HTTP_ERR_OKAY;
   int active_tab;
@@ -827,7 +851,8 @@ handle_html_tab_object(WebHttpContext * 
 static int
 handle_mgmt_auth_object(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   int user_count;
   INKCfgContext ctx;
   INKCfgIterState ctx_state;
@@ -912,6 +937,8 @@ handle_mgmt_auth_object(WebHttpContext *
 static int
 handle_tree_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   int err = WEB_HTTP_ERR_OKAY;
   char *file = NULL;
 
@@ -940,7 +967,8 @@ Ldone:
 static int
 handle_vip_object(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   // Hash table iteration variables
   InkHashTableEntry *entry;
   InkHashTableIteratorState iterator_state;
@@ -1407,6 +1435,7 @@ handle_floppy_select(WebHttpContext * wh
 static int
 handle_select(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   if (strcmp(arg, "snapshot") == 0) {
     configFiles->displaySnapOption(whc->response_bdy);
   } else if (strcmp(arg, "ftp_snapshot") == 0) {
@@ -1424,7 +1453,7 @@ handle_select(WebHttpContext * whc, char
 static int
 handle_password_object(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
   RecString pwd_file;
   RecGetRecordString_Xmalloc(arg, &pwd_file);
 
@@ -1482,6 +1511,8 @@ render_option(textBuffer * output, const
 static int
 handle_select_system_logs(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   const char *syslog_path = NULL;
   const char *syslog = NULL;
   char tmp[MAX_TMP_BUF_LEN + 1];
@@ -1528,6 +1559,8 @@ handle_select_system_logs(WebHttpContext
 static int
 handle_select_access_logs(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char *logdir;
   char *logfile;
   char tmp[MAX_TMP_BUF_LEN + 1];
@@ -1603,6 +1636,8 @@ handle_select_access_logs(WebHttpContext
 static int
 handle_select_debug_logs(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char tmp[MAX_TMP_BUF_LEN + 1];
   char tmp2[MAX_TMP_BUF_LEN + 1];
   char tmp3[MAX_TMP_BUF_LEN + 1];
@@ -1680,6 +1715,7 @@ handle_select_debug_logs(WebHttpContext 
 static int
 handle_log_action(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   textBuffer *output = whc->response_bdy;
   InkHashTable *ht = whc->post_data_ht;
   char *logfile;
@@ -1777,6 +1813,8 @@ Ldone:
 static int
 handle_version(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   whc->response_bdy->copyFrom(PACKAGE_VERSION, strlen(PACKAGE_VERSION));
   return WEB_HTTP_ERR_OKAY;
 }
@@ -1787,6 +1825,8 @@ handle_version(WebHttpContext * whc, cha
 static int
 handle_clear_cluster_stats(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   textBuffer *output = whc->response_bdy;
 
   RecInt cluster_type = 0;      // current SSL value, enabled/disabled
@@ -1824,6 +1864,8 @@ handle_clear_cluster_stats(WebHttpContex
 static int
 handle_submit_error_msg(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   if (whc->request_state & WEB_HTTP_STATE_SUBMIT_WARN || whc->request_state & WEB_HTTP_STATE_SUBMIT_NOTE) {
     textBuffer *output = whc->response_bdy;
     HtmlRndrTableOpen(output, "100%", 0, 0, 10);
@@ -1854,6 +1896,8 @@ handle_submit_error_msg(WebHttpContext *
 static int
 handle_help_link(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char *file = NULL;
   char *link;
 
@@ -1880,6 +1924,7 @@ handle_help_link(WebHttpContext * whc, c
 static int
 handle_submit_error_flg(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   if (whc->request_state & WEB_HTTP_STATE_SUBMIT_WARN) {
     char *dummy;
     if (arg && ink_hash_table_lookup(whc->submit_warn_ht, arg, (void **) &dummy)) {
@@ -1910,6 +1955,7 @@ handle_submit_error_flg(WebHttpContext *
 static int
 handle_link(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   char *link;
 
   if (arg) {
@@ -1929,6 +1975,8 @@ handle_link(WebHttpContext * whc, char *
 static int
 handle_link_file(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char *file = NULL;
 
   if ((file = WebHttpGetTopLevelRndrFile_Xmalloc(whc))) {
@@ -1948,6 +1996,8 @@ handle_link_file(WebHttpContext * whc, c
 static int
 handle_link_query(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   char *file = NULL;
   char *query;
 
@@ -1970,6 +2020,8 @@ handle_link_query(WebHttpContext * whc, 
 static int
 handle_cache_query(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   textBuffer *output = whc->response_bdy;
   char *cache_op;
   char *url;
@@ -2216,6 +2268,8 @@ handle_cache_query(WebHttpContext * whc,
 static int
 handle_cache_regex_query(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   textBuffer *output = whc->response_bdy;
   char *cache_op;
   char *regex;
@@ -2369,6 +2423,8 @@ handle_cache_regex_query(WebHttpContext 
 static int
 handle_time(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   time_t my_time_t;
   char my_ctime_str[32];
   time(&my_time_t);
@@ -2389,6 +2445,8 @@ handle_time(WebHttpContext * whc, char *
 static int
 handle_user(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   MgmtInt basic_auth_enabled;
   if (!varIntFromName("proxy.config.admin.basic_auth", &basic_auth_enabled)) {
     return WEB_HTTP_ERR_FAIL;
@@ -2409,7 +2467,8 @@ handle_user(WebHttpContext * whc, char *
 static int
 handle_plugin_object(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   textBuffer *output = whc->response_bdy;
   WebPluginConfig *wpc = lmgmt->plugin_list.getFirst();
   char *config_link;
@@ -2450,7 +2509,8 @@ handle_plugin_object(WebHttpContext * wh
 static int
 handle_ssl_redirect_url(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   RecInt ssl_value = 0;         // current SSL value, enabled/disabled
   char *hostname_FQ = NULL;
   char ssl_redirect_url[256] = "";
@@ -2486,7 +2546,8 @@ handle_ssl_redirect_url(WebHttpContext *
 static int
 handle_host_redirect_url(WebHttpContext * whc, char *tag, char *arg)
 {
-
+  NOWARN_UNUSED(tag);
+  NOWARN_UNUSED(arg);
   RecInt ssl_value = 0;         // current SSL value, enabled/disabled
   char hostname[1024];
   char host_redirect_url[256] = "";
@@ -2516,6 +2577,7 @@ handle_host_redirect_url(WebHttpContext 
 static int
 handle_network(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
   int err = WEB_HTTP_ERR_OKAY;
 #if defined(linux) || defined(solaris)
   char value[1024];
@@ -2667,6 +2729,7 @@ Ldone:
 static int
 handle_network_object(WebHttpContext * whc, char *tag, char *arg)
 {
+  NOWARN_UNUSED(tag);
 #if defined(linux)
   char *device_ink_path, *template_ink_path;
   char command[200], tmpname[80], interface[80];

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpSession.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpSession.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpSession.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpSession.cc Tue Aug  3 23:22:34 2010
@@ -62,6 +62,7 @@ struct session_ele
 static void *
 deleter_main(void *unused)
 {
+  NOWARN_UNUSED(unused);
   time_t now;
   InkHashTableIteratorState htis;
   InkHashTableEntry *hte;

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpTree.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpTree.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpTree.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/WebHttpTree.cc Tue Aug  3 23:22:34 2010
@@ -136,6 +136,7 @@ static int g_link_id = 0;
 void
 start_element_handler(void *userData, const char *name, const char **atts)
 {
+  NOWARN_UNUSED(userData);
   char **attrs = (char **) atts;
   if (strcmp(name, "MENU_TREE") == 0) {
     // Main entity tag - do nothing
@@ -273,6 +274,7 @@ generate_link_node(char **atts)
 void
 end_element_handler(void *userData, const char *name)
 {
+  NOWARN_UNUSED(userData);
   if (strcmp(name, "MENU_TREE") == 0) {
     // Main entity tag - do nothing
   } else if (strcmp(name, "MODE") == 0) {

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/WebIntrMain.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/WebIntrMain.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/WebIntrMain.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/WebIntrMain.cc Tue Aug  3 23:22:34 2010
@@ -122,6 +122,8 @@ static ink_mutex ssl_locks[CRYPTO_NUM_LO
 void
 SSLeay_mutex_cb(int mode, int type, const char *file, int line)
 {
+  NOWARN_UNUSED(file);
+  NOWARN_UNUSED(line);
   ink_release_assert(type < CRYPTO_NUM_LOCKS);
   ink_release_assert(type >= 0);
   if (mode & CRYPTO_LOCK) {
@@ -509,6 +511,7 @@ printServiceThr(int sig)
 void *
 serviceThrReaper(void *arg)
 {
+  NOWARN_UNUSED(arg);
   time_t currentTime;
   int numJoined;
 
@@ -602,7 +605,6 @@ webIntr_main(void *x)
   UIthr_t serviceThr = NO_THR;  // type for new service thread
 
   struct sockaddr_in *clientInfo;       // Info about client connection
-  int fdsReady;                 // Numbers of FDs ready, returned from select()
   ink_thread thrId;             // ID of service thread we just spawned
   fd_set selectFDs;             // FD set passed to select
   int webPort = -1;             // Port for incoming HTTP connections
@@ -987,7 +989,8 @@ webIntr_main(void *x)
       FD_SET(rafFD, &selectFDs);
     }
 
-    fdsReady = mgmt_select(32, &selectFDs, (fd_set *) NULL, (fd_set *) NULL, NULL);
+    // TODO: Should we check return value?
+    mgmt_select(32, &selectFDs, (fd_set *) NULL, (fd_set *) NULL, NULL);
 
     if (socketFD >= 0 && FD_ISSET(socketFD, &selectFDs)) {
       // new HTTP Connection

Modified: trafficserver/traffic/trunk/proxy/mgmt2/web2/WebOverview.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/web2/WebOverview.cc?rev=982077&r1=982076&r2=982077&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/web2/WebOverview.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/web2/WebOverview.cc Tue Aug  3 23:22:34 2010
@@ -1599,7 +1599,6 @@ overviewPage::agCacheHitRate()
   MgmtIntCounter totalMisses = 0;
   MgmtIntCounter totalAccess = 0;
   MgmtFloat hitRate = 0.00;
-  int status;
 
   // get current time and delta to work with
   ink_hrtime current_time = ink_get_hrtime();
@@ -1629,11 +1628,13 @@ overviewPage::agCacheHitRate()
     //////////////////////////
     cluster_hit_count.current_value = -10000;
     cluster_hit_count.current_time = ink_get_hrtime();
-    status = clusterSumInt(cluster_hit_count.lm_record_name, &(cluster_hit_count.current_value));
+    // TODO: Should we check return value?
+    clusterSumInt(cluster_hit_count.lm_record_name, &(cluster_hit_count.current_value));
 
     cluster_miss_count.current_value = -10000;
     cluster_miss_count.current_time = ink_get_hrtime();
-    status = clusterSumInt(cluster_miss_count.lm_record_name, &(cluster_miss_count.current_value));
+    // TODO: Should we check return value?
+    clusterSumInt(cluster_miss_count.lm_record_name, &(cluster_miss_count.current_value));
 
     ////////////////////////////////////////////////
     // if not initial or wrap, set derived values //
@@ -1711,7 +1712,6 @@ overviewPage::agHostdbHitRate()
   //  RecInt hostDBmisses = 0;
   RecInt dnsTotal = 0;
   RecFloat hitRate = 0.00;
-  int status;
 
   // get current time and delta to work with
   ink_hrtime current_time = ink_get_hrtime();
@@ -1741,11 +1741,13 @@ overviewPage::agHostdbHitRate()
     //////////////////////////
     cluster_hostdb_total_lookups.current_value = -10000;
     cluster_hostdb_total_lookups.current_time = ink_get_hrtime();
-    status = clusterSumInt(cluster_hostdb_total_lookups.lm_record_name, &(cluster_hostdb_total_lookups.current_value));
+    // TODO: Should we check return value?
+    clusterSumInt(cluster_hostdb_total_lookups.lm_record_name, &(cluster_hostdb_total_lookups.current_value));
 
     cluster_hostdb_hits.current_value = -10000;
     cluster_hostdb_hits.current_time = ink_get_hrtime();
-    status = clusterSumInt(cluster_hostdb_hits.lm_record_name, &(cluster_hostdb_hits.current_value));
+    // TODO: Should we check return value?
+    clusterSumInt(cluster_hostdb_hits.lm_record_name, &(cluster_hostdb_hits.current_value));
 
     ////////////////////////////////////////////////
     // if not initial or wrap, set derived values //
@@ -1825,7 +1827,6 @@ overviewPage::agBandwidthHitRate()
   MgmtInt totalHits = 0;
   MgmtInt cacheOn = 1;          // on by default
   MgmtInt httpCacheOn;
-  int status;
 
   // See if cache is on
   ink_assert(varIntFromName("proxy.config.http.cache.http", &httpCacheOn));
@@ -1898,11 +1899,13 @@ overviewPage::agBandwidthHitRate()
     //////////////////////////
     cluster_ua_total_bytes.current_value = -10000;
     cluster_ua_total_bytes.current_time = ink_get_hrtime();
-    status = clusterSumInt(cluster_ua_total_bytes.lm_record_name, &(cluster_ua_total_bytes.current_value));
+    // TODO: Should we check return value?
+    clusterSumInt(cluster_ua_total_bytes.lm_record_name, &(cluster_ua_total_bytes.current_value));
 
     cluster_os_total_bytes.current_value = -10000;
     cluster_os_total_bytes.current_time = ink_get_hrtime();
-    status = clusterSumInt(cluster_os_total_bytes.lm_record_name, &(cluster_os_total_bytes.current_value));
+    // TODO: Should we check return value?
+    clusterSumInt(cluster_os_total_bytes.lm_record_name, &(cluster_os_total_bytes.current_value));
 
     ////////////////////////////////////////////////
     // if not initial or wrap, set derived values //
@@ -2386,6 +2389,7 @@ resolveAlarm(InkHashTable * post_data_ht
 void
 resolveAlarmCLI(textBuffer * output, const char *request)
 {
+  NOWARN_UNUSED(output);
   Tokenizer colonTok(":");
   const char *ipAddr = NULL;
   alarm_t alarmType;