You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by jp...@apache.org on 2013/03/05 23:07:23 UTC

git commit: TS-1626: remove WUTS proxy code

Updated Branches:
  refs/heads/master c6de45128 -> 68e6a81be


TS-1626: remove WUTS proxy code

There is a bunch of code doing something with "WUTS proxy status
codes". What is a WUTS and why do we care? If this is cruft, let's
get rid of it!


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

Branch: refs/heads/master
Commit: 68e6a81be576227b006af782c94de20544ad6f17
Parents: c6de451
Author: Uri Shachar <us...@hotmail.com>
Authored: Tue Mar 5 14:05:27 2013 -0800
Committer: James Peach <jp...@apache.org>
Committed: Tue Mar 5 14:05:27 2013 -0800

----------------------------------------------------------------------
 CHANGES                                            |    3 +
 .../perl/AdminClient/lib/Apache/TS/AdminClient.pm  |    2 -
 mgmt/RecordsConfig.cc                              |    4 -
 proxy/hdrs/HTTP.h                                  |   17 -
 proxy/http/HttpConfig.cc                           |    6 -
 proxy/http/HttpConfig.h                            |    8 -
 proxy/http/HttpSM.cc                               |   30 +--
 proxy/http/HttpTransact.cc                         |   33 +--
 proxy/http/HttpTransact.h                          |   94 +------
 proxy/http/HttpTransactHeaders.cc                  |  237 +--------------
 proxy/http/HttpTransactHeaders.h                   |   20 +--
 proxy/logging/Log.cc                               |   20 +--
 12 files changed, 21 insertions(+), 453 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/CHANGES
----------------------------------------------------------------------
diff --git a/CHANGES b/CHANGES
index 7ac4b24..cbf9443 100644
--- a/CHANGES
+++ b/CHANGES
@@ -2,6 +2,9 @@
 Changes with Apache Traffic Server 3.3.1
 
 
+  *) [TS-1626] remove WUTS proxy code
+   Author: Uri Shachar <us...@hotmail.com>
+
   *) [TS-1741] add plugins examples to the build
 
   *) [TS-1058] add TSHttpTxnCloseAfterResponse experimental API

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/contrib/perl/AdminClient/lib/Apache/TS/AdminClient.pm
----------------------------------------------------------------------
diff --git a/contrib/perl/AdminClient/lib/Apache/TS/AdminClient.pm b/contrib/perl/AdminClient/lib/Apache/TS/AdminClient.pm
index 1b5a84a..1374cf4 100644
--- a/contrib/perl/AdminClient/lib/Apache/TS/AdminClient.pm
+++ b/contrib/perl/AdminClient/lib/Apache/TS/AdminClient.pm
@@ -480,7 +480,6 @@ The Apache Traffic Server Administration Manual will explain what these strings
  proxy.config.http.keep_alive_no_activity_timeout_in
  proxy.config.http.keep_alive_no_activity_timeout_out
  proxy.config.http.keep_alive_post_out
- proxy.config.http.log_spider_codes
  proxy.config.http.negative_caching_enabled
  proxy.config.http.negative_caching_lifetime
  proxy.config.http.negative_revalidating_enabled
@@ -532,7 +531,6 @@ The Apache Traffic Server Administration Manual will explain what these strings
  proxy.config.http_ui_enabled
  proxy.config.http.uncacheable_requests_bypass_parent
  proxy.config.http.user_agent_pipeline
- proxy.config.http.wuts_enabled
  proxy.config.icp.default_reply_port
  proxy.config.icp.enabled
  proxy.config.icp.icp_configuration

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/mgmt/RecordsConfig.cc
----------------------------------------------------------------------
diff --git a/mgmt/RecordsConfig.cc b/mgmt/RecordsConfig.cc
index 47f6395..1c2a88e 100644
--- a/mgmt/RecordsConfig.cc
+++ b/mgmt/RecordsConfig.cc
@@ -477,10 +477,6 @@ RecordElement RecordsConfig[] = {
   ,
   {RECT_CONFIG, "proxy.config.http.share_server_sessions", RECD_INT, "2", RECU_RESTART_TS, RR_NULL, RECC_NULL, NULL, RECA_NULL}
   ,
-  {RECT_CONFIG, "proxy.config.http.wuts_enabled", RECD_INT, "0", RECU_DYNAMIC, RR_NULL, RECC_NULL, NULL, RECA_NULL}
-  ,
-  {RECT_CONFIG, "proxy.config.http.log_spider_codes", RECD_INT, "0", RECU_DYNAMIC, RR_NULL, RECC_NULL, NULL, RECA_NULL}
-  ,
   {RECT_CONFIG, "proxy.config.http.record_heartbeat", RECD_INT, "0", RECU_DYNAMIC, RR_NULL, RECC_NULL, NULL, RECA_NULL}
   ,
   {RECT_CONFIG, "proxy.config.http.record_tcp_mem_hit", RECD_INT, "0", RECU_DYNAMIC, RR_NULL, RECC_NULL, NULL, RECA_NULL}

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/hdrs/HTTP.h
----------------------------------------------------------------------
diff --git a/proxy/hdrs/HTTP.h b/proxy/hdrs/HTTP.h
index d9aae03..a654bb1 100644
--- a/proxy/hdrs/HTTP.h
+++ b/proxy/hdrs/HTTP.h
@@ -125,7 +125,6 @@ enum SquidLogCode
   SQUID_LOG_TCP_SWAPFAIL = 'b',
   SQUID_LOG_TCP_DENIED = 'c',
   SQUID_LOG_TCP_WEBFETCH_MISS = 'd',
-  SQUID_LOG_TCP_SPIDER_BYPASS = 'e',
   SQUID_LOG_TCP_FUTURE_2 = 'f',
   SQUID_LOG_TCP_HIT_REDIRECT = '[',       // standard redirect
   SQUID_LOG_TCP_MISS_REDIRECT = ']',      // standard redirect
@@ -159,22 +158,6 @@ enum SquidLogCode
   SQUID_LOG_ERR_PROXY_DENIED = 'G',
   SQUID_LOG_ERR_WEBFETCH_DETECTED = 'H',
   SQUID_LOG_ERR_FUTURE_1 = 'I',
-  SQUID_LOG_ERR_SPIDER_MEMBER_ABORTED = 'J',
-  SQUID_LOG_ERR_SPIDER_PARENTAL_CONTROL_RESTRICTION = 'K',
-  SQUID_LOG_ERR_SPIDER_UNSUPPORTED_HTTP_VERSION = 'L',
-  SQUID_LOG_ERR_SPIDER_UIF = 'M',
-  SQUID_LOG_ERR_SPIDER_FUTURE_USE_1 = 'N',
-  SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_PASSING = 'O',
-  SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_DRAINING = 'P',
-  SQUID_LOG_ERR_SPIDER_GENERAL_TIMEOUT = 'Q',
-  SQUID_LOG_ERR_SPIDER_CONNECT_FAILED = 'R',
-  SQUID_LOG_ERR_SPIDER_FUTURE_USE_2 = 'S',
-  SQUID_LOG_ERR_SPIDER_NO_RESOURCES = 'T',
-  SQUID_LOG_ERR_SPIDER_INTERNAL_ERROR = 'U',
-  SQUID_LOG_ERR_SPIDER_INTERNAL_IO_ERROR = 'V',
-  SQUID_LOG_ERR_SPIDER_DNS_TEMP_ERROR = 'W',
-  SQUID_LOG_ERR_SPIDER_DNS_HOST_NOT_FOUND = 'X',
-  SQUID_LOG_ERR_SPIDER_DNS_NO_ADDRESS = 'Y',
   SQUID_LOG_ERR_UNKNOWN = 'Z'
 };
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpConfig.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpConfig.cc b/proxy/http/HttpConfig.cc
index d955964..8793e6f 100644
--- a/proxy/http/HttpConfig.cc
+++ b/proxy/http/HttpConfig.cc
@@ -1174,9 +1174,6 @@ HttpConfig::startup()
   HttpEstablishStaticConfigStringAlloc(c.proxy_response_via_string, "proxy.config.http.response_via_str");
   c.proxy_response_via_string_len = -1;
 
-  HttpEstablishStaticConfigByte(c.wuts_enabled, "proxy.config.http.wuts_enabled");
-  HttpEstablishStaticConfigByte(c.log_spider_codes, "proxy.config.http.log_spider_codes");
-
   HttpEstablishStaticConfigStringAlloc(c.url_expansions_string, "proxy.config.dns.url_expansions");
   HttpEstablishStaticConfigLongLong(c.proxy_server_port, "proxy.config.http.server_port");
   HttpEstablishStaticConfigStringAlloc(c.proxy_server_other_ports, "proxy.config.http.server_other_ports");
@@ -1453,9 +1450,6 @@ HttpConfig::reconfigure()
   params->proxy_response_via_string = ats_strdup(m_master.proxy_response_via_string);
   params->proxy_response_via_string_len = (params->proxy_response_via_string) ? strlen(params->proxy_response_via_string) : 0;
 
-  params->wuts_enabled = INT_TO_BOOL(m_master.wuts_enabled);
-  params->log_spider_codes = INT_TO_BOOL(m_master.log_spider_codes);
-
   params->url_expansions_string = ats_strdup(m_master.url_expansions_string);
   params->url_expansions = parse_url_expansions(params->url_expansions_string, &params->num_url_expansions);
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpConfig.h
----------------------------------------------------------------------
diff --git a/proxy/http/HttpConfig.h b/proxy/http/HttpConfig.h
index 2bc4748..494fc60 100644
--- a/proxy/http/HttpConfig.h
+++ b/proxy/http/HttpConfig.h
@@ -635,12 +635,6 @@ public:
   char *proxy_response_via_string;
   int proxy_response_via_string_len;
 
-  //////////////////
-  // WUTS headers //
-  //////////////////
-  MgmtByte wuts_enabled;
-  MgmtByte log_spider_codes;
-
   ///////////////////////////////////
   // URL expansions for DNS lookup //
   ///////////////////////////////////
@@ -914,8 +908,6 @@ HttpConfigParams::HttpConfigParams()
     proxy_request_via_string_len(0),
     proxy_response_via_string(0),
     proxy_response_via_string_len(0),
-    wuts_enabled(0),
-    log_spider_codes(0),
     url_expansions_string(0),
     url_expansions(0),
     num_url_expansions(0),

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpSM.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpSM.cc b/proxy/http/HttpSM.cc
index 4159628..27a687a 100644
--- a/proxy/http/HttpSM.cc
+++ b/proxy/http/HttpSM.cc
@@ -695,11 +695,6 @@ HttpSM::state_read_client_request_header(int event, void *data)
   case VC_EVENT_ACTIVE_TIMEOUT:
     // The user agent is hosed.  Close it &
     //   bail on the state machine
-    if (t_state.http_config_param->log_spider_codes) {
-      t_state.squid_codes.wuts_proxy_status_code = WUTS_PROXY_STATUS_SPIDER_TIMEOUT_WHILE_DRAINING;
-      t_state.squid_codes.log_code = SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_DRAINING;
-      t_state.squid_codes.hier_code = SQUID_HIER_TIMEOUT_DIRECT;
-    }
     vc_table.cleanup_entry(ua_entry);
     ua_entry = NULL;
     t_state.client_info.abort = HttpTransact::ABORTED;
@@ -2735,16 +2730,12 @@ HttpSM::tunnel_handler_server(int event, HttpTunnelProducer * p)
   milestones.server_close = ink_get_hrtime();
 
   bool close_connection = false;
-  bool log_spider_codes = t_state.http_config_param->log_spider_codes != 0;
 
   switch (event) {
   case VC_EVENT_INACTIVITY_TIMEOUT:
   case VC_EVENT_ACTIVE_TIMEOUT:
   case VC_EVENT_ERROR:
-    t_state.squid_codes.wuts_proxy_status_code =
-      log_spider_codes ? WUTS_PROXY_STATUS_SPIDER_TIMEOUT_WHILE_PASSING : WUTS_PROXY_STATUS_READ_TIMEOUT;
-    t_state.squid_codes.log_code =
-      log_spider_codes ? SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_PASSING : SQUID_LOG_ERR_READ_TIMEOUT;
+    t_state.squid_codes.log_code = SQUID_LOG_ERR_READ_TIMEOUT;
     t_state.squid_codes.hier_code = SQUID_HIER_TIMEOUT_DIRECT;
 
     switch (event) {
@@ -2776,11 +2767,6 @@ HttpSM::tunnel_handler_server(int event, HttpTunnelProducer * p)
       t_state.current.server->abort = HttpTransact::ABORTED;
       t_state.client_info.keep_alive = HTTP_NO_KEEPALIVE;
       t_state.current.server->keep_alive = HTTP_NO_KEEPALIVE;
-      if (t_state.http_config_param->log_spider_codes) {
-        t_state.squid_codes.wuts_proxy_status_code = WUTS_PROXY_STATUS_SPIDER_TIMEOUT_WHILE_DRAINING;
-        t_state.squid_codes.log_code = SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_DRAINING;
-        t_state.squid_codes.hier_code = SQUID_HIER_TIMEOUT_DIRECT;
-      }
     } else {
       p->read_success = true;
       t_state.current.server->abort = HttpTransact::DIDNOT_ABORT;
@@ -3108,11 +3094,6 @@ HttpSM::tunnel_handler_ua_push(int event, HttpTunnelProducer * p)
   case VC_EVENT_ERROR:
   case VC_EVENT_EOS:
     // Transfer terminated.  Bail on the cache write.
-    if (t_state.http_config_param->log_spider_codes) {
-      t_state.squid_codes.wuts_proxy_status_code = WUTS_PROXY_STATUS_SPIDER_TIMEOUT_WHILE_DRAINING;
-      t_state.squid_codes.log_code = SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_DRAINING;
-      t_state.squid_codes.hier_code = SQUID_HIER_TIMEOUT_DIRECT;
-    }
     t_state.client_info.abort = HttpTransact::ABORTED;
     p->vc->do_io_close(EHTTP_ERROR);
     p->read_vio = NULL;
@@ -3151,9 +3132,6 @@ HttpSM::tunnel_handler_cache_read(int event, HttpTunnelProducer * p)
     if (t_state.cache_info.object_read->object_size_get() != INT64_MAX || event == VC_EVENT_ERROR) {
       // Abnormal termination
       t_state.squid_codes.log_code = SQUID_LOG_TCP_SWAPFAIL;
-      t_state.squid_codes.wuts_proxy_status_code =
-        t_state.http_config_param->
-        log_spider_codes ? WUTS_PROXY_STATUS_SPIDER_GENERAL_TIMEOUT : WUTS_PROXY_STATUS_READ_TIMEOUT;
       p->vc->do_io_close(EHTTP_ERROR);
       p->read_vio = NULL;
       tunnel.chain_abort_all(p);
@@ -4737,16 +4715,12 @@ HttpSM::mark_host_failure(HostDBInfo * info, time_t time_down)
 void
 HttpSM::set_ua_abort(HttpTransact::AbortState_t ua_abort, int event)
 {
-  bool log_spider_codes = t_state.http_config_param->log_spider_codes != 0;
-
   t_state.client_info.abort = ua_abort;
 
   switch (ua_abort) {
   case HttpTransact::ABORTED:
   case HttpTransact::MAYBE_ABORTED:
-    t_state.squid_codes.wuts_proxy_status_code =
-      log_spider_codes ? WUTS_PROXY_STATUS_SPIDER_MEMBER_ABORTED : WUTS_PROXY_STATUS_CLIENT_ABORT;
-    t_state.squid_codes.log_code = log_spider_codes ? SQUID_LOG_ERR_SPIDER_MEMBER_ABORTED : SQUID_LOG_ERR_CLIENT_ABORT;
+    t_state.squid_codes.log_code = SQUID_LOG_ERR_CLIENT_ABORT;
     break;
   default:
     // Handled here:

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpTransact.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransact.cc b/proxy/http/HttpTransact.cc
index 0a4bfe7..6626c1d 100644
--- a/proxy/http/HttpTransact.cc
+++ b/proxy/http/HttpTransact.cc
@@ -4663,8 +4663,6 @@ HttpTransact::merge_and_update_headers_for_cache_update(State* s)
 
   s->cache_info.object_store.request_get()->field_delete(MIME_FIELD_VIA, MIME_LEN_VIA);
 
-  if (s->http_config_param->wuts_enabled)
-    HttpTransactHeaders::convert_wuts_code_to_normal_reason(s->cache_info.object_store.response_get());
 }
 
 void
@@ -4814,9 +4812,6 @@ HttpTransact::set_headers_for_cache_write(State* s, HTTPInfo* cache_info, HTTPHd
     // add one marker to the content in cache
    // cache_info->response_get()->value_set("@WWW-Auth", 9, "true", 4);
   //}
-  if (s->http_config_param->wuts_enabled)
-    HttpTransactHeaders::convert_wuts_code_to_normal_reason(cache_info->response_get());
-
   if (!s->cop_test_page)
     DUMP_HEADER("http_hdrs", cache_info->request_get(), s->state_machine_id, "Cached Request Hdr");
 }
@@ -5622,15 +5617,6 @@ HttpTransact::initialize_state_variables_from_request(State* s, HTTPHdr* obsolet
     s->client_info.pipeline_possible = true;
   }
 
-  if (s->http_config_param->log_spider_codes) {
-    HTTPVersion uver = s->client_info.http_version;
-    if (uver != HTTPVersion(1, 0) && uver != HTTPVersion(1, 1) && uver != HTTPVersion(0, 9)) {
-      // this probably will be overwriten later if the server accepts
-      // unsupported versions
-      s->squid_codes.wuts_proxy_status_code = WUTS_PROXY_STATUS_SPIDER_UNSUPPORTED_HTTP_VERSION;
-    }
-  }
-
   if (!s->server_info.name || s->redirect_info.redirect_in_process) {
     s->server_info.name = s->arena.str_store(host_name, host_len);
     s->server_info.port = incoming_request->port_get();
@@ -6203,10 +6189,7 @@ HttpTransact::is_response_cacheable(State* s, HTTPHdr* request, HTTPHdr* respons
             !response->get_last_modified()) {
           DebugTxn("http_trans", "[is_response_cacheable] " "last_modified, expires, or max-age is required");
 
-          // Set the WUTS code to NO_DLE or NO_LE only for 200 responses.
-          if (response_code == HTTP_STATUS_OK) {
-            s->squid_codes.hit_miss_code = ((response->get_date() == 0) ? (SQUID_MISS_HTTP_NO_DLE) : (SQUID_MISS_HTTP_NO_LE));
-          }
+          s->squid_codes.hit_miss_code = ((response->get_date() == 0) ? (SQUID_MISS_HTTP_NO_DLE) : (SQUID_MISS_HTTP_NO_LE));
           return (false);
         }
         break;
@@ -7985,16 +7968,7 @@ HttpTransact::build_response(State* s, HTTPHdr* base_response, HTTPHdr* outgoing
   response_url_remap(outgoing_response);
 
   if (s->http_config_param->enable_http_stats) {
-    if (s->hdr_info.server_response.valid() && s->http_config_param->wuts_enabled) {
-      int reason_len;
-      const char *reason = s->hdr_info.server_response.reason_get(&reason_len);
-      if (reason != NULL && reason_len > 0)
-        outgoing_response->reason_set(reason, reason_len);
-    }
-
-    HttpTransactHeaders::generate_and_set_wuts_codes(outgoing_response, s->via_string, &s->squid_codes, WUTS_PROXY_ID,
-                                                     ((s->http_config_param->wuts_enabled) ? (true) : (false)),
-                                                     ((s->http_config_param->log_spider_codes) ? (true) : (false)));
+    HttpTransactHeaders::generate_and_set_squid_codes(outgoing_response, s->via_string, &s->squid_codes);
   }
 
   HttpTransactHeaders::add_server_header_to_response(s->txn_conf, outgoing_response);
@@ -8461,7 +8435,6 @@ HttpTransact::client_result_stat(State* s, ink_hrtime total_time, ink_hrtime req
 
   switch (s->squid_codes.log_code) {
   case SQUID_LOG_ERR_CONNECT_FAIL:
-  case SQUID_LOG_ERR_SPIDER_CONNECT_FAILED:
     HTTP_INCREMENT_TRANS_STAT(http_cache_miss_cold_stat);
     client_transaction_result = CLIENT_TRANSACTION_RESULT_ERROR_CONNECT_FAIL;
     break;
@@ -8764,13 +8737,11 @@ HttpTransact::update_size_and_time_stats(State* s, ink_hrtime total_time, ink_hr
     HTTP_SUM_TRANS_STAT(http_tcp_ims_miss_origin_server_bytes_stat, origin_server_bytes);
     break;
   case SQUID_LOG_ERR_CLIENT_ABORT:
-  case SQUID_LOG_ERR_SPIDER_MEMBER_ABORTED:
     HTTP_INCREMENT_TRANS_STAT(http_err_client_abort_count_stat);
     HTTP_SUM_TRANS_STAT(http_err_client_abort_user_agent_bytes_stat, user_agent_bytes);
     HTTP_SUM_TRANS_STAT(http_err_client_abort_origin_server_bytes_stat, origin_server_bytes);
     break;
   case SQUID_LOG_ERR_CONNECT_FAIL:
-  case SQUID_LOG_ERR_SPIDER_CONNECT_FAILED:
     HTTP_INCREMENT_TRANS_STAT(http_err_connect_fail_count_stat);
     HTTP_SUM_TRANS_STAT(http_err_connect_fail_user_agent_bytes_stat, user_agent_bytes);
     HTTP_SUM_TRANS_STAT(http_err_connect_fail_origin_server_bytes_stat, origin_server_bytes);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpTransact.h
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransact.h b/proxy/http/HttpTransact.h
index adb06e7..2c3a9bd 100644
--- a/proxy/http/HttpTransact.h
+++ b/proxy/http/HttpTransact.h
@@ -46,7 +46,6 @@
 #include "congest/Congestion.h"
 
 #define MAX_DNS_LOOKUPS 2
-#define WUTS_PROXY_ID 0
 #define NUM_SECONDS_IN_ONE_YEAR (31536000)      // (365L * 24L * 3600L)
 
 #define HTTP_RELEASE_ASSERT(X) ink_release_assert(X)
@@ -106,94 +105,6 @@ class HttpSM;
 #include "InkErrno.h"
 #define UNKNOWN_INTERNAL_ERROR           (INK_START_ERRNO - 1)
 
-
-/* WUTS proxy-status codes */
-enum WUTSProxyStatusCode
-{
-  WUTS_PROXY_STATUS_UNKNOWN = 0,
-  WUTS_PROXY_STATUS_UNSPECIFIED = 0,
-  WUTS_PROXY_STATUS_CONTINUE = 100,
-  WUTS_PROXY_STATUS_SWITCHING_PROTOCOL = 101,
-  WUTS_PROXY_STATUS_OK = 200,
-  WUTS_PROXY_STATUS_CREATED = 201,
-  WUTS_PROXY_STATUS_ACCEPTED = 202,
-  WUTS_PROXY_STATUS_NON_AUTHORITATIVE_INFORMATION = 203,
-  WUTS_PROXY_STATUS_NO_CONTENT = 204,
-  WUTS_PROXY_STATUS_RESET_CONTENT = 205,
-  WUTS_PROXY_STATUS_PARTIAL_CONTENT = 206,
-  WUTS_PROXY_STATUS_MULTIPLE_CHOICES = 300,
-  WUTS_PROXY_STATUS_MOVED_PERMANENTLY = 301,
-  WUTS_PROXY_STATUS_MOVED_TEMPORARILY = 302,
-  WUTS_PROXY_STATUS_SEE_OTHER = 303,
-  WUTS_PROXY_STATUS_NOT_MODIFIED = 304,
-  WUTS_PROXY_STATUS_USE_PROXY = 305,
-  WUTS_PROXY_STATUS_BAD_REQUEST = 400,
-  WUTS_PROXY_STATUS_UNAUTHORIZED = 401,
-  WUTS_PROXY_STATUS_PAYMENT_REQUIRED = 402,
-  WUTS_PROXY_STATUS_FORBIDDEN = 403,
-  WUTS_PROXY_STATUS_NOT_FOUND = 404,
-  WUTS_PROXY_STATUS_METHOD_NOT_ALLOWED = 405,
-  WUTS_PROXY_STATUS_NOT_ACCEPTABLE = 406,
-  WUTS_PROXY_STATUS_PROXY_AUTHENTICATION_REQUIRED = 407,
-  WUTS_PROXY_STATUS_REQUEST_TIMEOUT = 408,
-  WUTS_PROXY_STATUS_CONFLICT = 409,
-  WUTS_PROXY_STATUS_GONE = 410,
-  WUTS_PROXY_STATUS_LENGTH_REQUIRED = 411,
-  WUTS_PROXY_STATUS_PRECONDITION_FAILED = 412,
-  WUTS_PROXY_STATUS_REQUEST_ENTITY_TOO_LARGE = 413,
-  WUTS_PROXY_STATUS_REQUEST_URI_TOO_LONG = 414,
-  WUTS_PROXY_STATUS_UNSUPPORTED_MEDIA_TYPE = 415,
-  WUTS_PROXY_STATUS_INTERNAL_SERVER_ERROR = 500,
-  WUTS_PROXY_STATUS_NOT_IMPLEMENTED = 501,
-  WUTS_PROXY_STATUS_BAD_GATEWAY = 502,
-  WUTS_PROXY_STATUS_SERVICE_UNAVAILABLE = 503,
-  WUTS_PROXY_STATUS_GATEWAY_TIMEOUT = 504,
-  WUTS_PROXY_STATUS_HTTPVER_NOT_SUPPORTED = 505,
-  WUTS_PROXY_STATUS_NO_HTTP_CODE_IN_RESPONSE_LINE = 600,
-  WUTS_PROXY_STATUS_READ_TIMEOUT = 800,
-  WUTS_PROXY_STATUS_LIFETIME_EXPIRED = 801,
-  WUTS_PROXY_STATUS_NO_CLIENT_BIG_OBJECT = 802,
-  WUTS_PROXY_STATUS_SOCKET_READ_ERROR = 803,
-  WUTS_PROXY_STATUS_CLIENT_ABORT = 804,
-  WUTS_PROXY_STATUS_CONNECT_FAILED = 805,
-  WUTS_PROXY_STATUS_INVALID_REQUEST = 806,
-  WUTS_PROXY_STATUS_UNSUPPORTED_REQUEST = 807,
-  WUTS_PROXY_STATUS_INVALID_URL = 808,
-  WUTS_PROXY_STATUS_NO_FILE_DESCRIPTORS = 809,
-  WUTS_PROXY_STATUS_DNS_LOOKUP_FAILURE = 810,
-  WUTS_PROXY_STATUS_PROTOCOL_OR_METHOD_NOT_SUPPORTED = 811,
-  WUTS_PROXY_STATUS_UNABLE_TO_FETCH = 812,
-  WUTS_PROXY_STATUS_NO_RELAY = 813,
-  WUTS_PROXY_STATUS_DISK_IO_ERROR = 814,
-  WUTS_PROXY_STATUS_ZERO_SIZE_OBJECT = 815,
-  WUTS_PROXY_STATUS_PROXY_AUTHORIZATION_FAILURE = 817,
-  WUTS_PROXY_STATUS_WEBFETCH_DETECTED_ERROR = 818,
-  WUTS_PROXY_STATUS_PERSISTENT_READ_ERROR = 819,
-  WUTS_PROXY_STATUS_SPIDER_MEMBER_ABORTED = 820,
-  WUTS_PROXY_STATUS_SPIDER_PARENT_CONTROL_RESTRICTION = 821,
-  WUTS_PROXY_STATUS_SPIDER_UNSUPPORTED_HTTP_VERSION = 822,
-  WUTS_PROXY_STATUS_SPIDER_USER_IDENTIFICATION_FAILURE = 823,
-  WUTS_PROXY_STATUS_SPIDER_RESERVED_FOR_FUTURE_USE_1 = 824,
-  WUTS_PROXY_STATUS_SPIDER_TIMEOUT_WHILE_PASSING = 825,
-  WUTS_PROXY_STATUS_SPIDER_TIMEOUT_WHILE_DRAINING = 826,
-  WUTS_PROXY_STATUS_SPIDER_GENERAL_TIMEOUT = 827,
-  WUTS_PROXY_STATUS_SPIDER_CONNECTION_FAILED = 828,
-  WUTS_PROXY_STATUS_SPIDER_RESERVED_FOR_FUTURE_USE_2 = 829,
-  WUTS_PROXY_STATUS_SPIDER_NO_RESOURCES = 830,
-  WUTS_PROXY_STATUS_SPIDER_INTERNAL_ERROR = 831,
-  WUTS_PROXY_STATUS_SPIDER_INTERNAL_IO_ERROR = 832,
-  WUTS_PROXY_STATUS_SPIDER_DNS_TEMP_ERROR = 833,
-  WUTS_PROXY_STATUS_SPIDER_DNS_HOST_NOT_FOUND = 834,
-  WUTS_PROXY_STATUS_SPIDER_DNS_NO_ADDRESS = 835,
-  WUTS_PROXY_STATUS_SPIDER_RESERVED_FOR_FUTURE_USE_3 = 836,
-  WUTS_PROXY_STATUS_IMS_RECEIVED_CACHE_HIT = 998,
-  WUTS_PROXY_STATUS_GET_RECEIVED_CACHE_HIT = 999,
-  WUTS_PROXY_STATUS_INVALID_ASSIGNED_CODE = 9
-};
-
-/* WUTS proxy-id */
-typedef int WUTSProxyId;
-
 enum ViaStringIndex_t
 {
   //
@@ -908,11 +819,10 @@ public:
     SquidLogCode log_code;
     SquidHierarchyCode hier_code;
     SquidHitMissCode hit_miss_code;
-    WUTSProxyStatusCode wuts_proxy_status_code;
 
     _SquidLogInfo()
-      : log_code(SQUID_LOG_ERR_UNKNOWN),
-      hier_code(SQUID_HIER_EMPTY), hit_miss_code(SQUID_MISS_NONE), wuts_proxy_status_code(WUTS_PROXY_STATUS_UNKNOWN)
+      : log_code(SQUID_LOG_ERR_UNKNOWN), hier_code(SQUID_HIER_EMPTY),
+        hit_miss_code(SQUID_MISS_NONE)
     { }
   } SquidLogInfo;
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpTransactHeaders.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransactHeaders.cc b/proxy/http/HttpTransactHeaders.cc
index 5f112c3..24c2349 100644
--- a/proxy/http/HttpTransactHeaders.cc
+++ b/proxy/http/HttpTransactHeaders.cc
@@ -492,176 +492,15 @@ HttpTransactHeaders::downgrade_request(bool *origin_server_keep_alive, HTTPHdr *
 
   return true;
 }
-bool
-HttpTransactHeaders::get_wuts_code(HTTPHdr *hdr, WUTSCode *w)
-{
-#define is_alnum(c)  (ParseRules::is_alnum (c))
-#define is_digit(c)  (ParseRules::is_digit (c))
-
-  const char *phrase;
-  int length;
-  int i, j;
-
-  phrase = hdr->reason_get(&length);
-  if (!phrase || (length == 0) || (phrase[0] != '!'))
-    return false;
-
-  if (length < 25)
-    return (false);
-
-  if (!is_alnum(phrase[1]))
-    return false;
-
-  w->squid_hit_miss_code = (SquidHitMissCode) phrase[1];
-
-  for (i = 0, j = 2; i < 5; i++) {
-    if (!is_alnum(phrase[1]))
-      return false;
-    w->squid_log_code[i] = (SquidLogCode) phrase[j];
-    j += 1;
-
-    if (!is_alnum(phrase[1]))
-      return false;
-    w->squid_hier_code[i] = (SquidHierarchyCode) phrase[j];
-    j += 1;
-  }
-
-  for (i = 0; i < 5; i++) {
-    if ((phrase[j] != '0') || (phrase[j + 1] != '0'))
-      return false;
-    w->proxy_id[i] = 0;
-    j += 2;
-  }
-
-  if (!is_digit(phrase[j + 0]) || !is_digit(phrase[j + 1]) || !is_digit(phrase[j + 2]))
-    return false;
-
-  w->proxy_status_code =
-    (WUTSProxyStatusCode) ((phrase[j + 0] - '0') * 100 + (phrase[j + 1] - '0') * 10 + (phrase[j + 2] - '0'));
-
-  return true;
-
-#undef is_alnum
-#undef is_digit
-}
-
-
-void
-HttpTransactHeaders::set_wuts_codes(HTTPHdr *hdr, WUTSCode *code)
-{
-#define is_digit(c)  (ParseRules::is_digit (c))
-#define is_hex(c)    (ParseRules::is_hex (c))
-
-  char phrase[1024];
-  const char *old_phrase;
-  int old_length;
-  int i, j, phrase_len;
-
-  old_phrase = hdr->reason_get(&old_length);
-  if (old_length > 0) {
-    if ((old_length >= 25) && (old_phrase[0] == '!') &&
-        is_hex(old_phrase[1]) && is_hex(old_phrase[2]) &&
-        is_hex(old_phrase[3]) && is_hex(old_phrase[4]) &&
-        is_hex(old_phrase[5]) && is_hex(old_phrase[6]) &&
-        is_hex(old_phrase[7]) && is_hex(old_phrase[8]) &&
-        is_hex(old_phrase[9]) && is_hex(old_phrase[10]) &&
-        is_hex(old_phrase[11]) && is_hex(old_phrase[12]) &&
-        is_hex(old_phrase[13]) && is_hex(old_phrase[14]) &&
-        is_hex(old_phrase[15]) && is_hex(old_phrase[16]) &&
-        is_hex(old_phrase[17]) && is_hex(old_phrase[18]) &&
-        is_hex(old_phrase[19]) && is_hex(old_phrase[20]) &&
-        is_hex(old_phrase[21]) && is_digit(old_phrase[22]) && is_digit(old_phrase[23]) && is_digit(old_phrase[24])) {
-      old_phrase += 25;
-      old_length -= 25;
-
-      if ((old_length >= 1) && (old_phrase[0] == ' ')) {
-        old_phrase += 1;
-        old_length -= 1;
-      }
-    }
-
-    if (old_length > (1023 - 25))
-      old_length = 1023 - 25;
-
-    phrase[0] = '!';
-    phrase[25] = ' ';
-    memcpy(&phrase[26], old_phrase, old_length);
-    phrase[26 + old_length] = '\0';
-    phrase_len = 26 + old_length;
-  } else {
-    phrase[0] = '!';
-    phrase[25] = '\0';
-    phrase_len = 25;
-  }
-
-  phrase[1] = code->squid_hit_miss_code;
-
-  for (i = 0, j = 2; i < 5; i++) {
-    phrase[j++] = code->squid_log_code[i];
-    phrase[j++] = code->squid_hier_code[i];
-  }
-
-  for (i = 0; i < 5; i++) {
-    phrase[j++] = ((code->proxy_id[i] / 10) % 10) + '0';
-    phrase[j++] = (code->proxy_id[i] % 10) + '0';
-  }
-
-  phrase[j++] = ((code->proxy_status_code / 100) % 10) + '0';
-  phrase[j++] = ((code->proxy_status_code / 10) % 10) + '0';
-  phrase[j++] = (code->proxy_status_code % 10) + '0';
-
-  hdr->reason_set(phrase, phrase_len);
-
-#undef is_hex
-#undef is_digit
-}
-
 
 void
-HttpTransactHeaders::set_wuts_codes(HTTPHdr *hdr,
-                                    SquidHitMissCode hit_miss_code,
-                                    SquidLogCode log_code,
-                                    SquidHierarchyCode hier_code,
-                                    WUTSProxyId proxy_id, WUTSProxyStatusCode proxy_status_code)
-{
-  WUTSCode code;
-  int i;
-
-  if (!get_wuts_code(hdr, &code)) {
-    for (i = 0; i < 5; i++) {
-      code.squid_log_code[i] = SQUID_LOG_EMPTY;
-      code.squid_hier_code[i] = SQUID_HIER_EMPTY;
-      code.proxy_id[i] = 0;
-    }
-  }
-
-  for (i = 0; i < 4; i++) {
-    if ((code.squid_log_code[i] == SQUID_LOG_EMPTY) &&
-        (code.squid_hier_code[i] == SQUID_HIER_EMPTY) && (code.proxy_id[i] == 0)) {
-      break;
-    }
-  }
-
-  code.squid_hit_miss_code = hit_miss_code;
-  code.squid_log_code[i] = log_code;
-  code.squid_hier_code[i] = hier_code;
-  code.proxy_id[i] = proxy_id;
-  code.proxy_status_code = proxy_status_code;
-
-  set_wuts_codes(hdr, &code);
-}
-
-
-void
-HttpTransactHeaders::generate_and_set_wuts_codes(HTTPHdr *header,
+HttpTransactHeaders::generate_and_set_squid_codes(HTTPHdr *header,
                                                  char *via_string,
-                                                 HttpTransact::SquidLogInfo *squid_codes,
-                                                 int wuts_id, bool set_codes_in_hdr, bool log_spider_codes)
+                                                 HttpTransact::SquidLogInfo *squid_codes)
 {
   SquidLogCode log_code;
   SquidHierarchyCode hier_code;
   SquidHitMissCode hit_miss_code;
-  WUTSProxyStatusCode status_code = WUTS_PROXY_STATUS_UNKNOWN;
 
   /////////////////////////////
   // First the Hit-Miss Code //
@@ -757,61 +596,37 @@ HttpTransactHeaders::generate_and_set_wuts_codes(HTTPHdr *header,
     hier_code = SQUID_HIER_DIRECT;
   }
 
-  if (log_spider_codes && hier_code == SQUID_HIER_DIRECT)
-    log_code = SQUID_LOG_TCP_SPIDER_BYPASS;
-
-  /////////////////////
-  // The Status Code //
-  /////////////////////
-  if (via_string[VIA_CLIENT_REQUEST] == VIA_CLIENT_IMS) {
-    if ((via_string[VIA_CACHE_RESULT] == VIA_IN_CACHE_FRESH) ||
-        (via_string[VIA_CACHE_RESULT] == VIA_IN_RAM_CACHE_FRESH)) {
-      status_code = WUTS_PROXY_STATUS_IMS_RECEIVED_CACHE_HIT;
-    }
-  } else if (via_string[VIA_CLIENT_REQUEST] == VIA_CLIENT_SIMPLE) {
-    if ((via_string[VIA_CACHE_RESULT] == VIA_IN_CACHE_FRESH) ||
-        (via_string[VIA_CACHE_RESULT] == VIA_IN_RAM_CACHE_FRESH)) {
-      status_code = WUTS_PROXY_STATUS_GET_RECEIVED_CACHE_HIT;
-    }
-  }
   // Errors may override the other codes, so check the via string error codes last
   switch (via_string[VIA_ERROR_TYPE]) {
   case VIA_ERROR_AUTHORIZATION:
-    status_code = WUTS_PROXY_STATUS_PROXY_AUTHORIZATION_FAILURE;
     // TODO decide which one?
     // log_code = SQUID_LOG_TCP_DENIED;
     log_code = SQUID_LOG_ERR_PROXY_DENIED;
     break;
   case VIA_ERROR_CONNECTION:
-    status_code = log_spider_codes ? WUTS_PROXY_STATUS_SPIDER_CONNECTION_FAILED : WUTS_PROXY_STATUS_CONNECT_FAILED;
     if (log_code == SQUID_LOG_TCP_MISS) {
-      log_code = log_spider_codes ? SQUID_LOG_ERR_SPIDER_CONNECT_FAILED : SQUID_LOG_ERR_CONNECT_FAIL;
+      log_code = SQUID_LOG_ERR_CONNECT_FAIL;
     }
     break;
   case VIA_ERROR_DNS_FAILURE:
-    status_code = log_spider_codes ? WUTS_PROXY_STATUS_SPIDER_DNS_HOST_NOT_FOUND : WUTS_PROXY_STATUS_DNS_LOOKUP_FAILURE;
-    log_code = log_spider_codes ? SQUID_LOG_ERR_SPIDER_DNS_HOST_NOT_FOUND : SQUID_LOG_ERR_DNS_FAIL;
+    log_code = SQUID_LOG_ERR_DNS_FAIL;
     hier_code = SQUID_HIER_NONE;
     break;
   case VIA_ERROR_FORBIDDEN:
-    status_code = WUTS_PROXY_STATUS_FORBIDDEN;
     log_code = SQUID_LOG_ERR_PROXY_DENIED;
     break;
   case VIA_ERROR_HEADER_SYNTAX:
-    status_code = WUTS_PROXY_STATUS_INVALID_REQUEST;
     log_code = SQUID_LOG_ERR_INVALID_REQ;
     hier_code = SQUID_HIER_NONE;
     break;
   case VIA_ERROR_SERVER:
-    status_code = log_spider_codes ? WUTS_PROXY_STATUS_SPIDER_CONNECTION_FAILED : WUTS_PROXY_STATUS_CONNECT_FAILED;
     if (log_code == SQUID_LOG_TCP_MISS || log_code == SQUID_LOG_TCP_MISS) {
-      log_code = log_spider_codes ? SQUID_LOG_ERR_SPIDER_CONNECT_FAILED : SQUID_LOG_ERR_CONNECT_FAIL;
+      log_code = SQUID_LOG_ERR_CONNECT_FAIL;
     }
     break;
   case VIA_ERROR_TIMEOUT:
-    status_code = WUTS_PROXY_STATUS_READ_TIMEOUT;
     if (log_code == SQUID_LOG_TCP_MISS || log_code == SQUID_LOG_TCP_IMS_MISS) {
-      log_code = log_spider_codes ? SQUID_LOG_ERR_SPIDER_GENERAL_TIMEOUT : SQUID_LOG_ERR_READ_TIMEOUT;
+      log_code = SQUID_LOG_ERR_READ_TIMEOUT;
     }
     if (hier_code == SQUID_HIER_SIBLING_HIT) {
       hier_code = SQUID_HIER_TIMEOUT_SIBLING_HIT;
@@ -822,12 +637,6 @@ HttpTransactHeaders::generate_and_set_wuts_codes(HTTPHdr *header,
     }
     break;
   case VIA_ERROR_CACHE_READ:
-    // policy decision to call this a disk io error
-    // in the absence of a corresponding status code
-    // for TCP_SWAPFAIL. it seems as if disk io goes
-    // better with the ERR_DISK_IO log code, but
-    // beep it. i am sick of second guessing wuts codes.
-    status_code = WUTS_PROXY_STATUS_DISK_IO_ERROR;
     log_code = SQUID_LOG_TCP_SWAPFAIL;
     hier_code = SQUID_HIER_NONE;
     break;
@@ -835,13 +644,9 @@ HttpTransactHeaders::generate_and_set_wuts_codes(HTTPHdr *header,
     break;
   }
 
-  if (status_code == WUTS_PROXY_STATUS_UNKNOWN) {
-    status_code = (WUTSProxyStatusCode) header->status_get();
-  }
-
   Debug("http_trans",
-        "[WUTS code generation] Hit/Miss: %d, Log: %d, Hier: %d, Status: %d",
-        hit_miss_code, log_code, hier_code, status_code);
+        "[Squid code generation] Hit/Miss: %d, Log: %d, Hier: %d",
+        hit_miss_code, log_code, hier_code);
   squid_codes->log_code = log_code;
   squid_codes->hier_code = hier_code;
 
@@ -854,32 +659,6 @@ HttpTransactHeaders::generate_and_set_wuts_codes(HTTPHdr *header,
       hit_miss_code = squid_codes->hit_miss_code;
     }
   }
-
-  if (status_code != WUTS_PROXY_STATUS_UNKNOWN) {
-    squid_codes->wuts_proxy_status_code = status_code;
-  }
-
-  if (set_codes_in_hdr) {
-    set_wuts_codes(header, hit_miss_code, log_code, hier_code, wuts_id, status_code);
-  }
-}
-
-
-void
-HttpTransactHeaders::convert_wuts_code_to_normal_reason(HTTPHdr *hdr)
-{
-  const char *phrase;
-  int length;
-
-  if (hdr == NULL)
-    return;
-
-  phrase = hdr->reason_get(&length);
-  if (!phrase || (length == 0 || (phrase[0] != '!')))
-    return;
-
-  phrase = (const char *) http_hdr_reason_lookup(hdr->status_get());
-  hdr->reason_set(phrase, strlen(phrase));
 }
 
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/http/HttpTransactHeaders.h
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransactHeaders.h b/proxy/http/HttpTransactHeaders.h
index f450795..9ee80f7 100644
--- a/proxy/http/HttpTransactHeaders.h
+++ b/proxy/http/HttpTransactHeaders.h
@@ -26,15 +26,6 @@
 
 #define ink_time_t time_t
 
-struct WUTSCode
-{
-  SquidHitMissCode squid_hit_miss_code;
-  SquidLogCode squid_log_code[5];
-  SquidHierarchyCode squid_hier_code[5];
-  WUTSProxyId proxy_id[5];
-  WUTSProxyStatusCode proxy_status_code;
-};
-
 extern int nstrhex(char *d, unsigned int i);
 
 class HttpTransactHeaders
@@ -68,16 +59,9 @@ public:
   static bool does_server_allow_response_to_be_stored(HTTPHdr * resp);
   static bool downgrade_request(bool * origin_server_keep_alive, HTTPHdr * outgoing_request);
 
-  static bool get_wuts_code(HTTPHdr * hdr, WUTSCode * w);
-  static void set_wuts_codes(HTTPHdr * hdr, WUTSCode * code);
-  static void set_wuts_codes(HTTPHdr * hdr, SquidHitMissCode hit_miss_code,
-                             SquidLogCode log_code, SquidHierarchyCode hier_code,
-                             WUTSProxyId proxy_id, WUTSProxyStatusCode proxy_status_code);
-  static void generate_and_set_wuts_codes(HTTPHdr * header, char *via_string,
-                                          HttpTransact::SquidLogInfo * squid_codes,
-                                          int wuts_id, bool set_codes_in_hdr, bool log_spider_codes = false);
+  static void generate_and_set_squid_codes(HTTPHdr * header, char *via_string,
+                                          HttpTransact::SquidLogInfo * squid_codes);
 
-  static void convert_wuts_code_to_normal_reason(HTTPHdr * header);
   static void handle_conditional_headers(HttpTransact::CacheLookupInfo * cache_info, HTTPHdr * header);
   static void insert_warning_header(HttpConfigParams *http_config_param,
                                     HTTPHdr *header, HTTPWarningCode code,

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/68e6a81b/proxy/logging/Log.cc
----------------------------------------------------------------------
diff --git a/proxy/logging/Log.cc b/proxy/logging/Log.cc
index dd463f0..f1008e6 100644
--- a/proxy/logging/Log.cc
+++ b/proxy/logging/Log.cc
@@ -564,7 +564,7 @@ Log::init_fields()
   ink_hash_table_insert(field_symbol_hash, "pfsc", field);
 
   Ptr<LogFieldAliasTable> cache_code_map = NEW(new LogFieldAliasTable);
-  cache_code_map->init(62,
+  cache_code_map->init(49,
                        SQUID_LOG_EMPTY, "UNDEFINED",
                        SQUID_LOG_TCP_HIT, "TCP_HIT",
                        SQUID_LOG_TCP_DISK_HIT, "TCP_DISK_HIT",
@@ -580,7 +580,6 @@ Log::init_fields()
                        SQUID_LOG_TCP_SWAPFAIL, "TCP_SWAPFAIL_MISS",
                        SQUID_LOG_TCP_DENIED, "TCP_DENIED",
                        SQUID_LOG_TCP_WEBFETCH_MISS, "TCP_WEBFETCH_MISS",
-                       SQUID_LOG_TCP_SPIDER_BYPASS, "TCP_SPIDER_BYPASS",
                        SQUID_LOG_TCP_FUTURE_2, "TCP_FUTURE_2",
                        SQUID_LOG_TCP_HIT_REDIRECT, "TCP_HIT_REDIRECT",
                        SQUID_LOG_TCP_MISS_REDIRECT, "TCP_MISS_REDIRECT",
@@ -614,22 +613,7 @@ Log::init_fields()
                        SQUID_LOG_ERR_PROXY_DENIED, "ERR_PROXY_DENIED",
                        SQUID_LOG_ERR_WEBFETCH_DETECTED, "ERR_WEBFETCH_DETECTED",
                        SQUID_LOG_ERR_FUTURE_1, "ERR_FUTURE_1",
-                       SQUID_LOG_ERR_SPIDER_MEMBER_ABORTED, "ERR_SPIDER_MEMBER_ABORTED",
-                       SQUID_LOG_ERR_SPIDER_PARENTAL_CONTROL_RESTRICTION, "ERR_SPIDER_PARENTAL_CONTROL_RESTRICTION",
-                       SQUID_LOG_ERR_SPIDER_UNSUPPORTED_HTTP_VERSION, "ERR_SPIDER_UNSUPPORTED_HTTP_VERSION",
-                       SQUID_LOG_ERR_SPIDER_UIF, "ERR_SPIDER_UIF",
-                       SQUID_LOG_ERR_SPIDER_FUTURE_USE_1, "ERR_SPIDER_FUTURE_USE_1",
-                       SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_PASSING, "ERR_SPIDER_TIMEOUT_WHILE_PASSING",
-                       SQUID_LOG_ERR_SPIDER_TIMEOUT_WHILE_DRAINING, "ERR_SPIDER_TIMEOUT_WHILE_DRAINING",
-                       SQUID_LOG_ERR_SPIDER_GENERAL_TIMEOUT, "ERR_SPIDER_GENERAL_TIMEOUT",
-                       SQUID_LOG_ERR_SPIDER_CONNECT_FAILED, "ERR_SPIDER_CONNECT_FAILED",
-                       SQUID_LOG_ERR_SPIDER_FUTURE_USE_2, "ERR_SPIDER_FUTURE_USE_2",
-                       SQUID_LOG_ERR_SPIDER_NO_RESOURCES, "ERR_SPIDER_NO_RESOURCES",
-                       SQUID_LOG_ERR_SPIDER_INTERNAL_ERROR, "ERR_SPIDER_INTERNAL_ERROR",
-                       SQUID_LOG_ERR_SPIDER_INTERNAL_IO_ERROR, "ERR_SPIDER_INTERNAL_IO_ERROR",
-                       SQUID_LOG_ERR_SPIDER_DNS_TEMP_ERROR, "ERR_SPIDER_DNS_TEMP_ERROR",
-                       SQUID_LOG_ERR_SPIDER_DNS_HOST_NOT_FOUND, "ERR_SPIDER_DNS_HOST_NOT_FOUND",
-                       SQUID_LOG_ERR_SPIDER_DNS_NO_ADDRESS, "ERR_SPIDER_DNS_NO_ADDRESS", SQUID_LOG_ERR_UNKNOWN, "ERR_UNKNOWN");
+                       SQUID_LOG_ERR_UNKNOWN, "ERR_UNKNOWN");
 
   field = NEW(new LogField("cache_result_code", "crc",
                            LogField::sINT,