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 2010/05/13 19:44:13 UTC

svn commit: r943951 [8/19] - in /trafficserver/traffic/tags/2.1.0: ./ ci/ example/add-header/ example/app-template/ example/append-transform/ example/basic-auth/ example/blacklist-0/ example/blacklist-1/ example/bnull-transform/ example/cache_scan/ exa...

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransact.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransact.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransact.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransact.cc Thu May 13 17:43:56 2010
@@ -92,7 +92,7 @@ is_asterisk(char *s)
 }
 
 
-// someday, reduce the amount of duplicate code between this 
+// someday, reduce the amount of duplicate code between this
 // function and _process_xxx_connection_field_in_outgoing_header
 inline static HTTPKeepAlive
 is_header_keep_alive(const HTTPVersion & http_version, const HTTPVersion & request_http_version, MIMEField * con_hdr    /*, bool* unknown_tokens */
@@ -138,7 +138,7 @@ is_header_keep_alive(const HTTPVersion &
           break;
         } else if (ptr_len_casecmp(val, val_len, "close", 5) == 0) {
           con_token = CON_TOKEN_CLOSE;
-          /* 
+          /*
              if (!*unknown_tokens) {
              *unknown_tokens = (iter->get_next(&val_len) == NULL);
              } */
@@ -349,7 +349,7 @@ find_server_and_update_current_info(Http
       break;
     case PARENT_FAIL:
       // Check to see if should bypass the parent and go direct
-      //   We can only do this if 
+      //   We can only do this if
       //   1) the parent was not set from API
       //   2) the config permits us
       //   3) the config permitted us to dns the origin server
@@ -545,7 +545,7 @@ how_to_open_connection(HttpTransact::Sta
            !s->hdr_info.server_request.presence(MIME_PRESENCE_HOST)) {
         URL *url = s->hdr_info.server_request.url_get();
         host = url->host_get(&host_len);
-        // Add a ':port' to the HOST header if the request is not going 
+        // Add a ':port' to the HOST header if the request is not going
         // to the default port.
         int port = url->port_get();
         if (port != url_canonicalize_port(URL_TYPE_HTTP, 0)) {
@@ -845,9 +845,9 @@ HttpTransact::StartRemapRequest(State * 
 
         /**
 	 * Check for URL remappings before checking request
-	 * validity or initializing state variables since       
-	 * the remappings can insert or change the destination  
-	 * host, port and protocol.                             
+	 * validity or initializing state variables since
+	 * the remappings can insert or change the destination
+	 * host, port and protocol.
 	**/
 
   HTTPHdr *incoming_request = &(s->hdr_info.client_request);
@@ -1073,7 +1073,7 @@ HttpTransact::ModifyRequest(State * s)
 
   Debug("http_trans", "START HttpTransact::ModifyRequest");
 
-  // Intialize the state vars necessary to sending error responses      
+  // Intialize the state vars necessary to sending error responses
   bootstrap_state_variables_from_request(s, &s->hdr_info.client_request);
 
   ////////////////////////////////////////////////
@@ -1270,7 +1270,7 @@ HttpTransact::HandleRequest(State * s)
   // initialize the cache_control structure read from cache.config
   update_cache_control_information_from_config(s);
 
-  // We still need to decide whether or not to do a cache lookup since 
+  // We still need to decide whether or not to do a cache lookup since
   // the scheduled update code depends on this info.
   if (is_request_cache_lookupable(s, &s->hdr_info.client_request))
     s->cache_info.action = CACHE_DO_LOOKUP;
@@ -1339,8 +1339,8 @@ HttpTransact::HandleRequest(State * s)
     }
   }
   // Added to skip the dns if the document is in the cache.
-  // DNS is requested before cache lookup only if there are rules in cache.config , parent.config or 
-  // if the newly added varible doc_in_cache_skip_dns is not enabled              
+  // DNS is requested before cache lookup only if there are rules in cache.config , parent.config or
+  // if the newly added varible doc_in_cache_skip_dns is not enabled
   if (s->dns_info.lookup_name[0] <= '9' &&
       s->dns_info.lookup_name[0] >= '0' &&
      // (s->state_machine->authAdapter.needs_rev_dns() ||
@@ -1348,7 +1348,7 @@ HttpTransact::HandleRequest(State * s)
     s->force_dns = 1;
   }
   //YTS Team, yamsat Plugin
-  //Doing a Cache Lookup in case of a Redirection to ensure that 
+  //Doing a Cache Lookup in case of a Redirection to ensure that
   //the newly requested object is not in the CACHE
   if (s->http_config_param->cache_http && s->redirect_info.redirect_in_process && s->state_machine->enable_redirection) {
     TRANSACT_RETURN(CACHE_LOOKUP, NULL);
@@ -1358,7 +1358,7 @@ HttpTransact::HandleRequest(State * s)
   if (s->force_dns) {
     TRANSACT_RETURN(DNS_LOOKUP, OSDNSLookup);   // After handling the request, DNS is done.
   } else {
-    // After the requested is properly handled No need of requesting the DNS directly check the ACLs 
+    // After the requested is properly handled No need of requesting the DNS directly check the ACLs
     // if the request is Authorised
     StartAccessControl(s);
   }
@@ -1445,7 +1445,7 @@ HttpTransact::HandleApiErrorJump(State *
 // Description: called after DNS lookup of parent proxy name
 //
 // Details    :
-//   
+//
 // the configuration information gave us the name of the parent proxy
 // to send the request to. this function is called after the dns lookup
 // for that name. it may fail, in which case we look for the next parent
@@ -1521,8 +1521,8 @@ HttpTransact::PPDNSLookup(State * s)
 //
 // Details    :
 //
-//  
-//  
+//
+//
 // Possible Next States From Here:
 // - HttpTransact::ORIGIN_SERVER_RAW_OPEN;
 // - HttpTransact::ORIGIN_SERVER_OPEN;
@@ -1538,7 +1538,7 @@ HttpTransact::ReDNSRoundRobin(State * s)
 
   if (s->dns_info.lookup_success) {
 
-    // We using a new server now so clear the connection 
+    // We using a new server now so clear the connection
     //  failure mark
     s->current.server->connect_failure = 0;
 
@@ -1606,7 +1606,7 @@ HttpTransact::ReDNSRoundRobin(State * s)
 // Description: called after the DNS lookup of origin server name
 //
 // Details    :
-//   
+//
 // normally called after Start. may be called more than once, however,
 // if the dns lookup fails. this may be if the client does not specify
 // the full hostname (e.g. just cnn, instead of www.cnn.com), or because
@@ -1750,8 +1750,8 @@ HttpTransact::OSDNSLookup(State * s)
 
   if (return_action == CONNECTION_COLLAPSING_SCHEDULED) {
     // Changing the state from DNS_LOOKUP to STATE_MACHINE_ACTION_UNDEFINED
-    //As the handler has been scheduled, the event system would call back 
-    //after rww_wait_time. So lets return to Zero state from here so that 
+    //As the handler has been scheduled, the event system would call back
+    //after rww_wait_time. So lets return to Zero state from here so that
     //transaction starts afresh when piggybacked_handler is scheduled
     //YTS Team, yamsat
     TRANSACT_RETURN(STATE_MACHINE_ACTION_UNDEFINED, NULL);
@@ -1759,8 +1759,8 @@ HttpTransact::OSDNSLookup(State * s)
 
   else if (return_action == CACHE_RELOOKUP) {
     //This case arises if a client could not insert an entry in Hash Table
-    //as someother url has inserted it.Therefore there is a possibility 
-    //for this client to get the object from Cache instead of going to 
+    //as someother url has inserted it.Therefore there is a possibility
+    //for this client to get the object from Cache instead of going to
     //origin server connection -- YTS Team, yamsat
     TRANSACT_RETURN(CACHE_LOOKUP, NULL);
   }
@@ -1770,7 +1770,7 @@ HttpTransact::OSDNSLookup(State * s)
   // return a response to the client with the expanded host name
   // and a tasty little blurb explaining what happened.
 
-  // if a DNS lookup succeeded on a user-defined 
+  // if a DNS lookup succeeded on a user-defined
   // hostname expansion, forward the request to the expanded hostname.
   // On the other hand, if the lookup succeeded on a www.<hostname>.com
   // expansion, return a 302 response.
@@ -1804,7 +1804,7 @@ HttpTransact::OSDNSLookup(State * s)
              s->dns_info.lookup_name[0] >= '0' &&
              //(s->state_machine->authAdapter.needs_rev_dns() ||
              ( host_rule_in_CacheControlTable() || s->parent_params->ParentTable->hostMatch)) {
-    // note, broken logic: ACC fudges the OR stmt to always be true, 
+    // note, broken logic: ACC fudges the OR stmt to always be true,
     // 'AuthHttpAdapter' should do the rev-dns if needed, not here .
     TRANSACT_RETURN(REVERSE_DNS_LOOKUP, HttpTransact::StartAccessControl);
   } else {
@@ -1820,7 +1820,7 @@ HttpTransact::OSDNSLookup(State * s)
         TRANSACT_RETURN(HttpTransact::HTTP_API_OS_DNS, HandleCacheOpenReadMiss);
       } else if (s->cache_lookup_result == HttpTransact::CACHE_LOOKUP_SKIPPED) {
         TRANSACT_RETURN(HttpTransact::HTTP_API_OS_DNS, LookupSkipOpenServer);
-        // DNS Lookup is done after LOOKUP Skipped  and after we get response 
+        // DNS Lookup is done after LOOKUP Skipped  and after we get response
         // from the DNS we need to call LookupSkipOpenServer
       } else if (s->cache_lookup_result == CACHE_LOOKUP_HIT_FRESH ||
                  s->cache_lookup_result == CACHE_LOOKUP_HIT_WARNING ||
@@ -1844,7 +1844,7 @@ HttpTransact::StartAccessControl(State *
 {
   //if (s->cop_test_page || s->traffic_net_req || (s->state_machine->authAdapter.disabled() == true)) {
     // Heartbeats should always be allowed.
-    // s->content_control.access = ACCESS_ALLOW;   
+    // s->content_control.access = ACCESS_ALLOW;
     HandleRequestAuthorized(s);
   //  return;
  // }
@@ -1852,7 +1852,7 @@ HttpTransact::StartAccessControl(State *
   // Don't use req_flavor to do the test because if updated
   // urls are remapped, the req_flavor is changed to REV_PROXY.
   //if (s->state_machine->ua_session == NULL) {
-    // Scheduled updates should always be allowed 
+    // Scheduled updates should always be allowed
    // return;
   //}
   // pass the access control logic to the ACC module.
@@ -1926,7 +1926,7 @@ HttpTransact::DecideCacheLookup(State * 
 {
   // Check if a client request is lookupable.
   if (s->redirect_info.redirect_in_process) {
-    // for redirect, we want to skip cache lookup and write into 
+    // for redirect, we want to skip cache lookup and write into
     // the cache directly with the URL before the redirect
     s->cache_info.action = CACHE_DO_NO_ACTION;
     s->current.mode = GENERIC_PROXY;
@@ -2020,7 +2020,7 @@ HttpTransact::DecideCacheLookup(State * 
       s->cache_info.action = CACHE_DO_WRITE;
       LookupSkipOpenServer(s);
     } else {
-      // calling out CACHE_LOOKUP_COMPLETE_HOOK even when the cache 
+      // calling out CACHE_LOOKUP_COMPLETE_HOOK even when the cache
       // lookup is skipped
       s->cache_lookup_result = HttpTransact::CACHE_LOOKUP_SKIPPED;
       if (s->force_dns) {
@@ -2061,7 +2061,7 @@ HttpTransact::LookupSkipOpenServer(State
 
 //////////////////////////////////////////////////////////////////////////////
 // Name       : HandleCacheOpenReadPush
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -2082,7 +2082,7 @@ HttpTransact::HandleCacheOpenReadPush(St
 
 //////////////////////////////////////////////////////////////////////////////
 // Name       : HandlePushResponseHdr
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -2123,7 +2123,7 @@ HttpTransact::HandlePushResponseHdr(Stat
 
 //////////////////////////////////////////////////////////////////////////////
 // Name       : HandlePushCacheWrite
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -2206,7 +2206,7 @@ HttpTransact::HandlePushError(State *s, 
 // Description: the cache lookup succeeded - may have been a hit or a miss
 //
 // Details    :
-//   
+//
 // the cache lookup succeeded. first check if the lookup resulted in
 // a hit or a miss, if the lookup was for an http request.
 // This function just funnels the result into the appropriate
@@ -2284,7 +2284,7 @@ HttpTransact::HandleCacheOpenRead(State 
 //
 //
 // Possible Next States From Here:
-// - 
+// -
 //
 ///////////////////////////////////////////////////////////////////////////////
 void
@@ -2296,8 +2296,8 @@ HttpTransact::issue_revalidate(State * s
 
   if (s->www_auth_content == CACHE_AUTH_FRESH) {
     s->hdr_info.server_request.method_set(HTTP_METHOD_HEAD, HTTP_LEN_HEAD);
-    // The document is fresh in cache and we just want to see if the 
-    // the client has the right credentials 
+    // The document is fresh in cache and we just want to see if the
+    // the client has the right credentials
     // this cache action is just to get us into the hcoofsr function
     s->cache_info.action = CACHE_DO_UPDATE;
     DUMP_HEADER("http_hdrs", &(s->hdr_info.server_request), s->state_machine_id, "Proxy's Request (Conditionalized)");
@@ -2318,7 +2318,7 @@ HttpTransact::issue_revalidate(State * s
       Debug("http_seq", "[HttpTransact::issue_revalidate] cache action: UPDATE");
     }
   } else {
-    // We've looped back around due to missing the write lock 
+    // We've looped back around due to missing the write lock
     //  for the cache.  At this point we want to forget about the cache
     ink_assert(s->cache_info.write_lock_state == CACHE_WL_READ_RETRY);
     s->cache_info.action = CACHE_DO_NO_ACTION;
@@ -2445,7 +2445,7 @@ HttpTransact::HandleCacheOpenReadHitFres
     DebugOn("http_trans", "[HandleCacheOpenReadHitFreshness] request_sent_time      : %ld", s->request_sent_time);
     DebugOn("http_trans", "[HandleCacheOpenReadHitFreshness] response_received_time : %ld", s->response_received_time);
   }
-  // if the plugin has already decided the freshness, we don't need to 
+  // if the plugin has already decided the freshness, we don't need to
   // do it again
   if (s->cache_lookup_result == HttpTransact::CACHE_LOOKUP_NONE) {
     // is the document still fresh enough to be served back to
@@ -2479,7 +2479,7 @@ HttpTransact::HandleCacheOpenReadHitFres
   if (s->cache_lookup_result == HttpTransact::CACHE_LOOKUP_HIT_STALE)
     SET_VIA_STRING(VIA_DETAIL_CACHE_LOOKUP, VIA_DETAIL_MISS_EXPIRED);
 
-  if (!s->force_dns) {          // If DNS is not performed before 
+  if (!s->force_dns) {          // If DNS is not performed before
     if (need_to_revalidate(s)) {
       TRANSACT_RETURN(HTTP_API_CACHE_LOOKUP_COMPLETE, CallOSDNSLookup); // content needs to be revalidated and we did not perform a dns ....calling DNS lookup
     } else {                    // document can be served can cache
@@ -2507,9 +2507,9 @@ HttpTransact::CallOSDNSLookup(State * s)
 // Name       : need_to_revalidate
 // Description: Checks if a document which is in the cache needs to be revalidates
 //
-// Details    : Function calls AuthenticationNeeded and is_cache_response_returnable to determine 
-//              if the cached document can be served 
-/////////////////////////////////////////////////////////////////////////////   
+// Details    : Function calls AuthenticationNeeded and is_cache_response_returnable to determine
+//              if the cached document can be served
+/////////////////////////////////////////////////////////////////////////////
 bool
 HttpTransact::need_to_revalidate(State * s)
 {
@@ -2579,15 +2579,15 @@ HttpTransact::need_to_revalidate(State *
 // Description: handle result of a cache hit
 //
 // Details    :
-//   
+//
 // Cache lookup succeeded and resulted in a cache hit. This means
 // that the Accept* and Etags fields also matched. The cache lookup
 // may have resulted in a vector of alternates (since lookup may
 // be based on a url). A different function (SelectFromAlternates)
 // goes through the alternates and finds the best match. That is
 // then returned to this function. The result may not be sent back
-// to the client, still, if the document is not fresh enough, or 
-// does not have enough authorization, or if the client wants a 
+// to the client, still, if the document is not fresh enough, or
+// does not have enough authorization, or if the client wants a
 // reload, etc. that decision will be made in this routine.
 //
 //
@@ -2599,8 +2599,8 @@ HttpTransact::need_to_revalidate(State *
 // - HttpTransact::SERVE_FROM_CACHE;
 // - result of how_to_open_connection()
 //
-// 
-// For Range requests, we will decide to do simple tunnelling if one of the 
+//
+// For Range requests, we will decide to do simple tunnelling if one of the
 // following conditions hold:
 // - document stale
 // - cached response doesn't have Accept-Ranges and Content-Length
@@ -2661,9 +2661,9 @@ HttpTransact::HandleCacheOpenReadHit(Sta
 
   // the response may not be directly returnable to the client. there
   // are several reasons for this: config may force revalidation or
-  // client may have forced a refresh by sending a Pragma:no-cache 
-  // or a Cache-Control:no-cache, or the client may have sent a 
-  // non-GET/HEAD request for a document that is cached. an example 
+  // client may have forced a refresh by sending a Pragma:no-cache
+  // or a Cache-Control:no-cache, or the client may have sent a
+  // non-GET/HEAD request for a document that is cached. an example
   // of a situation for this is when a client sends a DELETE, PUT
   // or POST request for a url that is cached. except for DELETE,
   // we may actually want to update the cached copy with the contents
@@ -2699,7 +2699,7 @@ HttpTransact::HandleCacheOpenReadHit(Sta
   //Added by YTS Team, yamsat
 
   //At this juncture, the object needs to be revalidated. But check if some other client
-  //is already in the process of revalidation. Looking-up hashtable will enable to find 
+  //is already in the process of revalidation. Looking-up hashtable will enable to find
   //if someone's there.The foll cases arise
   // 1) if URL inserted and revalidation_window_period not expired, then this client will
   //    be served stale object.
@@ -2814,7 +2814,7 @@ HttpTransact::HandleCacheOpenReadHit(Sta
   // cache hit, document is fresh, does not authorization,
   // is valid, etc. etc. send it back to the client.
   //
-  // the important thing to keep in mind is that if we are 
+  // the important thing to keep in mind is that if we are
   // here then we found a match in the cache and the document
   // is fresh and we have enough authorization for it to send
   // it back to the client without revalidating first with the
@@ -2987,7 +2987,7 @@ HttpTransact::build_response_from_cache(
           s->next_action = PROXY_INTERNAL_CACHE_NOOP;
           break;
         } else if (s->range_setup == RANGE_NOT_SATISFIABLE || s->range_setup == RANGE_NOT_HANDLED) {
-          // we switch to tunneing for Range requests either 
+          // we switch to tunneing for Range requests either
           // 1. we need to revalidate or
           // 2. out-of-order Range requests
           Debug("http_seq", "[HttpTransact::HandleCacheOpenReadHit] Out-oforder Range request - tunneling");
@@ -3040,10 +3040,10 @@ HttpTransact::build_response_from_cache(
 
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : handle_cache_write_lock
-// Description: 
+// Description:
 //
 // Details    :
-//   
+//
 //
 //
 // Possible Next States From Here:
@@ -3074,7 +3074,7 @@ HttpTransact::handle_cache_write_lock(St
     //  Write failed but retried and got a vector to read
     //  We need to clean up our state so that transact does
     //  not assert later on.  Then handle the open read hit
-    //  
+    //
     s->request_sent_time = UNDEFINED_TIME;
     s->response_received_time = UNDEFINED_TIME;
     s->cache_info.action = CACHE_DO_LOOKUP;
@@ -3106,8 +3106,8 @@ HttpTransact::handle_cache_write_lock(St
   if (s->cache_info.write_lock_state == CACHE_WL_READ_RETRY) {
     s->hdr_info.server_request.destroy();
 
-    // We need to cleanup SDK handles to cached hdrs 
-    //   since those headers are no longer good as we've closed 
+    // We need to cleanup SDK handles to cached hdrs
+    //   since those headers are no longer good as we've closed
     //   the orginal cache read vc and replaced it with a new cache
     //   read vc on the write lock read retry loop
     if (s->cache_req_hdr_heap_handle) {
@@ -3146,7 +3146,7 @@ HttpTransact::handle_cache_write_lock(St
 // Description: cache looked up, miss or hit, but needs authorization
 //
 // Details    :
-//   
+//
 //
 //
 // Possible Next States From Here:
@@ -3249,10 +3249,10 @@ HttpTransact::HandleCacheOpenReadMiss(St
 #ifndef INK_NO_ICP
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : HandleICPLookup
-// Description: 
+// Description:
 //
 // Details    :
-//   
+//
 //
 //
 // Possible Next States From Here:
@@ -3326,7 +3326,7 @@ HttpTransact::HandleICPLookup(State * s)
 // Description: called for ssl tunnelling
 //
 // Details    :
-//   
+//
 // when the method is CONNECT, we open a raw connection to the origin
 // server. if the open succeeds, then do ssl tunnelling from the client
 // to the host.
@@ -3904,10 +3904,10 @@ HttpTransact::delete_srv_entry(State * s
           TRANSACT_RETURN(OS_RR_MARK_DOWN, ReDNSRoundRobin);
         }
 
-        /* 
+        /*
            assert: at this point, we have (inside still_ok_hosts) those SRV records that were NOT pointing to the
            same hostname as the one that just failed; lets reenqueue those into the HostDB and perform another "lookup"
-           which [hopefully] will find these records inside the HostDB and use them. 
+           which [hopefully] will find these records inside the HostDB and use them.
          */
 
         new_r->ip_timeout_interval = 45;        /* good for 45 seconds, then lets re-validate? */
@@ -3965,7 +3965,7 @@ HttpTransact::delete_srv_entry(State * s
 
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : delete_server_rr_entry
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -3997,7 +3997,7 @@ HttpTransact::delete_server_rr_entry(Sta
 
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : retry_server_connection_not_open
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -4054,7 +4054,7 @@ HttpTransact::retry_server_connection_no
 
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : handle_server_connection_not_open
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -4344,7 +4344,7 @@ HttpTransact::build_response_copy(State 
 
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : handle_cache_operation_on_forward_server_response
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -4829,7 +4829,7 @@ HttpTransact::handle_cache_operation_on_
 
 ///////////////////////////////////////////////////////////////////////////////
 // Name       : handle_no_cache_operation_on_forward_server_response
-// Description: 
+// Description:
 //
 // Details    :
 //
@@ -4876,7 +4876,7 @@ HttpTransact::handle_no_cache_operation_
     if (!is_request_conditional(&s->hdr_info.client_request)) {
       // bogus server response. not a conditional request
       // from the client and probably not a conditional
-      // request from the proxy. 
+      // request from the proxy.
 
       // since this is bad, insert warning header into client response
       warn_text = "Proxy received unexpected 304 response; content may be stale";
@@ -5076,7 +5076,7 @@ HttpTransact::set_header_for_transform(S
   s->hdr_info.transform_response.create(HTTP_TYPE_RESPONSE);
   s->hdr_info.transform_response.copy(base_header);
 
-  // Nuke the content length since 1) the transform will probably 
+  // Nuke the content length since 1) the transform will probably
   //   change it.  2) it would only be valid for the first transform
   //   in the chain
   s->hdr_info.transform_response.field_delete(MIME_FIELD_CONTENT_LENGTH, MIME_LEN_CONTENT_LENGTH);
@@ -5103,7 +5103,7 @@ HttpTransact::set_headers_for_cache_writ
   //  Nasty hack. The set calls for
   //  marshalled types current do handle something being
   //  set to itself.  Make the check here for that case.
-  //  Why the request url is set before a copy made is 
+  //  Why the request url is set before a copy made is
   //  quite beyond me.  Seems like a unsafe practice so
   //  FIX ME!
 
@@ -5221,11 +5221,11 @@ HttpTransact::merge_response_header_with
     if (name == MIME_FIELD_WARNING) {
       continue;
     }
-    // Copy all remaining headers with replacement      
+    // Copy all remaining headers with replacement
 
     // Duplicate header fields cause a bug problem
     //   since we need to duplicate with replacement.
-    //   Without dups, we can just nuke what is already 
+    //   Without dups, we can just nuke what is already
     //   there in the cached header.  With dups, we
     //   can't do this because what is already there
     //   may be a dup we've already copied in.  If
@@ -5234,7 +5234,7 @@ HttpTransact::merge_response_header_with
     //   them in the cached response and then add in
     //   the remaining fields one by one from the
     //   response header
-    //    
+    //
     if (field->m_next_dup) {
       if (dups_seen == false) {
         MIMEField *dfield;
@@ -5286,7 +5286,7 @@ HttpTransact::merge_warning_header(HTTPH
   //         doesn't deal with warning headers.
   //    2) If there are 1xx warning codes in the cached
   //         header, they need to be removed.  Removal
-  //         is difficult since the hdrs don't comma 
+  //         is difficult since the hdrs don't comma
   //         separate values, so build up a new header
   //         piecemal.  Very slow but shouldn't happen
   //         very often
@@ -5449,7 +5449,7 @@ HttpTransact::get_ka_info_from_host_db(S
 //   0: never add no-cache headers to MSIE requests
 //   1: add no-cache headers to IMS MSIE requests
 //   2: add no-cache headers to all MSIE requests
-// 
+//
 //////////////////////////////////////////////////////////////////////////
 
 void
@@ -5705,8 +5705,8 @@ HttpTransact::RequestError_t HttpTransac
   }
   // Check whether a Host header field is missing in the request.
   if (!incoming_hdr->presence(MIME_PRESENCE_HOST) && incoming_hdr->version_get() != HTTPVersion(0, 9)) {
-    // Update the number of incoming 1.0 or 1.1 requests that do 
-    // not contain Host header fields.  
+    // Update the number of incoming 1.0 or 1.1 requests that do
+    // not contain Host header fields.
     HTTP_INCREMENT_TRANS_STAT(http_missing_host_hdr_stat);
   }
   // Did the client send a "TE: identity;q=0"? We have to respond
@@ -5987,7 +5987,7 @@ HttpTransact::initialize_state_variables
   //  when they are configured to use a proxy.  Proxy-Connection
   //  is not in the spec but was added to prevent problems
   //  with a dumb proxy forwarding all headers (including "Connection")
-  //  to the origin server and confusing it.  However, the 
+  //  to the origin server and confusing it.  However, the
   //  "Proxy-Connection" solution breaks down with transparent
   //  backbone caches since the request could be from dumb
   //  downstream caches that are forwarding the "Proxy-Connection"
@@ -6216,8 +6216,8 @@ HttpTransact::initialize_state_variables
         s->hdr_info.response_content_length = HTTP_UNDEFINED_CL;
         s->hdr_info.trust_response_cl = false;
 
-        // OBJECTIVE: Since we are dechunking the request remove the 
-        //   chunked value If this is the only value, we need to remove 
+        // OBJECTIVE: Since we are dechunking the request remove the
+        //   chunked value If this is the only value, we need to remove
         //    the whole field.
         MIMEField *new_enc_field = NULL;
         HdrCsvIter new_enc_iter;
@@ -6564,7 +6564,7 @@ HttpTransact::is_response_cacheable(Stat
     return (false);
 
   // Check whether the response is cachable based on its cookie
-  // If there are cookies in response but a ttl is set, allow caching 
+  // If there are cookies in response but a ttl is set, allow caching
   if ((s->cache_control.ttl_in_cache <= 0) &&
       do_cookies_prevent_caching((int) s->http_config_param->cache_responses_to_cookies, request, response)) {
     Debug("http_trans", "[is_response_cacheable] " "response has uncachable cookies, response is not cachable");
@@ -6628,7 +6628,7 @@ HttpTransact::is_response_cacheable(Stat
         break;
 
       case HttpConfigParams::CACHE_REQUIRED_HEADERS_AT_LEAST_LAST_MODIFIED:
-        if (!response->presence(MIME_PRESENCE_EXPIRES) && !(response->get_cooked_cc_mask() & cc_mask) && 
+        if (!response->presence(MIME_PRESENCE_EXPIRES) && !(response->get_cooked_cc_mask() & cc_mask) &&
             !response->get_last_modified()) {
           Debug("http_trans", "[is_response_cacheable] " "last_modified, expires, or max-age is required");
 
@@ -6746,7 +6746,7 @@ HttpTransact::is_response_cacheable(Stat
 //         if (! (response->is_cache_control_set(HTTP_VALUE_MUST_REVALIDATE)) &&
 //             ! (response->is_cache_control_set(HTTP_VALUE_PROXY_REVALIDATE)) &&
 //             ! (response->is_cache_control_set(HTTP_VALUE_PUBLIC))) {
-	    
+
 	    Debug("http_trans", "[is_response_cacheable] request has AUTHORIZATION - not cacheable");
             return(false);
 //         }
@@ -6981,14 +6981,14 @@ HttpTransact::is_response_valid(State * 
 // Description: uses some metric to force this transaction to be proxy-only
 //
 // Details    :
-//   
+//
 // Some metric may be employed to force the traffic server to enter
 // a proxy-only mode temporarily. This function is called to determine
 // if the current transaction should be proxy-only. The function is
 // called from initialize_state_variables_from_request and is used to
 // set s->current.mode to TUNNELLING_PROXY and just for safety to set
 // s->cache_info.action to CACHE_DO_NO_ACTION.
-// 
+//
 // Currently the function is just a placeholder and always returns false.
 //
 ///////////////////////////////////////////////////////////////////////////////
@@ -7815,12 +7815,12 @@ HttpTransact::calculate_document_freshne
 
 
 ////////////////////////////////////////////////////////////////////////////////////
-//  int HttpTransact::calculate_freshness_fuzz() 
+//  int HttpTransact::calculate_freshness_fuzz()
 //
 //    This function trys to revents many, many simulatenous revalidations in
 //     reverse proxy situations.  Statistically introduce a fuzz factor that
 //     brings revalidation forward for a small percentage of the requests/
-//     The hope is that is that the document early by a selected few, and 
+//     The hope is that is that the document early by a selected few, and
 //     the headers are updated in the cache before the regualr freshness
 //     limit is actually reached
 ////////////////////////////////////////////////////////////////////////////////////
@@ -7948,7 +7948,7 @@ HttpTransact::Freshness_t HttpTransact::
                                                    config->cache_guaranteed_max_lifetime, s->plugin_set_expire_time, s);
   HTTP_DEBUG_ASSERT(fresh_limit >= 0);
 
-  // Fuzz the freshness to prevent too many revalidates to popular 
+  // Fuzz the freshness to prevent too many revalidates to popular
   //  documents at the same time
   if (s->http_config_param->freshness_fuzz_time >= 0) {
     fresh_limit = fresh_limit - calculate_freshness_fuzz(s, fresh_limit);
@@ -8373,7 +8373,7 @@ HttpTransact::build_request(State * s, H
     int host_len;
     const char *host = url->host_get(&host_len);
 
-    // Add a ':port' to the HOST header if the request is not going 
+    // Add a ':port' to the HOST header if the request is not going
     // to the default port.
     int port = url->port_get();
     if (port != url_canonicalize_port(URL_TYPE_HTTP, 0)) {
@@ -8964,8 +8964,8 @@ ink_cluster_time(void)
 #endif
 
   highest_delta = (int) HttpConfig::m_master.cluster_time_delta;
-//     highest_delta = 
-//      lmgmt->record_data->readInteger("proxy.process.http.cluster_delta", 
+//     highest_delta =
+//      lmgmt->record_data->readInteger("proxy.process.http.cluster_delta",
 //                                      &found);
 //     if (! found) {
 //      HTTP_DEBUG_ASSERT(!"Highest delta config value not found!");
@@ -9547,15 +9547,15 @@ HttpTransact::delete_warning_value(HTTPH
 
 
 ////////////////////////////////////////////////////////////////////////////////////
-//  
+//
 // Name    : is_connection_collapse_checks_success
 //
-// Details : This function is used to check for the success of various connection 
+// Details : This function is used to check for the success of various connection
 //           collapsing parameters.Connection collapsing is disabled in the foll cases
 //              1) If Cache DISK not present
 //              2) If read_while_writing is disabled
 //              3) If request is Https
-// 
+//
 // YTS Team, yamsat
 ////////////////////////////////////////////////////////////////////////////////////
 
@@ -9578,15 +9578,15 @@ HttpTransact::is_connection_collapse_che
 // Name         : ConnectionCollapsing
 //
 // Details      : This function is called from OSDNSLookup(). Checks if there is an
-//                ongoing transaction already in progress for the same object.This 
+//                ongoing transaction already in progress for the same object.This
 //                is done by looking-up the hashtable.There would be two cases here.
 //              1) If entry found, check if URL headers match perfectly. then return
 //                 for scheduling this client to be piggy backed.
-//              2) If entry not found in Hashtable, insert an entry and return with 
+//              2) If entry not found in Hashtable, insert an entry and return with
 //                 status indicating normal procedure for connecting to OriginServer
 //              3) If entry could not be inserted,this means that there was someother
 //                 client who has inserted the request.Therefore, return with a status
-//                 indicating CACHE_RELOOKUP.Then, this client could get the object 
+//                 indicating CACHE_RELOOKUP.Then, this client could get the object
 //                 from the cache because of the read-while-write behavior
 //
 // YTS Team, yamsat

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.cc Thu May 13 17:43:56 2010
@@ -132,7 +132,7 @@ do_strings_match_weakly(const char *raw_
     if ((tag->len == 1) && (tag->str[0] == '*'))
       return true;
 
-    // strip off the leading 'W/' and quotation marks from the 
+    // strip off the leading 'W/' and quotation marks from the
     // current tag, then compare for equality with above tag.
     cur_tag = find_etag(tag->str, tag->len, &cur_tag_len);
     if ((cur_tag_len == etag_length) && (strncmp(cur_tag, etag_start, cur_tag_len) == 0))
@@ -997,7 +997,7 @@ encoding_wildcard:
       return (float) -1.0;
     }
   }
-//      q = (float)-1.0;        
+//      q = (float)-1.0;
   return (q);
 }
 
@@ -1486,7 +1486,7 @@ L1:
   }
 
   // Handling If-Range header:
-  // As Range && If-Range don't occur often, we want to put the 
+  // As Range && If-Range don't occur often, we want to put the
   // If-Range code in the end
   if (request->presence(MIME_PRESENCE_RANGE) && request->presence(MIME_PRESENCE_IF_RANGE)) {
     int raw_len, comma_sep_list_len;

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactCache.h Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
    HttpTransactCache.h --
    Created On      : Thu Mar 26 17:19:35 1998
 
-   
+
  ****************************************************************************/
 #if !defined (_HttpTransactCache_h_)
 #define _HttpTransactCache_h_

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.cc Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
    HttpTransactHeaders.cc --
    Created On      : Fri Mar 27 12:15:55 1998
 
-   
+
  ****************************************************************************/
 #include "inktomi++.h"
 
@@ -964,7 +964,7 @@ HttpTransactHeaders::generate_and_set_wu
     // 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 
+    // 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;
@@ -1095,7 +1095,7 @@ HttpTransactHeaders::insert_warning_head
   char *warning_text = NULL;
   int bufsize, i, warning_text_len;
 
-  // + 23 for 20 possible digits of warning code (long long max 
+  // + 23 for 20 possible digits of warning code (long long max
   //  digits) & 2 spaces & the string terminator
   bufsize = http_config_param->proxy_response_via_string_len + 23;
   if (warn_text != NULL)
@@ -1155,18 +1155,18 @@ HttpTransactHeaders::insert_server_heade
 // Name       : insert_via_header_in_request
 // Description: takes in existing via_string and inserts it in header
 //
-// Input      : 
-// Output     : 
+// Input      :
+// Output     :
 //
 // Details    :
-//   
+//
 // [u<client-stuff> l<cache-lookup-stuff> o<server-stuff> f<cache-fill-stuff> p<proxy-stuff>]
 //
 //      client stuff
 //              I       IMS
 //              N       no-cache
 //              A       accept headers
-//              C       cookie          
+//              C       cookie
 //
 //      cache lookup stuff
 //              M       miss

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTransactHeaders.h Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
    HttpTransactHeaders.h --
    Created On      : Fri Mar 27 12:13:52 1998
 
-   
+
  ****************************************************************************/
 #if !defined (_HttpTransactHeaders_h_)
 #define _HttpTransactHeaders_h_

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.cc Thu May 13 17:43:56 2010
@@ -22,12 +22,12 @@
  */
 
 /****************************************************************************
- 
+
    HttpTunnel.cc
- 
+
    Description:
- 
-   
+
+
 ****************************************************************************/
 
 #include "ink_config.h"
@@ -861,8 +861,8 @@ HttpTunnel::producer_run(HttpTunnelProdu
   }
 
   //YTS Team, yamsat Plugin
-  // Allocate and copy partial POST data to buffers. Check for the various parameters 
-  // including the maximum configured post data size 
+  // Allocate and copy partial POST data to buffers. Check for the various parameters
+  // including the maximum configured post data size
   if (p->alive && sm->t_state.method == HTTP_WKSIDX_POST && sm->enable_redirection
       && sm->redirection_tries == 0 && (p->vc_type == HT_HTTP_CLIENT)) {
     Debug("http_redirect", "[HttpTunnel::producer_run] client post: %d max size: %d",
@@ -889,7 +889,7 @@ HttpTunnel::producer_run(HttpTunnelProdu
     // If there is data to process in the buffer, do it now
     if (p->chunked_handler.dechunked_reader->read_avail())
       producer_handler(VC_EVENT_READ_READY, p);
-  } else if (p->do_dechunking || p->do_chunked_passthru) {      
+  } else if (p->do_dechunking || p->do_chunked_passthru) {
     // remove the dechunked reader marker so that it doesn't act like a buffer guard
     if (p->do_dechunking)
       p->chunked_handler.dechunked_buffer->dealloc_reader(dechunked_buffer_start);
@@ -912,8 +912,8 @@ HttpTunnel::producer_run(HttpTunnelProdu
       producer_handler(VC_EVENT_READ_READY, p);
     } else if (sm->redirection_tries > 0 && p->vc_type == HT_HTTP_CLIENT) {     // read_avail() == 0
       // [bug 2579251]
-      // Ugh, this is horrible but in the redirect case they are running a the tunnel again with the 
-      // now closed/empty producer to trigger PRECOMPLETE.  If the POST was chunked, producer_n is set 
+      // Ugh, this is horrible but in the redirect case they are running a the tunnel again with the
+      // now closed/empty producer to trigger PRECOMPLETE.  If the POST was chunked, producer_n is set
       // (incorrectly) to INT_MAX.  It needs to be set to 0 to prevent triggering another read.
       producer_n = 0;
     }

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpTunnel.h Thu May 13 17:43:56 2010
@@ -22,12 +22,12 @@
  */
 
 /****************************************************************************
- 
+
    HttpTunnel.h
- 
+
    Description:
- 
-   
+
+
 ****************************************************************************/
 
 #ifndef _HTTP_TUNNEL_H_

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.cc Thu May 13 17:43:56 2010
@@ -27,9 +27,9 @@
 
    Description:
 	An HttpSM sub class for support scheduled update functionality
-	
 
-   
+
+
  ****************************************************************************/
 
 

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/HttpUpdateSM.h Thu May 13 17:43:56 2010
@@ -27,9 +27,9 @@
 
    Description:
 	An HttpSM sub class for support scheduled update functionality
-	
 
-   
+
+
  ****************************************************************************/
 
 #ifndef _HTTP_SM_UPDATE_H_

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/AclFiltering.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/AclFiltering.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/AclFiltering.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/AclFiltering.h Thu May 13 17:43:56 2010
@@ -48,7 +48,7 @@ typedef struct src_ip_info_t
 } SRC_IP_INFO;
 
 /**
- * 
+ *
 **/
 class acl_filter_rule
 {
@@ -70,7 +70,7 @@ public:
   int method_array[ACL_FILTER_MAX_METHODS];     // any HTTP method (actually only WKSIDX from HTTP.cc)
   int method_idx[ACL_FILTER_MAX_METHODS];       // HTTP method index (actually method flag)
 
-  // src_ip    
+  // src_ip
   int src_ip_cnt;               // how many valid src_ip rules we have
   SRC_IP_INFO src_ip_array[ACL_FILTER_MAX_SRC_IP];
     acl_filter_rule();

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.cc Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@ remap_plugin_info_init
   instance_of_remap_plugin_info_init;
 
 /**
- * 
+ *
 **/
 remap_plugin_info_init::remap_plugin_info_init()
 {
@@ -38,7 +38,7 @@ remap_plugin_info_init::remap_plugin_inf
 
 
 /**
- * 
+ *
 **/
 remap_plugin_info::remap_plugin_info(char *_path)
   :
@@ -62,7 +62,7 @@ fp_tsremap_os_response(NULL)
 
 
 /**
- * 
+ *
 **/
 remap_plugin_info::~remap_plugin_info()
 {

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPluginInfo.h Thu May 13 17:43:56 2010
@@ -45,7 +45,7 @@
 class url_mapping;
 
 /**
- * 
+ *
 **/
 class remap_plugin_info
 {
@@ -75,7 +75,7 @@ public:
 
 
 /**
- * 
+ *
 **/
 class remap_plugin_info_init
 {

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPlugins.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPlugins.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPlugins.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/RemapPlugins.cc Thu May 13 17:43:56 2010
@@ -134,7 +134,7 @@ RemapPlugins::run_plugin(remap_plugin_in
   rri.remap_from_path = fromPath;
   rri.remap_from_path_size = fromPathLen;
 
-  // Set "remap to" path        
+  // Set "remap to" path
   rri.remap_to_path = toPath;
   rri.remap_to_path_size = toPathLen;
 
@@ -368,7 +368,7 @@ RemapPlugins::run_single_remap()
   }
 
   if ((!plugin && _cur == 0) || plugin_retcode == 0) {
-    // Handle cross protocol mapping when there are no remap plugin(s) 
+    // Handle cross protocol mapping when there are no remap plugin(s)
     // or if plugin did not make any modifications.
     Debug("url_rewrite", "no plugins available for this request");
     int to_len, from_len;
@@ -574,7 +574,7 @@ RemapPlugins::run_remap(int event, Event
     Debug("url_rewrite", "handling immediate event inside RemapPlugins::run_remap");
     ret = run_single_remap();
                         /**
-			 * If ret !=0 then we are done with this processor and we call back into the SM; 
+			 * If ret !=0 then we are done with this processor and we call back into the SM;
 			 * otherwise, we call this function again immediately (which really isn't immediate)
 			 * thru the eventProcessor, thus forcing another run of run_single_remap() which will
 			 * then operate on _request_url, etc performing additional remaps (mainly another plugin run)

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/StringHash.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/StringHash.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/StringHash.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/StringHash.cc Thu May 13 17:43:56 2010
@@ -60,7 +60,7 @@ StringHash::StringHash(int _hash_size, b
 
   if ((hash = (StringHashEntry **) xmalloc(hash_size * sizeof(StringHashEntry *))) != NULL)
     memset(hash, 0, hash_size * sizeof(StringHashEntry *));
-  //printf("StringHash::StringHash  hash = 0x%0X, mask = 0x%0lX, hash_mask_size = %d\n",hash_size,(long)hash_mask,hash_mask_size);   
+  //printf("StringHash::StringHash  hash = 0x%0X, mask = 0x%0lX, hash_mask_size = %d\n",hash_size,(long)hash_mask,hash_mask_size);
 }
 
 StringHash::~StringHash()

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/Trie.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/Trie.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/Trie.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/Trie.h Thu May 13 17:43:56 2010
@@ -48,12 +48,12 @@ public:
   const ValuePointerList &GetValues() const { return m_value_list; }
 
   virtual ~Trie() { Clear(); };
-  
+
 
 private:
   static const int N_NODE_CHILDREN = 256;
 
-  class Node 
+  class Node
   {
   public:
     T value;
@@ -73,7 +73,7 @@ private:
 
   Node m_root;
   ValuePointerList m_value_list;
-  
+
   void _CheckArgs(const char *key, int &key_len) const;
   void _Clear(Node *node);
 
@@ -89,15 +89,15 @@ Trie<T>::_CheckArgs(const char *key, int
 {
   if (!key) {
     key_len = 0;
-  } 
+  }
   else if (key_len == -1) {
     key_len = strlen(key);
   }
 }
 
-template<typename T> 
-bool 
-Trie<T>::Insert(const char *key, const T &value, int rank, int key_len /* = -1 */) 
+template<typename T>
+bool
+Trie<T>::Insert(const char *key, const T &value, int rank, int key_len /* = -1 */)
 {
   _CheckArgs(key, key_len);
 
@@ -142,13 +142,13 @@ Trie<T>::Insert(const char *key, const T
   }
   return retval;
 }
-  
+
 template<typename T>
 bool
 Trie<T>::Search(const char *key, T *&value_ptr, int key_len /* = -1 */)
 {
   _CheckArgs(key, key_len);
-  
+
   Node *found_node = 0;
   Node *curr_node = &m_root;
   int i = 0;
@@ -185,7 +185,7 @@ Trie<T>::Search(const char *key, T *&val
 
 template<typename T>
 void
-Trie<T>::_Clear(Node *node) 
+Trie<T>::_Clear(Node *node)
 {
   Node *child;
   for (int i = 0; i < N_NODE_CHILDREN; ++i) {

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.cc Thu May 13 17:43:56 2010
@@ -24,19 +24,19 @@
 #include "UrlMapping.h"
 
 /**
- * 
+ *
 **/
 url_mapping::url_mapping(int rank /* = 0 */)
-  : from_path_len(0), fromURL(), toURL(), homePageRedirect(false), unique(false), default_redirect_url(false), 
-    optional_referer(false), negative_referer(false), no_negative_cache(false), wildcard_from_scheme(false), 
-    pristine_host_hdr(-1), chunking_enabled(-1), tag(NULL), filter_redirect_url(NULL), referer_list(0), 
+  : from_path_len(0), fromURL(), toURL(), homePageRedirect(false), unique(false), default_redirect_url(false),
+    optional_referer(false), negative_referer(false), no_negative_cache(false), wildcard_from_scheme(false),
+    pristine_host_hdr(-1), chunking_enabled(-1), tag(NULL), filter_redirect_url(NULL), referer_list(0),
     redir_chunk_list(0), filter(NULL), _plugin_count(0), _cur_instance_count(0), _rank(rank)
 { /* nop */ ;
 }
 
 
 /**
- * 
+ *
 **/
 bool url_mapping::add_plugin(remap_plugin_info * i)
 {
@@ -47,7 +47,7 @@ bool url_mapping::add_plugin(remap_plugi
 
 
 /**
- * 
+ *
 **/
 remap_plugin_info *
 url_mapping::get_plugin(unsigned int index)
@@ -75,7 +75,7 @@ url_mapping::get_plugin(unsigned int ind
 
 
 /**
- * 
+ *
 **/
 bool url_mapping::set_instance(remap_plugin_info * p, ihandle * h)
 {
@@ -87,7 +87,7 @@ bool url_mapping::set_instance(remap_plu
 
 
 /**
- * 
+ *
 **/
 ihandle *
 url_mapping::get_instance(remap_plugin_info * p)
@@ -100,7 +100,7 @@ url_mapping::get_instance(remap_plugin_i
 }
 
 /**
- * 
+ *
 **/
 ihandle *
 url_mapping::get_another_instance(remap_plugin_info * p)
@@ -119,7 +119,7 @@ url_mapping::get_another_instance(remap_
 
 
 /**
- * 
+ *
 **/
 void
 url_mapping::delete_instance(remap_plugin_info * p)
@@ -136,7 +136,7 @@ url_mapping::delete_instance(remap_plugi
 
 
 /**
- * 
+ *
 **/
 url_mapping::~url_mapping()
 {
@@ -181,7 +181,7 @@ url_mapping::~url_mapping()
 
 
 /**
- * 
+ *
 **/
 url_mapping_ext::url_mapping_ext(url_mapping * mapping)
 :m_mapping(mapping)
@@ -190,7 +190,7 @@ url_mapping_ext::url_mapping_ext(url_map
 
 
 /**
- * 
+ *
 **/
 url_mapping_ext::~url_mapping_ext()
 {
@@ -199,7 +199,7 @@ url_mapping_ext::~url_mapping_ext()
 
 
 /**
- * 
+ *
 **/
 const char *
 url_mapping_ext::getToHost(int *lenp)
@@ -209,7 +209,7 @@ url_mapping_ext::getToHost(int *lenp)
 
 
 /**
- * 
+ *
 **/
 const char *
 url_mapping_ext::getToPath(int *lenp)
@@ -219,7 +219,7 @@ url_mapping_ext::getToPath(int *lenp)
 
 
 /**
- * 
+ *
 **/
 URL *
 url_mapping_ext::getFromURL()
@@ -229,7 +229,7 @@ url_mapping_ext::getFromURL()
 
 
 /**
- * 
+ *
 **/
 URL *
 url_mapping_ext::getToURL()
@@ -239,7 +239,7 @@ url_mapping_ext::getToURL()
 
 
 /**
- * 
+ *
 **/
 redirect_tag_str *
 redirect_tag_str::parse_format_redirect_url(char *url)
@@ -283,7 +283,7 @@ redirect_tag_str::parse_format_redirect_
 
 
 /**
- * 
+ *
 **/
 referer_info::referer_info(char *_ref, bool * error_flag, char *errmsgbuf, int errmsgbuf_size):next(0), referer(0), referer_size(0), any(false), negative(false),
 regx_valid(false)
@@ -320,7 +320,7 @@ regx_valid(false)
 
 
 /**
- * 
+ *
 **/
 referer_info::~referer_info()
 {

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMapping.h Thu May 13 17:43:56 2010
@@ -40,7 +40,7 @@
 #endif
 
 /**
- * Used to store http referer strings (and/or regexp) 
+ * Used to store http referer strings (and/or regexp)
 **/
 class referer_info
 {
@@ -57,7 +57,7 @@ public:
 };
 
 /**
- * 
+ *
 **/
 class redirect_tag_str
 {
@@ -82,7 +82,7 @@ public:
 };
 
 /**
- * 
+ *
 **/
 class url_mapping_ext
 {

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.cc Thu May 13 17:43:56 2010
@@ -33,14 +33,14 @@ UrlMappingPathIndex::Insert(url_mapping 
   const char *from_path;
 
   trie = _GetTrie(&(mapping->fromURL), scheme_idx, port);
-  
+
   if (!trie) {
     trie = new UrlMappingTrie();
     m_tries.insert(UrlMappingGroup::value_type(UrlMappingTrieKey(scheme_idx, port), trie));
     Debug("UrlMappingPathIndex::Insert", "Created new trie for scheme index, port combo <%d, %d>",
           scheme_idx, port);
   }
-  
+
   from_path = mapping->fromURL.path_get(&from_path_len);
   if (!trie->Insert(from_path, mapping, mapping->getRank(), from_path_len)) {
     Error("Couldn't insert into trie!");
@@ -60,7 +60,7 @@ UrlMappingPathIndex::Search(URL *request
   const char *path;
 
   trie = _GetTrie(request_url, scheme_idx, request_port, normal_search);
-  
+
   if (!trie) {
     Debug("UrlMappingPathIndex::Search", "No mappings exist for scheme index, port combo <%d, %d>",
           scheme_idx, request_port);
@@ -73,7 +73,7 @@ UrlMappingPathIndex::Search(URL *request
     goto lFail;
   }
   return *retval;
-  
+
 lFail:
   return 0;
 }
@@ -81,7 +81,7 @@ lFail:
 void
 UrlMappingPathIndex::GetMappings(MappingList &mapping_list) const
 {
-  for (UrlMappingGroup::const_iterator group_iter = m_tries.begin(); 
+  for (UrlMappingGroup::const_iterator group_iter = m_tries.begin();
        group_iter != m_tries.end(); ++group_iter) {
     const UrlMappingTrie::ValuePointerList &value_pointers = group_iter->second->GetValues();
     for (UrlMappingTrie::ValuePointerList::const_iterator list_iter = value_pointers.begin();

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlMappingPathIndex.h Thu May 13 17:43:56 2010
@@ -41,12 +41,12 @@ public:
   url_mapping *Search(URL *request_url, int request_port, bool normal_search = true) const;
 
   typedef std::list<url_mapping *> MappingList;
-  
+
   void GetMappings(MappingList &mapping_list) const;
 
   void Clear();
 
-  virtual ~UrlMappingPathIndex() 
+  virtual ~UrlMappingPathIndex()
   {
     Clear();
   }
@@ -54,12 +54,12 @@ public:
 
 private:
   typedef Trie<url_mapping *> UrlMappingTrie;
-  struct UrlMappingTrieKey 
+  struct UrlMappingTrieKey
   {
     int scheme_wks_idx;
     int port;
     UrlMappingTrieKey(int idx, int p) : scheme_wks_idx(idx), port(p) { };
-    bool operator <(const UrlMappingTrieKey &rhs) const 
+    bool operator <(const UrlMappingTrieKey &rhs) const
     {
       if (scheme_wks_idx == rhs.scheme_wks_idx) {
         return (port < rhs.port);
@@ -67,10 +67,10 @@ private:
       return (scheme_wks_idx < rhs.scheme_wks_idx);
     };
   };
-  
+
   typedef std::map<UrlMappingTrieKey, UrlMappingTrie *> UrlMappingGroup;
   UrlMappingGroup m_tries;
-    
+
   // make copy-constructor and assignment operator private
   // till we properly implement them
   UrlMappingPathIndex(const UrlMappingPathIndex &rhs) { };
@@ -91,7 +91,7 @@ private:
     }
     return 0;
   };
-  
+
 };
 
 #endif // _URL_MAPPING_PATH_INDEX_H

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.cc Thu May 13 17:43:56 2010
@@ -505,9 +505,9 @@ http_default_redirect_url(NULL), num_rul
 num_rules_redirect_temporary(0), remap_pi_list(NULL)
 {
 
-  forward_mappings.hash_lookup = reverse_mappings.hash_lookup = 
+  forward_mappings.hash_lookup = reverse_mappings.hash_lookup =
     permanent_redirects.hash_lookup = temporary_redirects.hash_lookup = NULL;
-  
+
   char *config_file = NULL;
 
   ink_assert(file_var_in != NULL);
@@ -670,7 +670,7 @@ UrlRewrite::_destroyTable(InkHashTable *
     for (ht_entry = ink_hash_table_iterator_first(h_table, &ht_iter); ht_entry != NULL;) {
       item = (UrlMappingPathIndex *) ink_hash_table_entry_value(h_table, ht_entry);
       item->GetMappings(mappings);
-      for (UrlMappingPathIndex::MappingList::iterator mapping_iter = mappings.begin(); 
+      for (UrlMappingPathIndex::MappingList::iterator mapping_iter = mappings.begin();
            mapping_iter != mappings.end(); ++mapping_iter) {
         delete *mapping_iter;
       }
@@ -723,7 +723,7 @@ UrlRewrite::PrintTable(InkHashTable * h_
   url_mapping *um;
 
   for (ht_entry = ink_hash_table_iterator_first(h_table, &ht_iter); ht_entry != NULL;) {
-    value = (UrlMappingPathIndex *) ink_hash_table_entry_value(h_table, ht_entry); 
+    value = (UrlMappingPathIndex *) ink_hash_table_entry_value(h_table, ht_entry);
     value->GetMappings(mappings);
     for (UrlMappingPathIndex::MappingList::iterator mapping_iter = mappings.begin();
          mapping_iter != mappings.end(); ++mapping_iter) {
@@ -1576,7 +1576,7 @@ UrlRewrite::BuildTable()
   bool is_cur_mapping_regex;
   const char *type_id_str;
   bool add_result;
-  
+
   ink_assert(forward_mappings.empty());
   ink_assert(reverse_mappings.empty());
   ink_assert(permanent_redirects.empty());
@@ -1866,7 +1866,7 @@ UrlRewrite::BuildTable()
     // been removed.
 
 
-    /* 
+    /*
        commenting these out
      */
     // RemoveTrailingSlash(&new_mapping->toURL);
@@ -1904,22 +1904,22 @@ UrlRewrite::BuildTable()
     switch (maptype) {
     case FORWARD_MAP:
     case FORWARD_MAP_REFERER:
-      if ((add_result = _addToStore(forward_mappings, new_mapping, reg_map, fromHost_lower, 
+      if ((add_result = _addToStore(forward_mappings, new_mapping, reg_map, fromHost_lower,
                                     is_cur_mapping_regex, num_rules_forward)) == true) {
         SetHomePageRedirectFlag(new_mapping);   // @todo: is this applicable to regex mapping too?
       }
       break;
     case REVERSE_MAP:
-      add_result = _addToStore(reverse_mappings, new_mapping, reg_map, fromHost_lower, 
+      add_result = _addToStore(reverse_mappings, new_mapping, reg_map, fromHost_lower,
                                is_cur_mapping_regex, num_rules_reverse);
       new_mapping->homePageRedirect = false;
       break;
     case PERMANENT_REDIRECT:
-      add_result = _addToStore(permanent_redirects, new_mapping, reg_map, fromHost_lower, 
+      add_result = _addToStore(permanent_redirects, new_mapping, reg_map, fromHost_lower,
                                is_cur_mapping_regex, num_rules_redirect_permanent);
       break;
     case TEMPORARY_REDIRECT:
-      add_result = _addToStore(temporary_redirects, new_mapping, reg_map, fromHost_lower, 
+      add_result = _addToStore(temporary_redirects, new_mapping, reg_map, fromHost_lower,
                                is_cur_mapping_regex, num_rules_redirect_temporary);
       break;
     default:
@@ -2177,7 +2177,7 @@ UrlRewrite::TableInsert(InkHashTable * h
     src_host_tmp_buf[0] = 0;
   }
   // Insert the new_mapping into hash table
-  if (ink_hash_table_lookup(h_table, src_host, (void**) &ht_contents)) {       
+  if (ink_hash_table_lookup(h_table, src_host, (void**) &ht_contents)) {
     // There is already a path index for this host
     if (ht_contents == NULL) {
       // why should this happen?
@@ -2411,9 +2411,9 @@ UrlRewrite::load_remap_plugin(char *argv
 		 * fail here, otherwise we *will* fail later
 		 * and that's some jacked backtrace inside CreateTableLookup [see bug 2316658]
 		 * at least this one will be obvious
-		 * We *really* don't want to continue when a plugin failed to init. We can't 
+		 * We *really* don't want to continue when a plugin failed to init. We can't
 		 * guarantee we are remapping what the user thought we were going to remap.
-		 * using something nice like exit() would be more ideal, but this should be 
+		 * using something nice like exit() would be more ideal, but this should be
 		 * caught in development, anyway.
      **/
     exit(-1);
@@ -2450,13 +2450,13 @@ UrlRewrite::_mappingLookup(MappingsStore
   request_host_lower[request_host_len] = 0;
 
   int rank_ceiling = -1;
-  url_mapping *mapping = _tableLookup(mappings.hash_lookup, request_url, request_port, request_host_lower, 
+  url_mapping *mapping = _tableLookup(mappings.hash_lookup, request_url, request_port, request_host_lower,
                                       request_host_len, tag);
   if (mapping != NULL) {
     rank_ceiling = mapping->getRank();
     Debug("url_rewrite", "Found 'simple' mapping with rank %d", rank_ceiling);
   }
-  url_mapping *regex_mapping = _regexMappingLookup(mappings.regex_list, request_url, request_port, 
+  url_mapping *regex_mapping = _regexMappingLookup(mappings.regex_list, request_url, request_port,
                                                    request_host_lower, request_host_len, tag, rank_ceiling);
   if (regex_mapping) {
     mapping = regex_mapping;
@@ -2465,10 +2465,10 @@ UrlRewrite::_mappingLookup(MappingsStore
   return mapping;
 }
 
-// does not null terminate return string 
+// does not null terminate return string
 int
 UrlRewrite::_expandSubstitutions(int *matches_info, const RegexMapping &reg_map,
-                                 const char *matched_string, 
+                                 const char *matched_string,
                                  char *dest_buf, int dest_buf_size)
 {
   int cur_buf_size = 0;
@@ -2483,7 +2483,7 @@ UrlRewrite::_expandSubstitutions(int *ma
     }
     memcpy(dest_buf + cur_buf_size, reg_map.to_url_host_template + token_start, n_bytes_needed);
     cur_buf_size += n_bytes_needed;
-    
+
     // then copy the sub pattern match
     match_index = reg_map.substitution_ids[i] * 2;
     n_bytes_needed = matches_info[match_index + 1] - matches_info[match_index];
@@ -2492,10 +2492,10 @@ UrlRewrite::_expandSubstitutions(int *ma
     }
     memcpy(dest_buf + cur_buf_size, matched_string + matches_info[match_index], n_bytes_needed);
     cur_buf_size += n_bytes_needed;
-    
+
     token_start = reg_map.substitution_markers[i] + 2; // skip the place holder
   }
-  
+
   // copy last few bytes (if any)
   if (token_start < reg_map.to_url_host_template_len) {
     n_bytes_needed = reg_map.to_url_host_template_len - token_start;
@@ -2505,17 +2505,17 @@ UrlRewrite::_expandSubstitutions(int *ma
     memcpy(dest_buf + cur_buf_size, reg_map.to_url_host_template + token_start, n_bytes_needed);
     cur_buf_size += n_bytes_needed;
   }
-  Debug("url_rewrite_regex", "Expanded substitutions and returning string [%.*s] with length %d", 
+  Debug("url_rewrite_regex", "Expanded substitutions and returning string [%.*s] with length %d",
         cur_buf_size, dest_buf, cur_buf_size);
   return cur_buf_size;
-  
+
  lOverFlow:
   Error("Overflow while expanding substitutions");
   return 0;
 }
 
 url_mapping *
-UrlRewrite::_regexMappingLookup(RegexMappingList &regex_mappings, URL *request_url, int request_port, 
+UrlRewrite::_regexMappingLookup(RegexMappingList &regex_mappings, URL *request_url, int request_port,
                                 const char *request_host, int request_host_len, char *tag, int rank_ceiling)
 {
   url_mapping *retval = NULL;
@@ -2549,10 +2549,10 @@ UrlRewrite::_regexMappingLookup(RegexMap
             reg_map_rank);
       continue;
     }
-    
+
     if (reg_map.url_map->fromURL.port_get() != request_port) {
       Debug("url_rewrite_regex", "Skipping regex with rank %d as regex map port does not match request port. "
-            "regex map port: %d, request port %d", 
+            "regex map port: %d, request port %d",
             reg_map_rank, reg_map.url_map->fromURL.port_get(), request_port);
       continue;
     }
@@ -2571,21 +2571,21 @@ UrlRewrite::_regexMappingLookup(RegexMap
     if (match_result > 0) {
       Debug("url_rewrite_regex", "Request URL host [%.*s] matched regex in mapping of rank %d "
             "with %d possible substitutions", request_host_len, request_host, reg_map_rank, match_result);
-      
+
       char buf[MAX_URL_STR_SIZE];
       int buf_len;
-      
+
       // Expand substitutions in the host field from the stored template
-      buf_len = _expandSubstitutions(matches_info, reg_map, request_host, 
+      buf_len = _expandSubstitutions(matches_info, reg_map, request_host,
                                      buf, MAX_URL_STR_SIZE);
       reg_map.url_map->toURL.host_set(buf, buf_len);
-      
-      Debug("url_rewrite_regex", "Expanded toURL to [%.*s]", 
+
+      Debug("url_rewrite_regex", "Expanded toURL to [%.*s]",
             reg_map.url_map->toURL.length_get(), reg_map.url_map->toURL.string_get_ref());
       retval = reg_map.url_map;
       break;
     } else if (match_result == PCRE_ERROR_NOMATCH) {
-      Debug("url_rewrite_regex", "Request URL host [%.*s] did NOT match regex in mapping of rank %d", 
+      Debug("url_rewrite_regex", "Request URL host [%.*s] did NOT match regex in mapping of rank %d",
             request_host_len, request_host, reg_map_rank);
     } else {
       Error("pcre_exec() failed with error code %d", match_result);
@@ -2597,7 +2597,7 @@ UrlRewrite::_regexMappingLookup(RegexMap
 }
 
 void
-UrlRewrite::_destroyList(RegexMappingList &mappings) 
+UrlRewrite::_destroyList(RegexMappingList &mappings)
 {
   RegexMappingList::iterator list_iter;
   for (list_iter = mappings.begin(); list_iter != mappings.end(); ++list_iter) {
@@ -2636,7 +2636,7 @@ UrlRewrite::_processRegexMappingConfig(c
   reg_map.to_url_host_template = NULL;
   reg_map.to_url_host_template_len = 0;
   reg_map.n_substitutions = 0;
-  
+
   reg_map.url_map = new_mapping;
 
   // using from_host_lower (and not new_mapping->fromURL.host_get())
@@ -2646,7 +2646,7 @@ UrlRewrite::_processRegexMappingConfig(c
     Error("pcre_compile failed! Regex has error starting at %s", from_host_lower + str_index);
     goto lFail;
   }
-  
+
   reg_map.re_extra = pcre_study(reg_map.re, 0, &str);
   if ((reg_map.re_extra == NULL) && (str != NULL)) {
     Error("pcre_study failed with message [%s]", str);
@@ -2659,7 +2659,7 @@ UrlRewrite::_processRegexMappingConfig(c
     goto lFail;
   }
   if (n_captures >= MAX_REGEX_SUBS) { // off by one for $0 (implicit capture)
-    Error("Regex has %d capturing subpatterns (including entire regex); Max allowed: %d", 
+    Error("Regex has %d capturing subpatterns (including entire regex); Max allowed: %d",
           n_captures + 1, MAX_REGEX_SUBS);
     goto lFail;
   }
@@ -2694,7 +2694,7 @@ UrlRewrite::_processRegexMappingConfig(c
   memcpy(reg_map.to_url_host_template, str, str_index);
 
   return true;
-  
+
  lFail:
   if (reg_map.re) {
     pcre_free(reg_map.re);

Modified: trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/http2/remap/UrlRewrite.h Thu May 13 17:43:56 2010
@@ -55,7 +55,7 @@
 #define BUILD_TABLE_MAX_ARGS 2048
 
 /**
- * 
+ *
 **/
 typedef struct s_build_table_info
 {
@@ -74,7 +74,7 @@ enum mapping_type
 { FORWARD_MAP, REVERSE_MAP, PERMANENT_REDIRECT, TEMPORARY_REDIRECT, FORWARD_MAP_REFERER, NONE };
 
 /**
- * 
+ *
 **/
 class UrlRewrite
 {
@@ -102,40 +102,40 @@ public:
     url_mapping *url_map;
     pcre *re;
     pcre_extra *re_extra;
-    
+
     // we store the host-string-to-substitute here; if a match is found,
     // the substitutions are made and the resulting url is stored
     // directly in toURL's host field
-    char *to_url_host_template; 
+    char *to_url_host_template;
     int to_url_host_template_len;
 
     // stores the number of substitutions
-    int n_substitutions;     
-    
+    int n_substitutions;
+
     // these two together point to template string places where
     // substitutions need to be made and the matching substring
     // to use
-    int substitution_markers[MAX_REGEX_SUBS]; 
+    int substitution_markers[MAX_REGEX_SUBS];
     int substitution_ids[MAX_REGEX_SUBS];
   };
-  
+
   typedef std::list<RegexMapping> RegexMappingList;
-  
-  struct MappingsStore 
+
+  struct MappingsStore
   {
     InkHashTable *hash_lookup;
     RegexMappingList regex_list;
-    bool empty() 
+    bool empty()
     {
       return ((hash_lookup == NULL) && (regex_list.size() == 0));
     }
   };
-  
+
   void PerformACLFiltering(HttpTransact::State * s, url_mapping * mapping);
   url_mapping *SetupPacMapping();       // manager proxy-autconfig mapping
   url_mapping *SetupBackdoorMapping();
   void PrintTable(InkHashTable * h_table);
-  void DestroyStore(MappingsStore &store) 
+  void DestroyStore(MappingsStore &store)
   {
     _destroyTable(store.hash_lookup);
     _destroyList(store.regex_list);
@@ -147,23 +147,23 @@ public:
   MappingsStore permanent_redirects;
   MappingsStore temporary_redirects;
 
-  url_mapping *forwardMappingLookup(URL *request_url, int request_port, const char *request_host, 
-                                    int request_host_len, char *tag = NULL) 
+  url_mapping *forwardMappingLookup(URL *request_url, int request_port, const char *request_host,
+                                    int request_host_len, char *tag = NULL)
   {
     return _mappingLookup(forward_mappings, request_url, request_port, request_host, request_host_len, tag);
   }
-  url_mapping *reverseMappingLookup(URL *request_url, int request_port, const char *request_host, 
-                                    int request_host_len, char *tag = NULL) 
+  url_mapping *reverseMappingLookup(URL *request_url, int request_port, const char *request_host,
+                                    int request_host_len, char *tag = NULL)
   {
     return _mappingLookup(reverse_mappings, request_url, request_port, request_host, request_host_len, tag);
   }
-  url_mapping *permanentRedirectLookup(URL *request_url, int request_port, const char *request_host, 
-                                       int request_host_len, char *tag = NULL) 
+  url_mapping *permanentRedirectLookup(URL *request_url, int request_port, const char *request_host,
+                                       int request_host_len, char *tag = NULL)
   {
     return _mappingLookup(permanent_redirects, request_url, request_port, request_host, request_host_len, tag);
   }
-  url_mapping *temporaryRedirectLookup(URL *request_url, int request_port, const char *request_host, 
-                                       int request_host_len, char *tag = NULL) 
+  url_mapping *temporaryRedirectLookup(URL *request_url, int request_port, const char *request_host,
+                                       int request_host_len, char *tag = NULL)
   {
     return _mappingLookup(temporary_redirects, request_url, request_port, request_host, request_host_len, tag);
   }
@@ -203,7 +203,7 @@ private:
   url_mapping *_tableLookup(InkHashTable * h_table, URL * request_url,
                             int request_port, char *request_host, int request_host_len, char *tag);
   url_mapping *_regexMappingLookup(RegexMappingList &regex_mappings,
-                                   URL * request_url, int request_port, const char *request_host, 
+                                   URL * request_url, int request_port, const char *request_host,
                                    int request_host_len, char *tag, int rank_ceiling);
   int _expandSubstitutions(int *matches_info, const RegexMapping &reg_map,
                            const char *matched_string, char *dest_buf, int dest_buf_size);

Modified: trafficserver/traffic/tags/2.1.0/proxy/logcat.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logcat.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logcat.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logcat.cc Thu May 13 17:43:56 2010
@@ -224,7 +224,7 @@ open_output_file(char *output_file)
 }
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   main
   -------------------------------------------------------------------------*/
 
@@ -240,7 +240,7 @@ main(int argc, char *argv[])
 
   // build the application information structure
   //
-  appVersionInfo.setup(PACKAGE_NAME,PROGRAM_NAME, PACKAGE_VERSION, __DATE__, 
+  appVersionInfo.setup(PACKAGE_NAME,PROGRAM_NAME, PACKAGE_VERSION, __DATE__,
                        __TIME__, BUILD_MACHINE, BUILD_PERSON, "");
 
   // process command-line arguments

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/Log.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/Log.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/Log.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/Log.cc Thu May 13 17:43:56 2010
@@ -32,7 +32,7 @@
  widely-implemented, Log could be implemented as a namespace rather than a
  class.
 
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -128,7 +128,7 @@ InkHashTable *
 
 RecRawStatBlock *
   log_rsb;
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   Log::change_configuration
 
   This routine is invoked when the current LogConfig object says it needs
@@ -144,7 +144,7 @@ Log::change_configuration()
   ink_assert(new_config != NULL);
   new_config->read_configuration_variables();
 
-  // grab the _APImutex so we can transfer the api objects to 
+  // grab the _APImutex so we can transfer the api objects to
   // the new config
   //
   ink_mutex_acquire(Log::config->log_object_manager._APImutex);
@@ -185,7 +185,7 @@ Log::add_to_inactive(LogObject * object)
   Log::inactive_objects[Log::numInactiveObjects++] = object;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   PERIODIC EVENTS
 
   There are a number of things that need to get done on a periodic basis,
@@ -207,10 +207,10 @@ Log::add_to_inactive(LogObject * object)
   -------------------------------------------------------------------------*/
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   Log::periodic_tasks
 
-  This function contains all of the tasks that need to be done each 
+  This function contains all of the tasks that need to be done each
   second.
   -------------------------------------------------------------------------*/
 
@@ -219,10 +219,10 @@ Log::periodic_tasks(long time_now)
 {
   // delete inactive objects
   //
-  // we don't care if we miss an object that may be added to the set of 
-  // inactive objects just after we have read numInactiveObjects and found 
-  // it to be zero; we will get a chance to delete it next time 
-  // 
+  // we don't care if we miss an object that may be added to the set of
+  // inactive objects just after we have read numInactiveObjects and found
+  // it to be zero; we will get a chance to delete it next time
+  //
 
   Debug("log2-api-mutex", "entering Log::periodic_tasks");
   if (numInactiveObjects) {
@@ -261,7 +261,7 @@ Log::periodic_tasks(long time_now)
 
     Debug("log2-periodic", "Performing periodic tasks");
 
-    // Check if space is ok and update the space used 
+    // Check if space is ok and update the space used
     //
     if (config->space_is_short() || time_now % config->space_used_frequency == 0) {
       Log::config->update_space_used();
@@ -379,7 +379,7 @@ Log::init_fields()
                              &LogAccess::unmarshal_str));
   global_field_list.add (field, false);
   ink_hash_table_insert (field_symbol_hash, "caun", field);
-    
+
   field = NEW(new LogField("client_req_timestamp_sec", "cqts",
                            LogField::sINT,
                            &LogAccess::marshal_client_req_timestamp_sec, &LogAccess::unmarshal_int_to_str));
@@ -860,7 +860,7 @@ Log::init_fields()
   // the client DNS name.
   //
   // For WMT, this is equivalent to c-dns
-  //     
+  //
   ADD_LOG_FIELD("client_dns_name", "cdns", LogField::STRING,
                 &LogAccess::marshal_client_dns_name, &LogAccess::unmarshal_str);
 
@@ -939,7 +939,7 @@ Log::init_fields()
                 &LogAccess::marshal_client_pkts_received, &LogAccess::unmarshal_int_to_str);
 
   // This field is for the number of lost packets during transmission
-  // from server to client as reported by the client. 
+  // from server to client as reported by the client.
   //
   // For WMT, this is equivalent to c-pkts-lost-client
   //
@@ -1016,7 +1016,7 @@ Log::init_fields()
 
 
 /*-------------------------------------------------------------------------
-  
+
   Initialization functions
 
   -------------------------------------------------------------------------*/
@@ -1099,7 +1099,7 @@ Log::init(int flags)
 	LOG_CLEAR_DYN_STAT(log2_stat_event_log_access_stat);
 	LOG_CLEAR_DYN_STAT(log2_stat_event_log_access_skip_stat);
 	LOG_CLEAR_DYN_STAT(log2_stat_event_log_access_fail_stat);
-	LOG_CLEAR_DYN_STAT(log2_stat_event_log_error_stat); 
+	LOG_CLEAR_DYN_STAT(log2_stat_event_log_error_stat);
 */
     // if remote management is enabled, do all necessary initialization to
     // be able to handle a logging mode change
@@ -1483,7 +1483,7 @@ Log::collate_thread_main(void *args)
   return NULL;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   Log::match_logobject
 
   This routine matches the given buffer with the local list of LogObjects.

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/Log.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/Log.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/Log.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/Log.h Thu May 13 17:43:56 2010
@@ -125,7 +125,7 @@
         +---------------------+
         |      fixed-size     |
         +---------------------+
-        |                     |  contains strings and any custom logging 
+        |                     |  contains strings and any custom logging
         :     variable-size   :  fields not in the union set.
         |                     |
         +---------------------+