You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by zw...@apache.org on 2014/09/28 03:51:31 UTC

git commit: Fix some indentation issues:

Repository: trafficserver
Updated Branches:
  refs/heads/master f5d62b5c7 -> a70d18875


Fix some indentation issues:

    No TABs
    Remove some trailing spaces
    Fix a DOS CRLF formatted doc file


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

Branch: refs/heads/master
Commit: a70d188756320188d8e8d86fe33d966ef67fa3ce
Parents: f5d62b5
Author: Leif Hedstrom <zw...@apache.org>
Authored: Sat Sep 27 19:47:45 2014 -0600
Committer: Leif Hedstrom <zw...@apache.org>
Committed: Sat Sep 27 19:47:45 2014 -0600

----------------------------------------------------------------------
 cmd/traffic_manager/stats.txt                   |  35 +++---
 doc/admin/event-logging-formats.en.rst          |   4 +-
 .../api/TSHttpConnectWithPluginId.en.rst        | 120 +++++++++----------
 iocore/cache/Cache.cc                           |  14 +--
 iocore/net/P_UnixNet.h                          |   8 +-
 lib/atscppapi/src/AsyncHttpFetch.cc             |   3 +-
 proxy/http/HttpSM.cc                            |  45 ++++---
 proxy/http/HttpSessionManager.cc                |   4 +-
 proxy/http/HttpSessionManager.h                 |   2 +-
 proxy/http/HttpTransact.h                       |  21 ++--
 proxy/logging/LogFilter.cc                      |  24 ++--
 11 files changed, 138 insertions(+), 142 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/cmd/traffic_manager/stats.txt
----------------------------------------------------------------------
diff --git a/cmd/traffic_manager/stats.txt b/cmd/traffic_manager/stats.txt
index 97bdb90..937d379 100644
--- a/cmd/traffic_manager/stats.txt
+++ b/cmd/traffic_manager/stats.txt
@@ -28,12 +28,12 @@
 // Design
 //-----------------------------------------------------------------------------
 
-This statistics processor is a Cougar II (Tsunami) feature. 
-It is designed to replace the StatAggregate.cc and portion of WebOverview.cc 
+This statistics processor is a Cougar II (Tsunami) feature.
+It is designed to replace the StatAggregate.cc and portion of WebOverview.cc
 for scalability, maintainability, and ability to customize reasons.
 
 The statistics processor aggregate/calculate traffic server statistics based
-on a XML-based configuration file. At the processor's initialization, the 
+on a XML-based configuration file. At the processor's initialization, the
 configuration file is read and parsed. Each set of calculation is then stored
 as a C++ object, called StatObject; and each StatObject is linked into a list,
 called StatObjectList.
@@ -48,22 +48,22 @@ proxy.node.* variables to their corresponding proxy.cluster.* variable.
 
 So there are two types of calculations in the statistics processor: NodeEval
 and ClusterEval. As their names imply, they aggregate node-based statistics
-and clsuter-based statistics, respectively. We call the different basis of 
+and clsuter-based statistics, respectively. We call the different basis of
 statistics aggregation as "scope". (See "Destination Attributes")
 
 In the cluster-based statistics, the aggregation is further divided into two
-types: sum and re-calculate. Sum refers calculating the proxy.cluster.* 
+types: sum and re-calculate. Sum refers calculating the proxy.cluster.*
 variable by simply summing all required proxy.node.* variables from nodes in
-the cluster. Re-calculate refers to summing all proxy.nodes.* variables that 
-are used in the process of calculation before performing the calculation. 
-An analogy would be, summing all open connection in the cluster vs. the 
+the cluster. Re-calculate refers to summing all proxy.nodes.* variables that
+are used in the process of calculation before performing the calculation.
+An analogy would be, summing all open connection in the cluster vs. the
 average hit rate in the cluster.
 
 //-----------------------------------------------------------------------------
 // Destination Attributes
 //-----------------------------------------------------------------------------
 	
-	"scope" 
+	"scope"
 	- "node"
 	- "cluster"
 
@@ -71,7 +71,6 @@ average hit rate in the cluster.
 	- "sum"
 		summing the corresponding node variable across all nodes in the cluster.
 	- "re-calculate"
-		
 
 	"define"
 	- "custom"
@@ -80,7 +79,7 @@ average hit rate in the cluster.
 //-----------------------------------------------------------------------------
 // Predefined Constants and Functions
 //-----------------------------------------------------------------------------
-	
+
 	Predefined Constants
 
 	. BYTES_TO_MB_SCALE (1/(1024*1024.0))
@@ -103,7 +102,7 @@ average hit rate in the cluster.
 
 	Predefined Functions
 	. DIFFTIME
-	  - the number of milliseconds since last update. Usually used in 
+	  - the number of milliseconds since last update. Usually used in
         combination of HRTIME_SECOND which computes the number of seconds
         since last update.
 
@@ -112,7 +111,7 @@ average hit rate in the cluster.
 //-----------------------------------------------------------------------------
 
 The statistics processor is designed to replace StatAggregate.cc and part of
-the WebOverview. The first thing to test StatProcessor is to comment the 
+the WebOverview. The first thing to test StatProcessor is to comment the
 aggregateNodeRecords() and doClusterAg() calls from mgmt/Main.cc.
 
 The next step is to replace the above function calls with StatProcessor::
@@ -128,7 +127,7 @@ Hence it can't be easily tested. We divided the test into multiple sections.
 
 2) Node-based Time-Delta Aggregation
 	- performs those aggregation that are node-based but the operation is only
-      perform in a regular interval AND one of more variables in the 
+      perform in a regular interval AND one of more variables in the
       calculation is obtained by calculating the difference between the last
       updated value and the current value. E.g. average connections per second
       is calculated by subtracting the 10 seconds ago connection count from the
@@ -137,7 +136,7 @@ Hence it can't be easily tested. We divided the test into multiple sections.
 Repeat the about 2 testes with cluster-based variables. So, we have, at least,
 4 test cases.
 
-Developing a PASS/FAIL unit test that will test the statistics processor is not 
+Developing a PASS/FAIL unit test that will test the statistics processor is not
 cost-efficient. The approach we are going to use is to display the input value
 and the output value before and after the calculation is done.
 
@@ -158,7 +157,7 @@ resulting values
 //-----------------------------------------------------------------------------
 // For QA Engineer
 //-----------------------------------------------------------------------------
-The most concerning question for QA engineers is "how can I tell if the 
+The most concerning question for QA engineers is "how can I tell if the
 Statistics Processor is working correctly?"
 
 Recall, the new Statistics Processor is meant to replace the StatAggregate.cc
@@ -181,7 +180,7 @@ computing that value.
         custom: variables that are introducted to be temporary storage or
                 variables that are introdcuted by the client.
     - default attributes:
-	type = built-in  
+	type = built-in
 
 <src>
     - variable need to computer the <dst>
@@ -218,7 +217,7 @@ DEFINED CONSTANT (in alphabetical order)
 
 *  _HRTIME_SECOND
 	* Origin:
-	* Value: 
+	* Value:
 
 *  _MBIT_TO_KBIT_SCALE
 	* Origin: utils/WebMgmtUtils.h

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/doc/admin/event-logging-formats.en.rst
----------------------------------------------------------------------
diff --git a/doc/admin/event-logging-formats.en.rst b/doc/admin/event-logging-formats.en.rst
index 81557f3..b81a4e7 100644
--- a/doc/admin/event-logging-formats.en.rst
+++ b/doc/admin/event-logging-formats.en.rst
@@ -220,9 +220,9 @@ The following list describes Traffic Server custom logging fields.
 ``phr``
     The proxy hierarchy route; the route Traffic Server used to retrieve
     the object.
-    
+
 .. _piid:
-    
+
 ``piid``
    The plugin ID for the transaction. This is set for plugin driven transactions via :c:func:`TSHttpConnectWithPluginId`.
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/doc/reference/api/TSHttpConnectWithPluginId.en.rst
----------------------------------------------------------------------
diff --git a/doc/reference/api/TSHttpConnectWithPluginId.en.rst b/doc/reference/api/TSHttpConnectWithPluginId.en.rst
index b333eca..8e83f85 100644
--- a/doc/reference/api/TSHttpConnectWithPluginId.en.rst
+++ b/doc/reference/api/TSHttpConnectWithPluginId.en.rst
@@ -1,60 +1,60 @@
-.. Licensed to the Apache Software Foundation (ASF) under one or more
-   contributor license agreements.  See the NOTICE file distributed
-   with this work for additional information regarding copyright
-   ownership.  The ASF licenses this file to you under the Apache
-   License, Version 2.0 (the "License"); you may not use this file
-   except in compliance with the License.  You may obtain a copy of
-   the License at
-
-      http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-   implied.  See the License for the specific language governing
-   permissions and limitations under the License.
-
-
-TSHttpConnectWithPluginID
-=========================
-
-Allows the plugin to initiate an http connection. This will tag the HTTP state machine with extra data that can be accessed by the logging interface. The connection is treated as an HTTP transaction as if it came from a client.
-
-
-Synopsis
---------
-
-`#include <ts/ts.h>`
-
-.. c:function:: TSVConn TSHttpConnectWithPluginId(sockaddr const *addr, char const* tag, int64_t id)
-
-
-Description
------------
-
-This call attempts to create an HTTP state machine and a virtual connection to that state machine. This is more efficient than using :c:func:`TSNetConnect` because it avoids using the operating system stack via the loopback interface.
-
-*addr*
-   This is the network address of the target of the connection. This includes the port which should be stored in the :c:type:`sockaddr` structure pointed at by :arg:`addr`.
-
-*tag*
-   This is a tag that is passed through to the HTTP state machine. It must be a persistent string that has a lifetime longer than the connection. It is accessible via the log field :ref:`pitag <pitag>`. This is intended as a class or type identifier that is consistent across all connections for this plugin. In effect, the name of the plugin. This can be :literal:`NULL`.
-
-*id*
-   This is a numeric identifier that is passed through to the HTTP state machine. It is accessible via the log field :ref:`piid <piid>`. This is intended as a connection identifier and should be distinct for every call to :c:func:`TSHttpConnectWithPluginId`. The easiest mechanism is to define a plugin global value and increment it for each connection. The value :literal:`0` is reserved to mean "not set" and can be used as a default if this functionality is not needed.
-
-The virtual connection returned as the :c:type:`TSCVonn` is API equivalent to a network virtual connection both to the plugin and to internal mechanisms. Data is read and written to the connection (and thence to the target system) by reading and writing on this virtual connection.
-
-.. note:: This function only opens the connection - to drive the transaction an actual HTTP request must be sent and the HTTP response handled. The transaction is handled as a standard HTTP transaction and all of the standard configuration options and plugins will operate on it.
-
-The combination of tag and id is intended to enable correlation in log post processing. The tag identifies the connection as related to the plugin and the id can be used in conjuction with plugin generated logs to correlate the log records.
-
-.. topic:: Example
-
-   The SPDY implementation uses this to correlate client sessions with SPDY streams. Each client connection is assigned a distinct numeric identifier. This is passed as the :arg:`id` to :c:func:`TSHttpConnectWithPluginId`. The :arg:`tag` is selected to be the NPN string for the client session protocol, e.g. "spdy/3" or "spdy/3.1". Log post processing can then count the number of connections for the various supported protocols and the number of SPDY virtual streams for each real client connection to Traffic Server.
-
-See also
-========
-:manpage:`TSHttpConnect(3ts)`,
-:manpage:`TSNetConnect(3ts)`,
-:manpage:`TSAPI(3ts)`
+.. Licensed to the Apache Software Foundation (ASF) under one or more
+   contributor license agreements.  See the NOTICE file distributed
+   with this work for additional information regarding copyright
+   ownership.  The ASF licenses this file to you under the Apache
+   License, Version 2.0 (the "License"); you may not use this file
+   except in compliance with the License.  You may obtain a copy of
+   the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing, software
+   distributed under the License is distributed on an "AS IS" BASIS,
+   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+   implied.  See the License for the specific language governing
+   permissions and limitations under the License.
+
+
+TSHttpConnectWithPluginID
+=========================
+
+Allows the plugin to initiate an http connection. This will tag the HTTP state machine with extra data that can be accessed by the logging interface. The connection is treated as an HTTP transaction as if it came from a client.
+
+
+Synopsis
+--------
+
+`#include <ts/ts.h>`
+
+.. c:function:: TSVConn TSHttpConnectWithPluginId(sockaddr const *addr, char const* tag, int64_t id)
+
+
+Description
+-----------
+
+This call attempts to create an HTTP state machine and a virtual connection to that state machine. This is more efficient than using :c:func:`TSNetConnect` because it avoids using the operating system stack via the loopback interface.
+
+*addr*
+   This is the network address of the target of the connection. This includes the port which should be stored in the :c:type:`sockaddr` structure pointed at by :arg:`addr`.
+
+*tag*
+   This is a tag that is passed through to the HTTP state machine. It must be a persistent string that has a lifetime longer than the connection. It is accessible via the log field :ref:`pitag <pitag>`. This is intended as a class or type identifier that is consistent across all connections for this plugin. In effect, the name of the plugin. This can be :literal:`NULL`.
+
+*id*
+   This is a numeric identifier that is passed through to the HTTP state machine. It is accessible via the log field :ref:`piid <piid>`. This is intended as a connection identifier and should be distinct for every call to :c:func:`TSHttpConnectWithPluginId`. The easiest mechanism is to define a plugin global value and increment it for each connection. The value :literal:`0` is reserved to mean "not set" and can be used as a default if this functionality is not needed.
+
+The virtual connection returned as the :c:type:`TSCVonn` is API equivalent to a network virtual connection both to the plugin and to internal mechanisms. Data is read and written to the connection (and thence to the target system) by reading and writing on this virtual connection.
+
+.. note:: This function only opens the connection - to drive the transaction an actual HTTP request must be sent and the HTTP response handled. The transaction is handled as a standard HTTP transaction and all of the standard configuration options and plugins will operate on it.
+
+The combination of tag and id is intended to enable correlation in log post processing. The tag identifies the connection as related to the plugin and the id can be used in conjuction with plugin generated logs to correlate the log records.
+
+.. topic:: Example
+
+   The SPDY implementation uses this to correlate client sessions with SPDY streams. Each client connection is assigned a distinct numeric identifier. This is passed as the :arg:`id` to :c:func:`TSHttpConnectWithPluginId`. The :arg:`tag` is selected to be the NPN string for the client session protocol, e.g. "spdy/3" or "spdy/3.1". Log post processing can then count the number of connections for the various supported protocols and the number of SPDY virtual streams for each real client connection to Traffic Server.
+
+See also
+========
+:manpage:`TSHttpConnect(3ts)`,
+:manpage:`TSNetConnect(3ts)`,
+:manpage:`TSAPI(3ts)`

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/iocore/cache/Cache.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/Cache.cc b/iocore/cache/Cache.cc
index 3625b71..27a1926 100644
--- a/iocore/cache/Cache.cc
+++ b/iocore/cache/Cache.cc
@@ -776,8 +776,8 @@ CacheProcessor::start_internal(int flags)
       else
         Warning("cache unable to open '%s': %s", path, strerror(errno));
     }
-    if(fd > 0) {
-    	close(fd);
+    if (fd > 0) {
+      close(fd);
     }
   }
 
@@ -2423,7 +2423,7 @@ static bool upgrade_doc_version(Ptr<IOBufferData>& buf) {
         dst = d_buf->data();
         memcpy(dst, src, sizeofDoc);
         src += sizeofDoc + doc->_flen; dst += sizeofDoc; n -= sizeofDoc;
-        
+
         // We copy the fragment table iff there is a fragment table and there is only one alternate.
         if (frag_count > 0 && cache_bc::HTTPInfo_v21::marshalled_length(src) > doc->hlen)
           frag_count = 0; // inhibit fragment table insertion.
@@ -2504,7 +2504,7 @@ CacheVC::handleReadDone(int event, Event *e)
 
     if (doc->doc_type == CACHE_FRAG_TYPE_HTTP_V23) {
       if (upgrade_doc_version(buf)) {
-        doc = reinterpret_cast<Doc*>(buf->data()); // buf may be a new copy 
+        doc = reinterpret_cast<Doc*>(buf->data()); // buf may be a new copy
       } else {
         Debug("cache_bc", "Upgrade of fragment failed - disk %s - doc id = %" PRIx64 ":%" PRIx64 "\n"
               , vol->hash_text.get(), read_key->slice64(0), read_key->slice64(1));
@@ -3204,8 +3204,8 @@ cplist_reconfigure()
         new_cp->disk_vols = (DiskVol **)ats_malloc(gndisks * sizeof(DiskVol *));
         memset(new_cp->disk_vols, 0, gndisks * sizeof(DiskVol *));
         if (create_volume(config_vol->number, size_in_blocks, config_vol->scheme, new_cp)) {
-        	delete new_cp;
-        	return -1;
+          delete new_cp;
+          return -1;
         }
         cp_list.enqueue(new_cp);
         cp_list_len++;
@@ -3760,7 +3760,7 @@ namespace cache_bc {
     length -= hdr_size;
 
     src = reinterpret_cast<char*>(s_hdr) + hdr_size;
-  
+
     return true;
   }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/iocore/net/P_UnixNet.h
----------------------------------------------------------------------
diff --git a/iocore/net/P_UnixNet.h b/iocore/net/P_UnixNet.h
index 1868055..9d16924 100644
--- a/iocore/net/P_UnixNet.h
+++ b/iocore/net/P_UnixNet.h
@@ -532,17 +532,17 @@ TS_INLINE int EventIO::modify(int e) {
     if (((-e) & events)) {
       ne = ~(-e) & events;
       if ((-e) & EVENTIO_READ)
-	n++;
+        n++;
       if ((-e) & EVENTIO_WRITE)
-	n++;
+        n++;
     }
   } else {
     if (!(e & events)) {
       ne = events | e;
       if (e & EVENTIO_READ)
-	n++;
+        n++;
       if (e & EVENTIO_WRITE)
-	n++;
+        n++;
     }
   }
   if (n && ne && event_loop) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/lib/atscppapi/src/AsyncHttpFetch.cc
----------------------------------------------------------------------
diff --git a/lib/atscppapi/src/AsyncHttpFetch.cc b/lib/atscppapi/src/AsyncHttpFetch.cc
index 34d77f4..042e457 100644
--- a/lib/atscppapi/src/AsyncHttpFetch.cc
+++ b/lib/atscppapi/src/AsyncHttpFetch.cc
@@ -74,10 +74,11 @@ static int handleFetchEvents(TSCont cont, TSEvent event, void *edata) {
     TSHttpTxn txn = static_cast<TSHttpTxn>(edata);
     int data_len;
     const char *data_start = TSFetchRespGet(txn, &data_len);
+
     if (data_start && (data_len > 0)) {
       const char *data_end = data_start + data_len;
-      
       TSHttpParser parser = TSHttpParserCreate();
+
       state->hdr_buf_ = TSMBufferCreate();
       state->hdr_loc_ = TSHttpHdrCreate(state->hdr_buf_);
       TSHttpHdrTypeSet(state->hdr_buf_, state->hdr_loc_, TS_HTTP_TYPE_RESPONSE);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/proxy/http/HttpSM.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpSM.cc b/proxy/http/HttpSM.cc
index fa1a2a4..cef58ff 100644
--- a/proxy/http/HttpSM.cc
+++ b/proxy/http/HttpSM.cc
@@ -695,7 +695,7 @@ HttpSM::state_read_client_request_header(int event, void *data)
 
       // Setting half close means we will send the FIN when we've written all of the data.
       if (event == VC_EVENT_EOS) {
-        this->set_ua_half_close_flag();      
+        this->set_ua_half_close_flag();
         t_state.client_info.keep_alive = HTTP_NO_KEEPALIVE;
       }
       return 0;
@@ -1628,7 +1628,7 @@ HttpSM::state_http_server_open(int event, void *data)
 
   switch (event) {
   case NET_EVENT_OPEN:
-    session = (TS_SERVER_SESSION_SHARING_POOL_THREAD == t_state.txn_conf->server_session_sharing_pool) ? 
+    session = (TS_SERVER_SESSION_SHARING_POOL_THREAD == t_state.txn_conf->server_session_sharing_pool) ?
       THREAD_ALLOC_INIT(httpServerSessionAllocator, mutex->thread_holding) :
       httpServerSessionAllocator.alloc();
     session->sharing_pool = static_cast<TSServerSessionSharingPoolType>(t_state.txn_conf->server_session_sharing_pool);
@@ -2042,13 +2042,13 @@ HttpSM::process_hostdb_info(HostDBInfo * r)
       // if use_client_target_addr is set, make sure the client
       // addr sits in the pool
       if (t_state.http_config_param->use_client_target_addr == 1
-        && t_state.client_info.is_transparent
-        && t_state.dns_info.os_addr_style == HttpTransact::DNSLookupInfo::OS_ADDR_TRY_DEFAULT) {
-      
+          && t_state.client_info.is_transparent
+          && t_state.dns_info.os_addr_style == HttpTransact::DNSLookupInfo::OS_ADDR_TRY_DEFAULT) {
         HostDBRoundRobin *rr = r->rr();
         sockaddr const* addr = t_state.state_machine->ua_session->get_netvc()->get_local_addr();
+
         if (rr && rr->find_ip(addr) == NULL) {
-          // The client specified server address does not appear 
+          // The client specified server address does not appear
           // in the DNS pool
           DebugSM("http", "use_client_target_addr == 1. Client specified address is not in the pool. Client address is not validated.");
           t_state.dns_info.lookup_validated = false;
@@ -2085,14 +2085,14 @@ HttpSM::process_hostdb_info(HostDBInfo * r)
       }
     } else {
       if (t_state.http_config_param->use_client_target_addr == 1
-        && t_state.client_info.is_transparent 
-        && t_state.dns_info.os_addr_style == HttpTransact::DNSLookupInfo::OS_ADDR_TRY_DEFAULT) {
+          && t_state.client_info.is_transparent
+          && t_state.dns_info.os_addr_style == HttpTransact::DNSLookupInfo::OS_ADDR_TRY_DEFAULT) {
         // Compare the client specified address against the looked up address
         sockaddr const* addr = t_state.state_machine->ua_session->get_netvc()->get_local_addr();
         if (!ats_ip_addr_eq(addr, &r->data.ip.sa)) {
           DebugSM("http", "use_client_target_addr == 1.  Comparing single addresses failed. Client address is not validated.");
           t_state.dns_info.lookup_validated = false;
-        } 
+        }
         // Regardless of whether the client address matches the DNS
         // record or not, we want to use that address.  Therefore,
         // we copy over the client address info and skip the assignment
@@ -2406,7 +2406,7 @@ HttpSM::state_cache_open_write(int event, void *data)
     t_state.cache_info.write_lock_state = HttpTransact::CACHE_WL_SUCCESS;
     break;
 
-  case CACHE_EVENT_OPEN_WRITE_FAILED: 
+  case CACHE_EVENT_OPEN_WRITE_FAILED:
     // Failed on the write lock and retrying the vector
     //  for reading
     t_state.cache_info.write_lock_state = HttpTransact::CACHE_WL_FAIL;
@@ -2800,11 +2800,11 @@ HttpSM::is_http_server_eos_truncation(HttpTunnelProducer * p)
   if ((p->do_dechunking || p->do_chunked_passthru) && p->chunked_handler.truncation) {
     // TS-3054 - In the chunked cases, chunked data that is incomplete
     // should not be cached, but it should be passed onto the client
-    // This makes ATS more transparent in the case of non-standard 
+    // This makes ATS more transparent in the case of non-standard
     // servers.  The cache aborts are dealt with in other checks
-    // on the truncation flag elsewhere in the code.  This return value 
-    // invalidates the current data being passed over to the client.  
-    // So changing it from return true to return false, so the partial data 
+    // on the truncation flag elsewhere in the code.  This return value
+    // invalidates the current data being passed over to the client.
+    // So changing it from return true to return false, so the partial data
     // is passed onto the client.
     return false;	
   }
@@ -4281,18 +4281,15 @@ HttpSM::calculate_output_cl(int64_t content_length, int64_t num_chars)
 void
 HttpSM::do_range_parse(MIMEField *range_field)
 {
-
-  //bool res = false;
-  
   int64_t content_length   = t_state.cache_info.object_read->object_size_get();
   int64_t num_chars_for_cl = num_chars_for_int(content_length);
-  
+
   parse_range_and_compare(range_field, content_length);
   calculate_output_cl(content_length, num_chars_for_cl);
 }
 
 // this function looks for any Range: headers, parses them and either
-// sets up a transform processor to handle the request OR defers to the 
+// sets up a transform processor to handle the request OR defers to the
 // HttpTunnel
 void
 HttpSM::do_range_setup_if_necessary()
@@ -4301,12 +4298,12 @@ HttpSM::do_range_setup_if_necessary()
   INKVConnInternal *range_trans;
   int field_content_type_len = -1;
   const char * content_type;
-  
+
   ink_assert(t_state.cache_info.object_read != NULL);
-  
+
   field = t_state.hdr_info.client_request.field_find(MIME_FIELD_RANGE, MIME_LEN_RANGE);
   ink_assert(field != NULL);
-  
+
   t_state.range_setup = HttpTransact::RANGE_NONE;
 
   if (t_state.method == HTTP_WKSIDX_GET && t_state.hdr_info.client_request.version_get() == HTTPVersion(1, 1)) {
@@ -4534,7 +4531,7 @@ HttpSM::do_http_server_open(bool raw)
 
   char addrbuf[INET6_ADDRPORTSTRLEN];
   DebugSM("http", "[%" PRId64 "] open connection to %s: %s",
-        sm_id, t_state.current.server->name, 
+        sm_id, t_state.current.server->name,
         ats_ip_nptop(&t_state.current.server->addr.sa, addrbuf, sizeof(addrbuf)));
 
   if (plugin_tunnel) {
@@ -7250,7 +7247,7 @@ HttpSM::set_next_state()
 
       ink_assert(t_state.dns_info.looking_up == HttpTransact::ORIGIN_SERVER);
 
-      // TODO: This might not be optimal (or perhaps even correct), but it will 
+      // TODO: This might not be optimal (or perhaps even correct), but it will
       // effectively mark the host as down. What's odd is that state_mark_os_down
       // above isn't triggering.
       HttpSM::do_hostdb_update_if_necessary();

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/proxy/http/HttpSessionManager.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpSessionManager.cc b/proxy/http/HttpSessionManager.cc
index 8ad077b..e1c4c35 100644
--- a/proxy/http/HttpSessionManager.cc
+++ b/proxy/http/HttpSessionManager.cc
@@ -55,7 +55,7 @@ ServerSessionPool::ServerSessionPool()
 
 void
 ServerSessionPool::purge()
-{ 
+{
   for ( IPHashTable::iterator last = m_ip_pool.end(), spot = m_ip_pool.begin() ; spot != last ; ++spot ) {
     spot->do_io_close();
   }
@@ -287,7 +287,7 @@ HttpSessionManager::release_session(HttpServerSession *to_release)
   EThread *ethread = this_ethread();
   ServerSessionPool* pool = TS_SERVER_SESSION_SHARING_POOL_THREAD == to_release->sharing_pool ? ethread->server_session_pool : m_g_pool;
   bool released_p = true;
-  
+
   // The per thread lock looks like it should not be needed but if it's not locked the close checking I/O op will crash.
   MUTEX_TRY_LOCK(lock, pool->mutex, ethread);
   if (lock) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/proxy/http/HttpSessionManager.h
----------------------------------------------------------------------
diff --git a/proxy/http/HttpSessionManager.h b/proxy/http/HttpSessionManager.h
index 442a5c1..1fdf6a1 100644
--- a/proxy/http/HttpSessionManager.h
+++ b/proxy/http/HttpSessionManager.h
@@ -84,7 +84,7 @@ public:
     typedef DList(HttpServerSession, host_hash_link) ListHead;
 
     static ID hash(Key key) { return key.fold(); }
-    static Key key(Value const* value) { return value->hostname_hash; } 
+    static Key key(Value const* value) { return value->hostname_hash; }
     static bool equal(Key lhs, Key rhs) { return lhs == rhs; }
   };
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/proxy/http/HttpTransact.h
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransact.h b/proxy/http/HttpTransact.h
index f35d0fe..981d5bd 100644
--- a/proxy/http/HttpTransact.h
+++ b/proxy/http/HttpTransact.h
@@ -572,7 +572,7 @@ public:
     RANGE_NOT_HANDLED,
     RANGE_NOT_TRANSFORM_REQUESTED
   };
-  
+
   enum CacheAuth_t
   {
     CACHE_AUTH_NONE = 0,
@@ -699,7 +699,7 @@ public:
     TransferEncoding_t transfer_encoding;
 
     IpEndpoint addr;    // replaces 'ip' field
-    
+
     // port to connect to, except for client
     // connection where it is port on proxy
     // that client connected to.
@@ -768,7 +768,7 @@ public:
 	on the CTA (USE_CLIENT) up to the max retry value.  In essence
 	we try to treat the CTA as if it were another RR value in the
 	HostDB record.
-     */ 
+     */
     enum {
       OS_ADDR_TRY_DEFAULT, ///< Initial state, use what config says.
       OS_ADDR_TRY_HOSTDB, ///< Try HostDB data.
@@ -784,10 +784,10 @@ public:
     bool srv_lookup_success;
     short srv_port;
     HostDBApplicationInfo srv_app;
-    /*** Set to true by default.  If use_client_target_address is set 
-     * to 1, this value will be set to false if the client address is 
+    /*** Set to true by default.  If use_client_target_address is set
+     * to 1, this value will be set to false if the client address is
      * not in the DNS pool */
-    bool lookup_validated; 
+    bool lookup_validated;
 
     _DNSLookupInfo()
     : attempts(0), os_addr_style(OS_ADDR_TRY_DEFAULT),
@@ -1004,21 +1004,21 @@ public:
 
     bool already_downgraded;
     URL pristine_url;  // pristine url is the url before remap
-    
+
     bool api_skip_all_remapping;
-    
+
     // Http Range: related variables
     RangeSetup_t range_setup;
     int64_t num_range_fields;
     int64_t range_output_cl;
     RangeRecord *ranges;
-    
+
     OverridableHttpConfigParams *txn_conf;
     OverridableHttpConfigParams my_txn_conf; // Storage for plugins, to avoid malloc
 
     bool transparent_passthrough;
     bool range_in_cache;
-    
+
     // Methods
     void
     init()
@@ -1229,7 +1229,6 @@ public:
       }
       internal_msg_buffer_size = 0;
     }
-   
   }; // End of State struct.
 
   static void HandleBlindTunnel(State* s);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/a70d1887/proxy/logging/LogFilter.cc
----------------------------------------------------------------------
diff --git a/proxy/logging/LogFilter.cc b/proxy/logging/LogFilter.cc
index 22ffd17..f1eb7e5 100644
--- a/proxy/logging/LogFilter.cc
+++ b/proxy/logging/LogFilter.cc
@@ -313,7 +313,7 @@ bool LogFilterString::toss_this_entry(LogAccess * lad)
         big_buf_upper = (char *)ats_malloc((unsigned int) marsh_len);
         buf_upper = big_buf_upper;
       } else {
-    	  buf = small_buf; // make clang happy
+        buf = small_buf; // make clang happy
       }
       for (size_t i = 0; i < marsh_len; i++) {
         buf_upper[i] = ParseRules::ink_toupper(buf[i]);
@@ -639,7 +639,7 @@ LogFilterIP::LogFilterIP(const char *name, LogField * field,
   m_map.mark(value,value);
   this->init();
 }
- 
+
 LogFilterIP::LogFilterIP(const char *name, LogField * field,
                            LogFilter::Action action, LogFilter::Operator oper, size_t num_values, IpAddr* value)
   : LogFilter(name, field, action, oper)
@@ -712,8 +712,8 @@ LogFilterIP::init()
 
 LogFilterIP::~LogFilterIP()
 {
-}   
-    
+}
+
 /*-------------------------------------------------------------------------
   LogFilterIP::operator==
 
@@ -732,7 +732,7 @@ LogFilterIP::operator==(LogFilterIP & rhs)
       m_action == rhs.m_action &&
       m_operator == rhs.m_operator &&
       m_num_values == rhs.m_num_values) {
-    
+
     IpMap::iterator left_spot(m_map.begin());
     IpMap::iterator left_limit(m_map.end());
     IpMap::iterator right_spot(rhs.m_map.begin());
@@ -771,7 +771,7 @@ LogFilterIP::is_match(LogAccess* lad)
   return zret;
 }
 
-bool 
+bool
 LogFilterIP::toss_this_entry(LogAccess* lad)
 {
   bool cond_satisfied = this->is_match(lad);
@@ -836,19 +836,19 @@ LogFilterIP::display(FILE* fd)
   }
 }
 
- 
-void 
+
+void
 LogFilterIP::display_as_XML(FILE * fd)
-{  
+{
   ink_assert(fd != NULL);
   fprintf(fd,
           "<LogFilter>\n"
-          "  <Name      = \"%s\"/>\n" 
+          "  <Name      = \"%s\"/>\n"
           "  <Action    = \"%s\"/>\n"
           "  <Condition = \"%s %s ", m_name, ACTION_NAME[m_action], m_field->symbol(), OPERATOR_NAME[m_operator]);
 
   if (m_map.getCount() == 0) {
-    fprintf(fd, "<no values>");  
+    fprintf(fd, "<no values>");
   } else {
     this->displayRanges(fd);
   }
@@ -949,7 +949,7 @@ LogFilterList::add(LogFilter * filter, bool copy)
     if (filter->type() == LogFilter::INT_FILTER) {
       LogFilterInt *f = new LogFilterInt(*((LogFilterInt *) filter));
       m_filter_list.enqueue(f);
-    } else if (filter->type() == LogFilter::IP_FILTER) {   
+    } else if (filter->type() == LogFilter::IP_FILTER) {
       LogFilterIP *f = new LogFilterIP(*((LogFilterIP *) filter));
       m_filter_list.enqueue(f);
     } else {