You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by so...@apache.org on 2014/11/14 18:55:31 UTC

[2/5] trafficserver git commit: Remove trailing whitespace

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/EsiProcessor.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/EsiProcessor.h b/plugins/experimental/esi/lib/EsiProcessor.h
index 16004c6..fbbf547 100644
--- a/plugins/experimental/esi/lib/EsiProcessor.h
+++ b/plugins/experimental/esi/lib/EsiProcessor.h
@@ -48,48 +48,48 @@ public:
                EsiLib::ComponentBase::Debug debug_func, EsiLib::ComponentBase::Error error_func,
                HttpDataFetcher &fetcher, EsiLib::Variables &variables,
                const EsiLib::HandlerManager &handler_mgr);
-  
+
   /** Initializes the processor with the context of the request to be processed */
   bool start();
 
   /** Adds data to be parsed */
   bool addParseData(const char *data, int data_len = -1);
 
-  /** convenient alternative to method above */ 
+  /** convenient alternative to method above */
   bool addParseData(const std::string &data) {
     return addParseData(data.data(), data.size());
   }
-  
+
   /** Tells processor to wrap-up parsing; a final or the only piece of
    * data can be optionally provided */
   bool completeParse(const char *data = 0, int data_len = -1);
-  
-  /** convenient alternative to method above */ 
+
+  /** convenient alternative to method above */
   bool completeParse(const std::string &data) {
     return completeParse(data.data(), data.size());
   }
-  
+
   enum ReturnCode { FAILURE, SUCCESS, NEED_MORE_DATA };
-  
-  /** Processes the currently parsed ESI document and returns processed 
-   * data in supplied out-parameters. Should be called when fetcher has 
-   * finished pulling in all data. 
-   * 
+
+  /** Processes the currently parsed ESI document and returns processed
+   * data in supplied out-parameters. Should be called when fetcher has
+   * finished pulling in all data.
+   *
    * try/attempt/except construct can generate new fetch requests
    * during processing. Only in such cases is NEED_MORE_DATA returned;
    * else FAILURE/SUCCESS is returned. */
   ReturnCode process(const char *&data, int &data_len);
 
-  /** Process the ESI document and flush processed data as much as 
-   * possible. Can be called when fetcher hasn't finished pulling 
+  /** Process the ESI document and flush processed data as much as
+   * possible. Can be called when fetcher hasn't finished pulling
    * in all data. */
   ReturnCode flush(std:: string &data, int &overall_len);
- 
+
   /** returns packed version of document currently being processed */
   void packNodeList(std::string &buffer, bool retain_buffer_data) {
     return _node_list.pack(buffer, retain_buffer_data);
   }
-  
+
   /** Unpacks previously parsed and packed ESI node list from given
    * buffer and preps for process(); Unpacked document will point to
    * data in argument (i.e., caller space) */
@@ -101,12 +101,12 @@ public:
   }
 
   /** Clears state from current request */
-  void stop(); 
+  void stop();
 
   virtual ~EsiProcessor();
 
 private:
-  
+
   enum EXEC_STATE { STOPPED, PARSING, WAITING_TO_PROCESS, PROCESSED, ERRORED };
   EXEC_STATE _curr_state;
 
@@ -124,7 +124,7 @@ private:
 
   bool _reqAdded;
   bool _usePackedNodeList;
-  
+
   bool _processEsiNode(const EsiLib::DocNodeList::iterator &iter);
   bool _handleParseComplete();
   bool _getIncludeData(const EsiLib::DocNode &node, const char **content_ptr = 0, int *content_len_ptr = 0);
@@ -144,7 +144,7 @@ private:
     EsiLib::DocNodeList &attempt_nodes;
     EsiLib::DocNodeList &except_nodes;
     EsiLib::DocNodeList::iterator pos;
-    TryBlock(EsiLib::DocNodeList &att, EsiLib::DocNodeList &exc, EsiLib::DocNodeList::iterator p) 
+    TryBlock(EsiLib::DocNodeList &att, EsiLib::DocNodeList &exc, EsiLib::DocNodeList::iterator p)
       : attempt_nodes(att), except_nodes(exc), pos(p) { };
   };
   typedef std::list<TryBlock> TryBlockList;
@@ -153,7 +153,7 @@ private:
 
   const EsiLib::HandlerManager &_handler_manager;
 
-  static const char *INCLUDE_DATA_ID_ATTR; 
+  static const char *INCLUDE_DATA_ID_ATTR;
 
   typedef std::map<std::string, EsiLib::SpecialIncludeHandler *> IncludeHandlerMap;
   IncludeHandlerMap _include_handlers;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Expression.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Expression.cc b/plugins/experimental/esi/lib/Expression.cc
index 9e3674b..fc94b3a 100644
--- a/plugins/experimental/esi/lib/Expression.cc
+++ b/plugins/experimental/esi/lib/Expression.cc
@@ -29,7 +29,7 @@ using namespace EsiLib;
 
 const string Expression::EMPTY_STRING("");
 const string Expression::TRUE_STRING("true");
-const Expression::OperatorString Expression::OPERATOR_STRINGS[N_OPERATORS] = { 
+const Expression::OperatorString Expression::OPERATOR_STRINGS[N_OPERATORS] = {
   Expression::OperatorString("==", 2),
   Expression::OperatorString("!=", 2),
   Expression::OperatorString("<=", 2),
@@ -38,14 +38,14 @@ const Expression::OperatorString Expression::OPERATOR_STRINGS[N_OPERATORS] = {
   Expression::OperatorString(">", 1),
   Expression::OperatorString("!", 1),
   Expression::OperatorString("|", 1),
-  Expression::OperatorString("&", 1) 
+  Expression::OperatorString("&", 1)
 };
 
-Expression::Expression(const char *debug_tag, ComponentBase::Debug debug_func, 
-                             ComponentBase::Error error_func, Variables &variables) 
+Expression::Expression(const char *debug_tag, ComponentBase::Debug debug_func,
+                             ComponentBase::Error error_func, Variables &variables)
   : ComponentBase(debug_tag, debug_func, error_func), _variables(variables), _value("") {
 }
-  
+
 inline bool
 Expression::_stripQuotes(const char *&expr, int &expr_len) const {
   char quote_char = 0;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Expression.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Expression.h b/plugins/experimental/esi/lib/Expression.h
index ad982dc..af3482b 100644
--- a/plugins/experimental/esi/lib/Expression.h
+++ b/plugins/experimental/esi/lib/Expression.h
@@ -31,7 +31,7 @@
 #include "ComponentBase.h"
 #include "Variables.h"
 
-namespace EsiLib { 
+namespace EsiLib {
 
 class Expression : private ComponentBase {
 
@@ -39,7 +39,7 @@ public:
 
   Expression(const char *debug_tag, ComponentBase::Debug debug_func, ComponentBase::Error error_func,
              Variables &variables);
-  
+
   /** substitutes variables (if any) in given expression */
   const std::string &expand(const char *expr, int expr_len = -1);
 
@@ -66,7 +66,7 @@ private:
   Variables &_variables;
   std::string _value;
 
-  // these are arranged in parse priority format indices correspond to op strings array 
+  // these are arranged in parse priority format indices correspond to op strings array
   enum Operator { OP_EQ, OP_NEQ, OP_LTEQ, OP_GTEQ, OP_LT, OP_GT, OP_NOT, OP_OR, OP_AND, N_OPERATORS };
 
   struct OperatorString {
@@ -74,15 +74,15 @@ private:
     int str_len;
     OperatorString(const char *s = 0, int s_len = -1) : str(s), str_len(s_len) { };
   };
-  
+
   static const OperatorString OPERATOR_STRINGS[N_OPERATORS];
 
   inline void _trimWhiteSpace(const char *&expr, int &expr_len) const;
-  
+
   inline bool _stripQuotes(const char *&expr, int &expr_len) const;
-  
+
   inline int _findOperator(const char *expr, int expr_len, Operator &op) const;
-  
+
   inline bool _isBinaryOperator(Operator &op) const {
     return ((op == OP_EQ) || (op == OP_NEQ) || (op == OP_LT) || (op == OP_GT) ||
             (op == OP_LTEQ) || (op == OP_GTEQ) || (op == OP_OR) || (op == OP_AND));

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/FailureInfo.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/FailureInfo.cc b/plugins/experimental/esi/lib/FailureInfo.cc
index 24954ab..2541f8c 100644
--- a/plugins/experimental/esi/lib/FailureInfo.cc
+++ b/plugins/experimental/esi/lib/FailureInfo.cc
@@ -37,7 +37,7 @@ void FailureInfo::registerSuccFail(bool isSuccess)
     {
         ++_windowMarker;
         _windowMarker%=_totalSlots;
-      
+
         if(_windowMarker==_totalSlots-1)
         {
             ++_windowsPassed;
@@ -52,7 +52,7 @@ void FailureInfo::registerSuccFail(bool isSuccess)
             _avgOverWindow+=avg/_windowsPassed;
             _debugLog(_debug_tag,"[%s] current average over window is %lf",__FUNCTION__,_avgOverWindow);
         }
-    
+
         gettimeofday(&_start,NULL);
     }
 
@@ -60,13 +60,13 @@ void FailureInfo::registerSuccFail(bool isSuccess)
    {
        _statistics[_windowMarker].second++;
    }
-   
+
    else
    {
        _statistics[_windowMarker].first++;
    }
 }
-    
+
 bool FailureInfo::isAttemptReq()
 {
     double avg=0;
@@ -75,11 +75,11 @@ bool FailureInfo::isAttemptReq()
         if(_statistics[i].first >0)
         {
             avg+=_statistics[i].first/(_statistics[i].first+_statistics[i].second);
-            
+
         }
     }
-    
-    if(avg) { 
+
+    if(avg) {
         //Average it out for time being
         avg=avg/_totalSlots;
         double prob;
@@ -91,10 +91,10 @@ bool FailureInfo::isAttemptReq()
             double mapFactor=( ( (avg*1000-LOWER_CUT_OFF)*(avg*1000-LOWER_CUT_OFF) ) / (HIGHER_CUT_OFF-LOWER_CUT_OFF ) )+LOWER_CUT_OFF;
             prob=mapFactor/1000;
         }
-        
+
         if(static_cast<int>(prob))
             prob=_avgOverWindow;
-        
+
         _debugLog(_debug_tag,"[%s] Calculated probability is %lf",__FUNCTION__,prob);
         int decision=rand()%100;
 
@@ -103,7 +103,7 @@ bool FailureInfo::isAttemptReq()
             return (_requestMade=false);
         }
     }
-        
+
     _debugLog(_debug_tag,"[%s] fetch request will be added for an attempt request",__FUNCTION__);
     return true;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/FailureInfo.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/FailureInfo.h b/plugins/experimental/esi/lib/FailureInfo.h
index 8f4705b..b97bddb 100644
--- a/plugins/experimental/esi/lib/FailureInfo.h
+++ b/plugins/experimental/esi/lib/FailureInfo.h
@@ -98,12 +98,12 @@ private:
 
     /* Keep track of the number of windows filled prev*/
     size_t _windowsPassed;
-    
+
     /*Used as a deciding factor between attempt/except
      * incase prob is complete truth
      */
     double _avgOverWindow;
-    
+
 public:
     /*Was a reqeust made*/
     bool _requestMade;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/HttpHeader.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/HttpHeader.h b/plugins/experimental/esi/lib/HttpHeader.h
index bdef5ce..e5773ab 100644
--- a/plugins/experimental/esi/lib/HttpHeader.h
+++ b/plugins/experimental/esi/lib/HttpHeader.h
@@ -34,7 +34,7 @@ struct HttpHeader {
   int name_len;
   const char *value;
   int value_len;
-  HttpHeader(const char *n = 0, int n_len = -1, const char *v = 0, int v_len = -1) 
+  HttpHeader(const char *n = 0, int n_len = -1, const char *v = 0, int v_len = -1)
     : name(n), name_len(n_len), value(v), value_len(v_len) { };
 };
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/IncludeHandlerFactory.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/IncludeHandlerFactory.h b/plugins/experimental/esi/lib/IncludeHandlerFactory.h
index 2845d49..abf8c6e 100644
--- a/plugins/experimental/esi/lib/IncludeHandlerFactory.h
+++ b/plugins/experimental/esi/lib/IncludeHandlerFactory.h
@@ -36,7 +36,7 @@ EsiLib::SpecialIncludeHandler *createSpecialIncludeHandler(EsiLib::Variables &es
                                                            EsiLib::Expression &esi_expr,
                                                            HttpDataFetcher &fetcher,
                                                            const std::string &id);
-  
+
 #ifdef __cplusplus
 }
 #endif

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Stats.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Stats.h b/plugins/experimental/esi/lib/Stats.h
index 0d8dd67..44f54d3 100644
--- a/plugins/experimental/esi/lib/Stats.h
+++ b/plugins/experimental/esi/lib/Stats.h
@@ -60,6 +60,6 @@ void increment(STAT st, int step = 1);
 };
 
 };
-              
+
 
 #endif

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Utils.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Utils.cc b/plugins/experimental/esi/lib/Utils.cc
index 047fbe6..86c3196 100644
--- a/plugins/experimental/esi/lib/Utils.cc
+++ b/plugins/experimental/esi/lib/Utils.cc
@@ -183,7 +183,7 @@ Utils::parseAttributes(const char *data, int data_len, AttributeList &attr_list,
       attr.value = 0;
       inside_quotes = false;
     } else if (data[i] == '"') {
-      if (!escape_on) { 
+      if (!escape_on) {
         inside_quotes = !inside_quotes;
       }
     } else if ((data[i] == '=') && !attr.value && !inside_quotes) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Utils.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Utils.h b/plugins/experimental/esi/lib/Utils.h
index 6308e7c..9b562c5 100644
--- a/plugins/experimental/esi/lib/Utils.h
+++ b/plugins/experimental/esi/lib/Utils.h
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-#ifndef _ESI_UTILS_H 
+#ifndef _ESI_UTILS_H
 
 #define _ESI_UTILS_H
 
@@ -49,7 +49,7 @@ namespace Utils {
   // to data inside data string
   bool getAttribute(const std::string &data, const std::string &attr, size_t curr_pos, size_t end_pos,
                     Attribute &attr_info, size_t *term_pos = 0, char terminator = 0);
-  
+
   // less specialized version of method above
   inline bool getAttribute(const std::string &data, const char *attr, Attribute &attr_info) {
     return getAttribute(data, std::string(attr), 0, data.size(), attr_info);
@@ -98,10 +98,10 @@ namespace Utils {
   // parses given lines (assumes <key><whitespace><value> format) and
   // stores them in supplied map; Lines beginning with '#' are ignored
   void parseKeyValueConfig(const std::list<std::string> &lines, KeyValueMap &kvMap);
-  
+
   inline std::string unescape(const char *str, int len = -1) {
     std::string retval("");
-    if (str) { 
+    if (str) {
       for (int i = 0; (((len == -1) && (str[i] != '\0')) || (i < len)); ++i) {
         if (str[i] != '\\') {
           retval += str[i];

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Variables.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Variables.cc b/plugins/experimental/esi/lib/Variables.cc
index 0bf93dd..dc59f13 100644
--- a/plugins/experimental/esi/lib/Variables.cc
+++ b/plugins/experimental/esi/lib/Variables.cc
@@ -67,11 +67,11 @@ Variables::_toUpperCase(string &str) const {
   return str;
 }
 
-inline int 
+inline int
 Variables::_searchHeaders(const string headers[], const char *name, int name_len) const {
   int curr_header_size;
   for (int i = 0; (curr_header_size = static_cast<int>(headers[i].size())); ++i) {
-    if ((name_len == curr_header_size) && 
+    if ((name_len == curr_header_size) &&
         (strncasecmp(headers[i].data(), name, curr_header_size) == 0)) {
       return i;
     }
@@ -221,7 +221,7 @@ Variables::getValue(const string &name) const {
   _toUpperCase(search_key);
   StringHash::const_iterator iter = _simple_data.find(search_key);
   if (iter != _simple_data.end()) {
-    _debugLog(_debug_tag, "[%s] Found value [%.*s] for variable [%.*s] in simple data", 
+    _debugLog(_debug_tag, "[%s] Found value [%.*s] for variable [%.*s] in simple data",
               __FUNCTION__, iter->second.size(), iter->second.data(), name.size(), name.data());
     return iter->second;
   }
@@ -251,21 +251,21 @@ Variables::getValue(const string &name) const {
               __FUNCTION__, search_key.size(), search_key.data());
     return (iter == _dict_data[dict_index].end()) ? EMPTY_STRING : TRUE_STRING;
   }
-  
+
   if (iter != _dict_data[dict_index].end()) {
     _debugLog(_debug_tag, "[%s] Found variable [%.*s] in %s dictionary with value [%.*s]",
-              __FUNCTION__, search_key.size(), search_key.data(), NORM_SPECIAL_HEADERS[dict_index].c_str(), 
+              __FUNCTION__, search_key.size(), search_key.data(), NORM_SPECIAL_HEADERS[dict_index].c_str(),
               iter->second.size(), iter->second.data());
     return iter->second;
   }
 
   size_t cookie_part_divider = (dict_index == HTTP_COOKIE) ? search_key.find(';') : search_key.size();
   if (cookie_part_divider && (cookie_part_divider < (search_key.size() - 1))) {
-    _debugLog(_debug_tag, "[%s] Cookie variable [%s] refers to sub cookie", 
+    _debugLog(_debug_tag, "[%s] Cookie variable [%s] refers to sub cookie",
               __FUNCTION__, search_key.c_str());
     return _getSubCookieValue(search_key, cookie_part_divider);
   }
-  
+
   _debugLog(_debug_tag, "[%s] Found no value for dict variable [%s]", __FUNCTION__, name.c_str());
   return EMPTY_STRING;
 }
@@ -309,14 +309,14 @@ Variables::_getSubCookieValue(const string &cookie_str, size_t cookie_part_divid
   // that; hence this shortcut
   string &non_const_cookie_str = const_cast<string &>(cookie_str);
   StringHash::const_iterator it_part;
-    
+
   non_const_cookie_str[cookie_part_divider] = '\0'; // make sure cookie name is NULL terminated
   const char *cookie_name = non_const_cookie_str.data(); /* above NULL will take effect */
   const char *part_name = non_const_cookie_str.c_str() + cookie_part_divider + 1;
 
   StringKeyHash<StringHash>::const_iterator it_cookie = _sub_cookies.find(cookie_name);
   if (it_cookie == _sub_cookies.end()) {
-      _debugLog(_debug_tag, "[%s] Could not find value for cookie [%s]", 
+      _debugLog(_debug_tag, "[%s] Could not find value for cookie [%s]",
               __FUNCTION__, cookie_name);
       goto fail;
   }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/Variables.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/Variables.h b/plugins/experimental/esi/lib/Variables.h
index 6462662..19f37f2 100644
--- a/plugins/experimental/esi/lib/Variables.h
+++ b/plugins/experimental/esi/lib/Variables.h
@@ -41,7 +41,7 @@ public:
   Variables(const char *debug_tag, ComponentBase::Debug debug_func, ComponentBase::Error error_func)
     : ComponentBase(debug_tag, debug_func, error_func), _headers_parsed(false), _query_string(""),
       _query_string_parsed(false), _cookie_jar_created(false) { };
-  
+
   /** currently 'host', 'referer', 'accept-language', 'cookie' and 'user-agent' headers are parsed */
   void populate(const HttpHeader &header);
 
@@ -130,7 +130,7 @@ private:
   typedef std::list<std::string> HeaderValueList;
   HeaderValueList _cached_simple_headers[N_SIMPLE_HEADERS];
   HeaderValueList _cached_special_headers[N_SPECIAL_HEADERS];
-  
+
   std::string _cookie_str;
   bool _headers_parsed;
   std::string _query_string;
@@ -138,7 +138,7 @@ private:
 
   void _parseHeader(const char *name, int name_len, const char *value, int value_len);
   void _parseQueryString(const char *query_string, int query_string_len);
- 
+
   StringKeyHash<StringHash> _sub_cookies;
   bool _cookie_jar_created;
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/gzip.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/gzip.cc b/plugins/experimental/esi/lib/gzip.cc
index 9a38ce4..df7272f 100644
--- a/plugins/experimental/esi/lib/gzip.cc
+++ b/plugins/experimental/esi/lib/gzip.cc
@@ -173,7 +173,7 @@ EsiLib::gunzip(const char *data, int data_len, BufferList &buf_list) {
     // avoid data copy for temporary
     buf_list.push_back(string());
     string &curr_buf = buf_list.back();
-    curr_buf.assign(raw_buf, curr_buf_size); 
+    curr_buf.assign(raw_buf, curr_buf_size);
 
     if (inflate_result == Z_STREAM_END) {
       break;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/lib/gzip.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/lib/gzip.h b/plugins/experimental/esi/lib/gzip.h
index 13906b8..5ac116a 100644
--- a/plugins/experimental/esi/lib/gzip.h
+++ b/plugins/experimental/esi/lib/gzip.h
@@ -23,7 +23,7 @@
 
 #ifndef _GZIP_H
 
-#define _GZIP_H 
+#define _GZIP_H
 
 #include <string>
 #include <list>

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/serverIntercept.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/serverIntercept.cc b/plugins/experimental/esi/serverIntercept.cc
index c8b46f5..9ff27a0 100644
--- a/plugins/experimental/esi/serverIntercept.cc
+++ b/plugins/experimental/esi/serverIntercept.cc
@@ -69,7 +69,7 @@ struct SContData {
   bool req_hdr_parsed;
   bool initialized;
 
-  SContData(TSCont cont) 
+  SContData(TSCont cont)
     : net_vc(0), contp(cont), input(), output(), body(""), req_content_len(0), req_hdr_bufp(0), req_hdr_loc(0),
       req_hdr_parsed(false), initialized(false) {
     http_parser = TSHttpParserCreate();
@@ -81,7 +81,7 @@ struct SContData {
 
   ~SContData() {
     TSDebug(DEBUG_TAG, "[%s] Destroying continuation data", __FUNCTION__);
-    TSHttpParserDestroy(http_parser); 
+    TSHttpParserDestroy(http_parser);
     if (req_hdr_loc) {
       TSHandleMLocRelease(req_hdr_bufp, TS_NULL_MLOC, req_hdr_loc);
     }
@@ -98,7 +98,7 @@ SContData::init(TSVConn vconn)
     TSError("[%s] SContData already initialized!", __FUNCTION__);
     return false;
   }
-  
+
   net_vc = vconn;
 
   input.buffer = TSIOBufferCreate();
@@ -129,7 +129,7 @@ handleRead(SContData *cont_data, bool &read_complete) {
     TSError("[%s] Error while getting number of bytes available", __FUNCTION__);
     return false;
   }
-  
+
           TSDebug(DEBUG_TAG, "[%s] Parsed header, avail: %d", __FUNCTION__, avail);
 
   int consumed = 0;
@@ -178,11 +178,11 @@ handleRead(SContData *cont_data, bool &read_complete) {
       block = TSIOBufferBlockNext(block);
     }
   }
-  
+
   TSIOBufferReaderConsume(cont_data->input.reader, consumed);
 
   TSDebug(DEBUG_TAG, "[%s] Consumed %d bytes from input vio, avail: %d", __FUNCTION__, consumed, avail);
-  
+
   // Modify the input VIO to reflect how much data we've completed.
   TSVIONDoneSet(cont_data->input.vio, TSVIONDoneGet(cont_data->input.vio) + consumed);
 
@@ -201,7 +201,7 @@ handleRead(SContData *cont_data, bool &read_complete) {
 static bool
 processRequest(SContData *cont_data) {
   string reply_header("HTTP/1.1 200 OK\r\n");
-  
+
   TSMLoc field_loc = TSMimeHdrFieldGet(cont_data->req_hdr_bufp, cont_data->req_hdr_loc, 0);
   while (field_loc) {
     TSMLoc next_field_loc;
@@ -245,7 +245,7 @@ processRequest(SContData *cont_data) {
     TSHandleMLocRelease(cont_data->req_hdr_bufp, cont_data->req_hdr_loc, field_loc);
     field_loc = next_field_loc;
   }
-  
+
   int body_size = static_cast<int>(cont_data->body.size());
   if (cont_data->req_content_len != body_size) {
     TSError("[%s] Read only %d bytes of body; expecting %d bytes", __FUNCTION__, body_size,
@@ -270,7 +270,7 @@ processRequest(SContData *cont_data) {
   int total_bytes_written = reply_header.size() + body_size;
   TSDebug(DEBUG_TAG, "[%s] Wrote reply of size %d", __FUNCTION__, total_bytes_written);
   TSVIONBytesSet(cont_data->output.vio, total_bytes_written);
-  
+
   TSVIOReenable(cont_data->output.vio);
   return true;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/StubIncludeHandler.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/StubIncludeHandler.cc b/plugins/experimental/esi/test/StubIncludeHandler.cc
index 4c6798d..8076b60 100644
--- a/plugins/experimental/esi/test/StubIncludeHandler.cc
+++ b/plugins/experimental/esi/test/StubIncludeHandler.cc
@@ -46,7 +46,7 @@ void
 StubIncludeHandler::handleParseComplete() {
   parseCompleteCalled = true;
 }
-  
+
 bool
 StubIncludeHandler::getData(int include_id, const char *&data, int &data_len) {
   TestHttpDataFetcher &test_fetcher = dynamic_cast<TestHttpDataFetcher &>(_http_fetcher);
@@ -65,7 +65,7 @@ StubIncludeHandler::getFooter(const char *&footer, int &footer_len) {
   footer = FOOTER;
   footer_len = FOOTER_SIZE;
 }
-  
+
 StubIncludeHandler::~StubIncludeHandler() {
   for (std::list<char *>::iterator iter = heap_strings.begin(); iter != heap_strings.end(); ++iter) {
     delete[] *iter;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/StubIncludeHandler.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/StubIncludeHandler.h b/plugins/experimental/esi/test/StubIncludeHandler.h
index 576834b..74118fe 100644
--- a/plugins/experimental/esi/test/StubIncludeHandler.h
+++ b/plugins/experimental/esi/test/StubIncludeHandler.h
@@ -32,7 +32,7 @@ class StubIncludeHandler : public EsiLib::SpecialIncludeHandler {
 
 public:
 
-  StubIncludeHandler(EsiLib::Variables &esi_vars, EsiLib::Expression &esi_expr, 
+  StubIncludeHandler(EsiLib::Variables &esi_vars, EsiLib::Expression &esi_expr,
                      HttpDataFetcher &http_fetcher)
     : EsiLib::SpecialIncludeHandler(esi_vars, esi_expr, http_fetcher),
       parseCompleteCalled(false), n_includes(0) {
@@ -42,13 +42,13 @@ public:
 
   bool parseCompleteCalled;
   void handleParseComplete();
-  
+
   bool getData(int include_id, const char *&data, int &data_len);
 
   void getFooter(const char *&footer, int &footer_len);
-  
+
   ~StubIncludeHandler();
-  
+
   static bool includeResult;
   static const char *const DATA_PREFIX;
   static const int DATA_PREFIX_SIZE;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/TestHttpDataFetcher.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/TestHttpDataFetcher.h b/plugins/experimental/esi/test/TestHttpDataFetcher.h
index 1df387e..62c403a 100644
--- a/plugins/experimental/esi/test/TestHttpDataFetcher.h
+++ b/plugins/experimental/esi/test/TestHttpDataFetcher.h
@@ -30,11 +30,11 @@
 
 class TestHttpDataFetcher : public HttpDataFetcher
 {
-  
+
 public:
-  
+
   TestHttpDataFetcher() :  _n_pending_requests(0), _return_data(true) { }
-  
+
   bool addFetchRequest(const std::string &url, FetchedDataProcessor *callback_obj = 0) {
     ++_n_pending_requests;
     return true;
@@ -73,7 +73,7 @@ private:
   int _n_pending_requests;
   std::string _data;
   bool _return_data;
-  
+
 };
 
 #endif

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/docnode_test.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/docnode_test.cc b/plugins/experimental/esi/test/docnode_test.cc
index 19967d8..1bc6bde 100644
--- a/plugins/experimental/esi/test/docnode_test.cc
+++ b/plugins/experimental/esi/test/docnode_test.cc
@@ -144,11 +144,11 @@ void checkNodeList2(const DocNodeList &node_list) {
 
 pthread_key_t threadKey;
 
-int main() 
+int main()
 {
   pthread_key_create(&threadKey, NULL);
   Utils::init(&Debug, &Error);
-  
+
   {
     cout << endl << "==================== Test 1" << endl;
     EsiParser parser("parser_test", &Debug, &Error);
@@ -173,14 +173,14 @@ int main()
     assert(node_list3.unpack(packed) == true);
     assert(node_list3.size() == 0);
     *(reinterpret_cast<int *>(&packed[0])) = 3;
-    
+
     DocNodeList node_list4;
     assert(node_list4.unpack(packed) == true);
     assert(node_list4.size() == 3);
     checkNodeList1(node_list4);
   }
 
-  { 
+  {
     cout << endl << "==================== Test 2" << endl;
     EsiParser parser("parser_test", &Debug, &Error);
     string input_data("<esi:choose>"
@@ -217,7 +217,7 @@ int main()
                       "</esi:try>"
                       "</esi:otherwise>"
                       "</esi:choose>");
-    
+
     DocNodeList node_list;
     assert(parser.completeParse(node_list, input_data) == true);
     checkNodeList2(node_list);
@@ -242,7 +242,7 @@ int main()
     assert(node_list2.unpack(packed3.data() + 5, packed3.size() - 5) == true);
     checkNodeList2(node_list2);
   }
-  
+
   cout << "All tests passed" << endl;
   return 0;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/parser_test.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/parser_test.cc b/plugins/experimental/esi/test/parser_test.cc
index a2e5eb0..715df84 100644
--- a/plugins/experimental/esi/test/parser_test.cc
+++ b/plugins/experimental/esi/test/parser_test.cc
@@ -46,11 +46,11 @@ void check_node_attr(const Attribute &attr, const char *name, const char *value)
 
 pthread_key_t threadKey;
 
-int main() 
+int main()
 {
   pthread_key_create(&threadKey, NULL);
   Utils::init(&Debug, &Error);
-  
+
   {
     cout << endl << "==================== Test 1: No src attr test " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
@@ -72,7 +72,7 @@ int main()
     assert(parser.completeParse(node_list) == false);
     assert(node_list.size() == 0);
   }
-  
+
   {
     cout << endl << "==================== Test 3: Valid src test " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
@@ -631,7 +631,7 @@ int main()
   {
     cout << endl << "==================== Test 30: choose tag " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
-    string input_data = 
+    string input_data =
       "<esi:choose>"
       "<esi:when test=blah><esi:include src=url /></esi:when>"
       "</esi:choose>";
@@ -663,7 +663,7 @@ int main()
     cout << endl << "==================== Test 31: when tag " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
     string input_data = "<esi:when test=blah><esi:include src=url /></esi:when>";
-    
+
     DocNodeList node_list;
     assert(parser.parseChunk(input_data, node_list) == true);
     assert(parser.completeParse(node_list) == true);
@@ -680,7 +680,7 @@ int main()
     cout << endl << "==================== Test 32: otherwise tag " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
     string input_data = "<esi:otherwise><esi:include src=url /></esi:otherwise>";
-    
+
     DocNodeList node_list;
     assert(parser.parseChunk(input_data, node_list) == true);
     assert(parser.completeParse(node_list) == true);
@@ -695,12 +695,12 @@ int main()
   {
     cout << endl << "==================== Test 33: try tag " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
-    string input_data = 
+    string input_data =
       "<esi:try>"
       "<esi:attempt><esi:include src=url1 /></esi:attempt>"
       "<esi:except><esi:include src=url2 /></esi:except>"
       "</esi:try>";
-    
+
     DocNodeList node_list;
     assert(parser.parseChunk(input_data, node_list) == true);
     assert(parser.completeParse(node_list) == true);
@@ -742,7 +742,7 @@ int main()
     string input_data =
       "<esi:attempt><esi:include src=url1 /></esi:attempt>"
       "<esi:except><esi:include src=url2 /></esi:except>";
-    
+
     DocNodeList node_list;
     assert(parser.parseChunk(input_data, node_list) == true);
     assert(parser.completeParse(node_list) == true);
@@ -823,7 +823,7 @@ int main()
     assert(list_iter->type == DocNode::TYPE_PRE);
     assert(list_iter->data_len == static_cast<int>(strlen("foo")));
     assert(strncmp(list_iter->data, "foo", list_iter->data_len) == 0);
-    
+
     ++list_iter;
     assert(list_iter->type == DocNode::TYPE_TRY);
     DocNodeList &child_nodes = list_iter->child_nodes;
@@ -849,10 +849,10 @@ int main()
   {
     cout << endl << "==================== Test 37: html comment tag " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
-    string input_data = 
-      "foo <esi:comment text=\"blah\"/><!--esi <p><esi:vars>Hello, $(HTTP_COOKIE{name})!</esi:vars></p>-->" 
+    string input_data =
+      "foo <esi:comment text=\"blah\"/><!--esi <p><esi:vars>Hello, $(HTTP_COOKIE{name})!</esi:vars></p>-->"
       "<esi:include src=url /> bar";
-    
+
     DocNodeList node_list;
     assert(parser.parseChunk(input_data, node_list) == true);
     assert(parser.completeParse(node_list) == true);
@@ -898,9 +898,9 @@ int main()
       "<!--esi blah--><esi:com",
       "ment text=\"bleh\" /> <esi:remove> </esi:remove><!--esi bleh -->",
       "<!--esi blooh--><esi:include src=url3/>",
-      0 
+      0
     };
-    
+
     DocNodeList node_list;
     for (int i = 0; lines[i]; ++i) {
       assert(parser.parseChunk(lines[i], node_list) == true);
@@ -1059,7 +1059,7 @@ int main()
     assert(parser.completeParse(node_list) == false);
     assert(node_list.size() == 0);
   }
-  
+
   {
     cout << endl << "==================== Test 42: Valid special include " << endl;
     EsiParser parser("parser_test", &Debug, &Error);
@@ -1080,7 +1080,7 @@ int main()
   {
     cout << endl << "===================== Test 43) choose-when" << endl;
     EsiParser parser("parser_test", &Debug, &Error);
-    string 
+    string
       input_data1("<esi:choose>"
                   "<esi:when test=cond1>"
                   "<esi:include src=foo />"
@@ -1166,7 +1166,7 @@ int main()
                       "<esi:include src=otherwise />"
                       "</esi:otherwise>"
                       "</esi:choose>");
-    
+
     DocNodeList node_list;
     assert(parser.parseChunk(input_data, node_list) == false);
     assert(parser.completeParse(node_list) == false);
@@ -1334,7 +1334,7 @@ int main()
     assert(list_iter->child_nodes.size() == 0);
     assert(list_iter->attr_list.size() == 1);
     check_node_attr(list_iter->attr_list.front(), "src", "pre");
-    
+
     ++list_iter;
     assert(list_iter->type == DocNode::TYPE_PRE);
     assert(list_iter->child_nodes.size() == 0);
@@ -1353,34 +1353,34 @@ int main()
     assert(list_iter2->child_nodes.size() == 2);
     assert(list_iter2->attr_list.size() == 0);
     assert(list_iter2->data_len == 0);
-    
+
     list_iter3 = list_iter2->child_nodes.begin();
     assert(list_iter3->type == DocNode::TYPE_PRE);
     assert(list_iter3->child_nodes.size() == 0);
     assert(list_iter3->attr_list.size() == 0);
     assert(list_iter3->data_len == static_cast<int>(strlen("bar")));
     assert(strncmp(list_iter3->data, "bar", list_iter3->data_len) == 0);
-    
+
     ++list_iter3;
     assert(list_iter3->type == DocNode::TYPE_INCLUDE);
     assert(list_iter3->child_nodes.size() == 0);
     assert(list_iter3->attr_list.size() == 1);
     assert(list_iter3->data_len == 0);
     check_node_attr(list_iter3->attr_list.front(), "src", "attempt");
-    
+
     ++list_iter2;
     assert(list_iter2->type == DocNode::TYPE_EXCEPT);
     assert(list_iter2->child_nodes.size() == 1);
     assert(list_iter2->attr_list.size() == 0);
     assert(list_iter2->data_len == 0);
-    
+
     list_iter3 = list_iter2->child_nodes.begin();
     assert(list_iter3->type == DocNode::TYPE_INCLUDE);
     assert(list_iter3->child_nodes.size() == 0);
     assert(list_iter3->attr_list.size() == 1);
     assert(list_iter3->data_len == 0);
     check_node_attr(list_iter3->attr_list.front(), "src", "except");
-    
+
     ++list_iter;
     assert(list_iter->type == DocNode::TYPE_PRE);
     assert(list_iter->child_nodes.size() == 0);
@@ -1442,7 +1442,7 @@ int main()
     assert(parser.completeParse(node_list) == false);
     assert(node_list.size() == 0);
   }
-  
+
   {
     cout << endl << "===================== Test 57) choose/try combo" << endl;
     EsiParser parser("parser_test", &Debug, &Error);
@@ -1585,7 +1585,7 @@ int main()
     assert(attr_iter->value_len == 6);
     assert(strncmp(attr_iter->value, "c >= d", attr_iter->value_len) == 0);
   }
-  
+
   cout << endl << "All tests passed!" << endl;
   return 0;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/processor_test.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/processor_test.cc b/plugins/experimental/esi/test/processor_test.cc
index cb9cf12..be6b15b 100644
--- a/plugins/experimental/esi/test/processor_test.cc
+++ b/plugins/experimental/esi/test/processor_test.cc
@@ -41,7 +41,7 @@ pthread_key_t threadKey;
 
 static const int FETCHER_STATIC_DATA_SIZE = 30;
 
-int main() 
+int main()
 {
   Variables esi_vars("vars", &Debug, &Error);
   HandlerManager handler_mgr("handler_mgr", &Debug, &Error);
@@ -107,7 +107,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo<esi:blah/>bar");
-    
+
     const char *output_data;
     int output_data_len = 10;
 
@@ -122,7 +122,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo<esi:comment text=\"bleh\"/>bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -139,7 +139,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("<esi:comment text=\"bleh\"/>bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -156,7 +156,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo<esi:comment text=\"bleh\"/>");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -173,7 +173,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo\n<esi:comment text=\"\nbleh\"/>\nbar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -190,7 +190,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo\n<esi:remove><img src=\"http://www.example.com\"></esi:remove>\nbar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -208,7 +208,7 @@ int main()
                           handler_mgr);
     string input_data("foo\n<esi:remove><img src=\"http://www.example.com\"></esi:remove>\nbar"
                       "foo2\n<esi:comment text=\"bleh\"/>\nbar2");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -237,7 +237,7 @@ int main()
     assert(esi_proc.completeParse() == true);
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 54);
-    assert(strncmp(output_data, "foo1bar1\nfoo1bar1\nfoo2bar2\nfoo2bar2\nfoo3bar3\nfoo3bar3\n", 
+    assert(strncmp(output_data, "foo1bar1\nfoo1bar1\nfoo2bar2\nfoo2bar2\nfoo3bar3\nfoo3bar3\n",
                    output_data_len) == 0);
   }
 
@@ -247,7 +247,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:include src=url1/> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -257,7 +257,7 @@ int main()
     assert(output_data_len == 8 + 4 + FETCHER_STATIC_DATA_SIZE);
     assert(strncmp(output_data, "foo >>>>> Content for URL [url1] <<<<< bar", output_data_len) == 0);
   }
-  
+
   {
     cout << endl << "===================== Test 11) include tag with no URL" << endl;
     TestHttpDataFetcher data_fetcher;
@@ -284,7 +284,7 @@ int main()
     string input_data("foo1 <esi:include src=url1/> bar1\n"
                       "foo2 <esi:include src=url2/> bar2\n"
                       "<esi:include src=\"blah bleh\"/>");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -293,12 +293,12 @@ int main()
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 11 + 4 + FETCHER_STATIC_DATA_SIZE + 11 + 4 + FETCHER_STATIC_DATA_SIZE +
            9 + FETCHER_STATIC_DATA_SIZE);
-    assert(strncmp(output_data, 
+    assert(strncmp(output_data,
                    "foo1 >>>>> Content for URL [url1] <<<<< bar1\n"
                    "foo2 >>>>> Content for URL [url2] <<<<< bar2\n"
                    ">>>>> Content for URL [blah bleh] <<<<<", output_data_len) == 0);
   }
-  
+
   {
     cout << endl << "===================== Test 14) remove, comment and include tags" << endl;
     TestHttpDataFetcher data_fetcher;
@@ -309,7 +309,7 @@ int main()
                       "<esi:include src=\"blah bleh\"/>"
                       "<esi:comment text=\"bleh\"/>"
                       "<esi:remove> <a href=> </esi:remove>");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -318,7 +318,7 @@ int main()
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 11 + 4 + FETCHER_STATIC_DATA_SIZE + 11 + 4 + FETCHER_STATIC_DATA_SIZE +
            9 + FETCHER_STATIC_DATA_SIZE);
-    assert(strncmp(output_data, 
+    assert(strncmp(output_data,
                    "foo1 >>>>> Content for URL [url1] <<<<< bar1\n"
                    "foo2 >>>>> Content for URL [url2] <<<<< bar2\n"
                    ">>>>> Content for URL [blah bleh] <<<<<", output_data_len) == 0);
@@ -335,7 +335,7 @@ int main()
     char line4[] = "<esi:comment text=\"bleh\"/>";
     char line5[] = "<esi:remove> <a href=>";
     char line6[] = "</esi:remove>";
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -349,12 +349,12 @@ int main()
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 11 + 4 + FETCHER_STATIC_DATA_SIZE + 11 + 4 + FETCHER_STATIC_DATA_SIZE +
            9 + FETCHER_STATIC_DATA_SIZE);
-    assert(strncmp(output_data, 
+    assert(strncmp(output_data,
                    "foo1 >>>>> Content for URL [url1] <<<<< bar1\n"
                    "foo2 >>>>> Content for URL [url2] <<<<< bar2\n"
                    ">>>>> Content for URL [blah bleh] <<<<<", output_data_len) == 0);
   }
-  
+
   {
     cout << endl << "===================== Test 16) one-shot parse" << endl;
     TestHttpDataFetcher data_fetcher;
@@ -365,7 +365,7 @@ int main()
                       "<esi:include src=\"blah bleh\"/>"
                       "<esi:comment text=\"bleh\"/>"
                       "<esi:remove> <a href=> </esi:remove>");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -373,7 +373,7 @@ int main()
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 11 + 4 + FETCHER_STATIC_DATA_SIZE + 11 + 4 + FETCHER_STATIC_DATA_SIZE +
            9 + FETCHER_STATIC_DATA_SIZE);
-    assert(strncmp(output_data, 
+    assert(strncmp(output_data,
                    "foo1 >>>>> Content for URL [url1] <<<<< bar1\n"
                    "foo2 >>>>> Content for URL [url2] <<<<< bar2\n"
                    ">>>>> Content for URL [blah bleh] <<<<<", output_data_len) == 0);
@@ -390,7 +390,7 @@ int main()
     char line4[] = "<esi:comment text=\"bleh\"/>";
     char line5[] = "<esi:remove> <a href=>";
     char line6[] = "</esi:remove>";
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -403,7 +403,7 @@ int main()
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 11 + 4 + FETCHER_STATIC_DATA_SIZE + 11 + 4 + FETCHER_STATIC_DATA_SIZE +
            9 + FETCHER_STATIC_DATA_SIZE);
-    assert(strncmp(output_data, 
+    assert(strncmp(output_data,
                    "foo1 >>>>> Content for URL [url1] <<<<< bar1\n"
                    "foo2 >>>>> Content for URL [url2] <<<<< bar2\n"
                    ">>>>> Content for URL [blah bleh] <<<<<", output_data_len) == 0);
@@ -415,7 +415,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:include src=url1/> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -432,7 +432,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:include src=url1/> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -453,7 +453,7 @@ int main()
                       "<esi:include src=\"blah bleh\"/>"
                       "<esi:comment text=bleh />"
                       "<esi:remove> <a href=> </esi:remove>");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -461,7 +461,7 @@ int main()
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 11 + 4 + FETCHER_STATIC_DATA_SIZE + 11 + 4 + FETCHER_STATIC_DATA_SIZE +
            9 + FETCHER_STATIC_DATA_SIZE);
-    assert(strncmp(output_data, 
+    assert(strncmp(output_data,
                    "foo1 >>>>> Content for URL [url1] <<<<< bar1\n"
                    "foo2 >>>>> Content for URL [url2] <<<<< bar2\n"
                    ">>>>> Content for URL [blah bleh] <<<<<", output_data_len) == 0);
@@ -473,7 +473,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:include src=$(HTTP_HOST) /> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -489,7 +489,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:vars>HTTP_HOST</esi:vars> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -506,7 +506,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:vars>$(HTTP_HOST)</esi:vars> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -523,7 +523,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("foo <esi:vars>$(HTTP_HOST</esi:vars> bar");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -533,7 +533,7 @@ int main()
     assert(output_data_len == 8);
     assert(strncmp(output_data, "foo  bar", output_data_len) == 0);
   }
- 
+
   {
     cout << endl << "===================== Test 25) choose-when" << endl;
     TestHttpDataFetcher data_fetcher;
@@ -552,7 +552,7 @@ int main()
                       "</esi:choose>");
     const char *output_data;
     int output_data_len=0;
-    
+
     assert(esi_proc.completeParse(input_data) == true);
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == FETCHER_STATIC_DATA_SIZE + 3);
@@ -571,7 +571,7 @@ int main()
                       "</esi:choose>");
     const char *output_data;
     int output_data_len=0;
-    
+
     assert(esi_proc.completeParse(input_data) == true);
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == FETCHER_STATIC_DATA_SIZE + 9);
@@ -754,7 +754,7 @@ int main()
                       "</esi:choose>");
     const char *output_data;
     int output_data_len=0;
-    
+
     assert(esi_proc.completeParse(input_data) == true);
     assert(esi_proc.process(output_data, output_data_len) == EsiProcessor::SUCCESS);
     assert(output_data_len == 1 + FETCHER_STATIC_DATA_SIZE + 3);
@@ -940,7 +940,7 @@ int main()
 
      // this is to make the StubHandler return failure
     data_fetcher.setReturnData(false);
-    
+
      // this is to decrement HttpDataFetcher's pending request count - argument content doesn't matter
     data_fetcher.getContent("blah", output_data, output_data_len);
 
@@ -956,7 +956,7 @@ int main()
     EsiProcessor esi_proc("processor", "parser", "expression", &Debug, &Error, data_fetcher, esi_vars,
                           handler_mgr);
     string input_data("<esi:comment text=\"bleh\"/>");
-    
+
     const char *output_data;
     int output_data_len=0;
 
@@ -998,7 +998,7 @@ int main()
 
     esi_proc.stop();
     node_list.clear();
-    input_data = 
+    input_data =
       "<esi:choose>\n\t"
       "<esi:when test=foo>"
       "\t<esi:include src=foo />"
@@ -1039,7 +1039,7 @@ int main()
 
     string packedNodeList = node_list.pack();
 
-    
+
     const char *output_data;
     int output_data_len=0;
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/sampleProb.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/sampleProb.cc b/plugins/experimental/esi/test/sampleProb.cc
index a303e0d..41198ff 100644
--- a/plugins/experimental/esi/test/sampleProb.cc
+++ b/plugins/experimental/esi/test/sampleProb.cc
@@ -51,17 +51,17 @@ public:
         _windowPassed=0;
     };
 
-    ~FailureInfo() 
+    ~FailureInfo()
     {
     }
-    
+
     //Whenever the window time expires u start filling the count
     //by taking a mod
     //so what u get is over a window of 200 ms and 10 rounds
     //the no of failures
     //Introduce a variable which will be a function of
-    //failure and which will lead to points in graph 
-    //according to which the probability of serving the 
+    //failure and which will lead to points in graph
+    //according to which the probability of serving the
     // data from cache or contacting the origin server
     // will be decided
     std::vector <std::pair < double,double > > _passFail;
@@ -69,7 +69,7 @@ public:
     int _marker;
 
     int _totalSlot;
-    
+
     struct timeval _start;
 
     double _avgOverWindow;
@@ -89,12 +89,12 @@ void registerSuccFail(string URL,FailureData& data,bool isSuccess)
     it=data.find(URL);
     vector < pair < double , double > > & passFail=it->second->_passFail;
     marker=it->second->_marker;
- 
- 
-    startTime=it->second->_start;  
-     
+
+
+    startTime=it->second->_start;
+
     gettimeofday(&currTime,NULL);
-    
+
     timersub(&currTime,&startTime,&result);
 
 
@@ -118,20 +118,20 @@ void registerSuccFail(string URL,FailureData& data,bool isSuccess)
         it->second->_marker=marker;
         gettimeofday(&it->second->_start,NULL);
     }
-    
+
 
    if(isSuccess)
    {
        passFail[marker].second++;
    }
-   
+
    else
    {
        passFail[marker].first++;
    }
 }
 
-    
+
 bool isAttemptReq(string URL,FailureData& data)
 {
     FailureData::iterator it;
@@ -150,19 +150,19 @@ bool isAttemptReq(string URL,FailureData& data)
                 //cout<<"Prob of faillure:"<<passFail[i].first/(passFail[i].first+passFail[i].second)<<endl;
             }
         }
- 
+
        if(avg)
-       { 
+       {
            avg=avg/it->second->_totalSlot;
            double prob;
 
-        
+
            if(avg*1000<lowerCutOff)
            {
                prob=avg;
            }
- 
-        
+
+
            else
            {
                double mapFactor=( ( (avg*1000-lowerCutOff)*(avg*1000-lowerCutOff) ) / ( higherCutOff-lowerCutOff ) )+lowerCutOff;
@@ -175,13 +175,13 @@ bool isAttemptReq(string URL,FailureData& data)
                prob=it->second->_avgOverWindow;
                cout<<"Average"<<prob<<endl;
            }
-        
+
            int decision=rand()%100;
 
-      
+
            if(decision<prob*100)
                return false;
-        
+
            return true;
        }
        return true;
@@ -203,7 +203,7 @@ int main(int argc,char**argv)
     FailureData data;
     int noOfAttempt=0,noOfExcept=0;
 
-    int count=atoi(argv[1]); 
+    int count=atoi(argv[1]);
     while(count--)
     {
         int decision=rand()%100;
@@ -213,16 +213,16 @@ int main(int argc,char**argv)
             noOfAttempt++;
             if(decision>=atoi(argv[2]) && 0)
                 registerSuccFail(fetchURL,data,true);
-    
+
             else
                 registerSuccFail(fetchURL,data,false);
         }
         else
             noOfExcept++;
-   
+
     }
 
     cout<<" SERVED FROM ATTEMPT "<<noOfAttempt<<" TOTAL "<<atoi(argv[1])<<endl;
     cout<<" SERVED FROM EXCEPT "<<noOfExcept<<" TOTAL "<<atoi(argv[1])<<endl;
-       
+
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/utils_test.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/utils_test.cc b/plugins/experimental/esi/test/utils_test.cc
index 469d5a8..a083785 100644
--- a/plugins/experimental/esi/test/utils_test.cc
+++ b/plugins/experimental/esi/test/utils_test.cc
@@ -48,7 +48,7 @@ void checkAttributes(const char *check_id, const AttributeList &attr_list, const
 
 pthread_key_t threadKey;
 
-int main() 
+int main()
 {
   pthread_key_create(&threadKey, NULL);
   Utils::init(&Debug, &Error);
@@ -89,7 +89,7 @@ int main()
   Utils::parseAttributes(str7, attr_list, "&");
   const char *expected_strs7[] = { "key1", "val1", 0 };
   checkAttributes("test7", attr_list, expected_strs7);
-  
+
   const char *escaped_sequence = "{\\\"site-attribute\\\":\\\"content=no_expandable; ajax_cert_expandable\\\"}";
   string str8("pos=\"FPM1\" spaceid=96584352 extra_mime=\"");
   str8.append(escaped_sequence);
@@ -116,4 +116,4 @@ int main()
   cout << endl << "All tests passed!" << endl;
   return 0;
 }
-  
+

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/esi/test/vars_test.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/test/vars_test.cc b/plugins/experimental/esi/test/vars_test.cc
index c420bc3..2739338 100644
--- a/plugins/experimental/esi/test/vars_test.cc
+++ b/plugins/experimental/esi/test/vars_test.cc
@@ -66,7 +66,7 @@ fakeDebug(const char *tag, const char *fmt, ...) {
   gFakeDebugLog.append(buf);
 }
 
-int main() 
+int main()
 {
   pthread_key_create(&threadKey, NULL);
   Utils::init(&Debug, &Error);
@@ -121,7 +121,7 @@ int main()
     esi_vars.populate(HttpHeader("hosT", -1, "localhost", -1));
     assert(esi_vars.getValue("HTTP_HOST") == "localhost");
 
-    esi_vars.populate(HttpHeader("User-agent", -1, 
+    esi_vars.populate(HttpHeader("User-agent", -1,
                                  "Mozilla/5.0 (Windows; U; Windows NT 5.1; en-US; rv:1.9.1.6) "
                                  "Gecko/20091201 Firefox/3.5.6 (.NETgecko CLR 3.5.30729)", -1));
 
@@ -365,7 +365,7 @@ int main()
   {
     cout << endl << "===================== Test 4" << endl;
     Variables esi_vars("vars_test", &Debug, &Error);
-    string cookie_str("FPS=dl; mb=d=OPsv7rvU4FFaAOoIRi75BBuqdMdbMLFuDwQmk6nKrCgno7L4xuN44zm7QBQJRmQSh8ken6GSVk8-&v=1; C=mg=1; Y=v=1&n=fmaptagvuff50&l=fc0d94i7/o&p=m2f0000313000400&r=8j&lg=en-US&intl=us; F=a=4KvLV9IMvTJnIAqCk25y9Use6hnPALtUf3n78PihlcIqvmzoW.Ax8UyW8_oxtgFNrrdmooqZmPa7WsX4gE.6sI69wuNwRKrRPFT29h9lhwuxxLz0RuQedVXhJhc323Q-&b=8gQZ"); // TODO - might need to 
+    string cookie_str("FPS=dl; mb=d=OPsv7rvU4FFaAOoIRi75BBuqdMdbMLFuDwQmk6nKrCgno7L4xuN44zm7QBQJRmQSh8ken6GSVk8-&v=1; C=mg=1; Y=v=1&n=fmaptagvuff50&l=fc0d94i7/o&p=m2f0000313000400&r=8j&lg=en-US&intl=us; F=a=4KvLV9IMvTJnIAqCk25y9Use6hnPALtUf3n78PihlcIqvmzoW.Ax8UyW8_oxtgFNrrdmooqZmPa7WsX4gE.6sI69wuNwRKrRPFT29h9lhwuxxLz0RuQedVXhJhc323Q-&b=8gQZ"); // TODO - might need to
     esi_vars.populate(HttpHeader("Cookie", -1, cookie_str.data(), cookie_str.size()));
 
     assert(esi_vars.getValue("HTTP_COOKIE{FPS}") == "dl");

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/geoip_acl/acl.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/geoip_acl/acl.cc b/plugins/experimental/geoip_acl/acl.cc
index 90bbe79..dde623a 100644
--- a/plugins/experimental/geoip_acl/acl.cc
+++ b/plugins/experimental/geoip_acl/acl.cc
@@ -95,7 +95,7 @@ RegexAcl::compile(const std::string& str, const char* filename, int lineno)
 {
   const char* error;
   int erroffset;
-  
+
   _regex_s = str;
   _rex = pcre_compile(_regex_s.c_str(), 0, &error, &erroffset, NULL);
 
@@ -224,7 +224,7 @@ CountryAcl::eval(TSRemapRequestInfo *rri, TSHttpTxn txnp) const
 
   if ((iso <= 0) || (!_iso_country_codes[iso]))
     return !_allow;
-    
+
   return _allow;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/geoip_acl/geoip_acl.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/geoip_acl/geoip_acl.cc b/plugins/experimental/geoip_acl/geoip_acl.cc
index 87e4d03..1382abd 100644
--- a/plugins/experimental/geoip_acl/geoip_acl.cc
+++ b/plugins/experimental/geoip_acl/geoip_acl.cc
@@ -18,7 +18,7 @@
 
 
 //////////////////////////////////////////////////////////////////////////////////////////////
-// 
+//
 // Main entry points for the plugin hooks etc.
 //
 #include <ts/ts.h>
@@ -110,7 +110,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
   return TSREMAP_NO_REMAP;
 }
 
-
+
 /*
   local variables:
   mode: C++

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/geoip_acl/lulu.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/geoip_acl/lulu.h b/plugins/experimental/geoip_acl/lulu.h
index 0ede84b..b7394d4 100644
--- a/plugins/experimental/geoip_acl/lulu.h
+++ b/plugins/experimental/geoip_acl/lulu.h
@@ -18,7 +18,7 @@
 
 
 //////////////////////////////////////////////////////////////////////////////////////////////
-// 
+//
 // Implement the classes for the various types of hash keys we support.
 //
 #ifndef __LULU_H__
@@ -35,7 +35,7 @@ static const char* PLUGIN_NAME = "geoip_acl";
 #endif // __LULU_H__
 
 
-
+
 /*
   local variables:
   mode: C++

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/hipes/hipes.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/hipes/hipes.cc b/plugins/experimental/hipes/hipes.cc
index 03908b7..04cbd95 100644
--- a/plugins/experimental/hipes/hipes.cc
+++ b/plugins/experimental/hipes/hipes.cc
@@ -41,13 +41,13 @@ escapify_url(const char *src, int src_len, char* dst, int dst_len)
 {
   // This bitmap is generated using the gen_escape.c prog.
   static unsigned char codes_to_escape[32] = {
-    0xFF, 0xFF, 0xFF, 0xFF, 
-    0xFF, 0xF9, 0x00, 0x3F, 
-    0x80, 0x00, 0x00, 0x1E, 
-    0x80, 0x00, 0x00, 0x1F, 
-    0xFF, 0xFF, 0xFF, 0xFF, 
-    0xFF, 0xFF, 0xFF, 0xFF, 
-    0xFF, 0xFF, 0xFF, 0xFF, 
+    0xFF, 0xFF, 0xFF, 0xFF,
+    0xFF, 0xF9, 0x00, 0x3F,
+    0x80, 0x00, 0x00, 0x1E,
+    0x80, 0x00, 0x00, 0x1F,
+    0xFF, 0xFF, 0xFF, 0xFF,
+    0xFF, 0xFF, 0xFF, 0xFF,
+    0xFF, 0xFF, 0xFF, 0xFF,
     0xFF, 0xFF, 0xFF, 0xFF
   };
 
@@ -306,11 +306,11 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
       len = 8 + h_conf->hipes_server.size() + strlen(port) + (param_len - (slash - param) - 1);
     } else {
       len = 8 + h_conf->hipes_server.size() + (param_len - (slash - param) - 1);
-    } 
+    }
     if (len > MAX_PATH_SIZE) {
       TSHttpTxnSetHttpRetStatus(rh, TS_HTTP_STATUS_REQUEST_URI_TOO_LONG);
       return TSREMAP_NO_REMAP;
-    }  
+    }
     if(h_conf->hipes_port != 80) {
       snprintf(svc_url, MAX_PATH_SIZE, "http://%s%s/%.*s", h_conf->hipes_server.c_str(), port, len, slash + 1);
     } else {
@@ -320,7 +320,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
 
     len = escapify_url(svc_url, len, svc_url_esc, MAX_PATH_SIZE);
     if (len < 0) {
-      TSHttpTxnSetHttpRetStatus(rh, TS_HTTP_STATUS_BAD_REQUEST); 
+      TSHttpTxnSetHttpRetStatus(rh, TS_HTTP_STATUS_BAD_REQUEST);
       return TSREMAP_NO_REMAP;
     }
     TSDebug(PLUGIN_NAME, "Escaped service URL is %s(%d)", svc_url_esc, len);
@@ -435,7 +435,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
 
   // If we redirect, just generate a 302 URL, otherwise update the RRI struct properly.
   if (do_redirect) {
-    int len; 
+    int len;
 
     if (h_conf->ssl) {
       // https://<host>:<port>/<path>?<query?\0
@@ -493,10 +493,10 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
 
       redirect_url_size = pos - redirect_url + 1;
       TSDebug(PLUGIN_NAME, "Redirecting to %.*s", redirect_url_size, redirect_url);
-      const char *start = redirect_url; 
+      const char *start = redirect_url;
       const char *end = start + redirect_url_size;
       rri->redirect = 1;
-      TSUrlParse(rri->requestBufp, rri->requestUrl, &start, end);  
+      TSUrlParse(rri->requestBufp, rri->requestUrl, &start, end);
       TSHttpTxnSetHttpRetStatus(rh, TS_HTTP_STATUS_MOVED_TEMPORARILY);
     }
   } else { // Not a redirect, so proceed normally
@@ -519,7 +519,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
     }
 
     // Set server ...
-    TSUrlHostSet(rri->requestBufp, rri->requestUrl, h_conf->svc_server.c_str(), h_conf->svc_server.size()); 
+    TSUrlHostSet(rri->requestBufp, rri->requestUrl, h_conf->svc_server.c_str(), h_conf->svc_server.size());
     TSDebug(PLUGIN_NAME, "New server is %.*s", (int) h_conf->svc_server.size(), h_conf->svc_server.c_str());
 
     // ... and port
@@ -546,7 +546,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
 }
 
 
-
+
 /*
   local variables:
   mode: C++

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/mysql_remap/lib/dictionary.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/mysql_remap/lib/dictionary.c b/plugins/experimental/mysql_remap/lib/dictionary.c
index 11a56a2..c76cf70 100644
--- a/plugins/experimental/mysql_remap/lib/dictionary.c
+++ b/plugins/experimental/mysql_remap/lib/dictionary.c
@@ -67,7 +67,7 @@
 static void * mem_double(void * ptr, int size)
 {
     void * newptr ;
- 
+
     newptr = calloc(2*size, 1);
     if (newptr==NULL) {
         return NULL ;
@@ -253,7 +253,7 @@ int dictionary_set(dictionary * d, char * key, char * val)
 	unsigned	hash ;
 
 	if (d==NULL || key==NULL) return -1 ;
-	
+
 	/* Compute hash for this key */
 	hash = dictionary_hash(key) ;
 	/* Find if value is already in dictionary */
@@ -397,7 +397,7 @@ int main(int argc, char *argv[])
 	/* Allocate dictionary */
 	printf("allocating...\n");
 	d = dictionary_new(0);
-	
+
 	/* Set values in dictionary */
 	printf("setting %d values...\n", NVALS);
 	for (i=0 ; i<NVALS ; i++) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/mysql_remap/lib/iniparser.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/mysql_remap/lib/iniparser.c b/plugins/experimental/mysql_remap/lib/iniparser.c
index 14b8e3c..234435e 100644
--- a/plugins/experimental/mysql_remap/lib/iniparser.c
+++ b/plugins/experimental/mysql_remap/lib/iniparser.c
@@ -105,9 +105,9 @@ static char * strstrip(char * s)
 {
     static char l[ASCIILINESZ+1];
 	char * last ;
-	
+
     if (s==NULL) return NULL ;
-    
+
 	while (isspace((int)*s) && *s) s++;
 	memset(l, 0, ASCIILINESZ+1);
 	strcpy(l, s);
@@ -480,7 +480,7 @@ static line_status iniparser_line(
     char * section,
     char * key,
     char * value)
-{   
+{
     line_status sta ;
     char        line[ASCIILINESZ+1];
     int         len ;
@@ -494,7 +494,7 @@ static line_status iniparser_line(
         sta = LINE_EMPTY ;
     } else if (line[0]=='#') {
         /* Comment line */
-        sta = LINE_COMMENT ; 
+        sta = LINE_COMMENT ;
     } else if (line[0]=='[' && line[len-1]==']') {
         /* Section name */
         sscanf(line, "[%[^]]", section);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/s3_auth/s3_auth.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/s3_auth/s3_auth.cc b/plugins/experimental/s3_auth/s3_auth.cc
index 38bb397..744a287 100644
--- a/plugins/experimental/s3_auth/s3_auth.cc
+++ b/plugins/experimental/s3_auth/s3_auth.cc
@@ -258,7 +258,7 @@ S3Request::set_header(const char* header, int header_len, const char* val, int v
 //    Date + "\n" +
 //    CanonicalizedAmzHeaders +
 //    CanonicalizedResource;
-// 
+//
 // ToDo:
 // -----
 //     1) UTF8
@@ -511,7 +511,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn txnp, TSRemapRequestInfo */* rri */)
 }
 
 
-
+
 /*
   local variables:
   mode: C++

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ssl_cert_loader/ats-util.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ssl_cert_loader/ats-util.h b/plugins/experimental/ssl_cert_loader/ats-util.h
index 0ee4a8d..892ed8f 100644
--- a/plugins/experimental/ssl_cert_loader/ats-util.h
+++ b/plugins/experimental/ssl_cert_loader/ats-util.h
@@ -51,7 +51,7 @@
     foo *bar[ZOMG]; // array of pointers.
     ink_zero(bar); // zero all pointers in the array.
     @endcode
-    
+
  */
 template <typename T> inline void
 ink_zero(

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ssl_cert_loader/domain-tree.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/ssl_cert_loader/domain-tree.cc b/plugins/experimental/ssl_cert_loader/domain-tree.cc
index c1f51c9..31e8fd7 100644
--- a/plugins/experimental/ssl_cert_loader/domain-tree.cc
+++ b/plugins/experimental/ssl_cert_loader/domain-tree.cc
@@ -1,4 +1,4 @@
-/** @file 
+/** @file
     SSL dynamic certificate loader
     Loads certificates into a hash table as they are requested
 
@@ -27,7 +27,7 @@
 
 // return true if comparable.  Return type of compare in relative parameter
 // 0 if eq.  < 0 if node key is broader.  > 0 if parameter key is broader
-bool 
+bool
 DomainNameTree::DomainNameNode::compare(std::string key, int &relative)
 {
   size_t star_loc = key.find("*");
@@ -42,14 +42,14 @@ DomainNameTree::DomainNameNode::compare(std::string key, int &relative)
   return this->prunedCompare(key, relative, is_wild);
 }
 
-bool 
+bool
 DomainNameTree::DomainNameNode::prunedCompare(std::string key, int &relative, bool is_wild)
 {
   if (key == this->key) {
     relative = 0;
     return true;
   } else {
-    if (this->is_wild) { 
+    if (this->is_wild) {
       size_t loc = key.find(this->key);
 
       if (this->key == "") { // Match all
@@ -75,7 +75,7 @@ DomainNameTree::DomainNameNode::prunedCompare(std::string key, int &relative, bo
           if ((this->key.length() - key.length()) == loc) {
             relative = 1;
             return true;
-          } 
+          }
         }
       }
     }
@@ -95,7 +95,7 @@ DomainNameTree::DomainNameNode *DomainNameTree::find(std::string key, bool best_
     key = key.substr(star_loc+1);
     is_wild = true;
   }
-  
+
   bool set_iter = false;
   std::deque<DomainNameNode *>::iterator sibPtr;
   DomainNameNode *current_node = root;
@@ -169,7 +169,7 @@ DomainNameTree::insert(std::string key, void *payload, int order)
       new_node->parent = node->parent;
       new_node->children.push_back(node);
 
-      // Replace the node with new_node in the child list of the parent; 
+      // Replace the node with new_node in the child list of the parent;
       for (std::deque<DomainNameNode *>::iterator iter = node->parent->children.begin();
            iter != node->parent->children.end(); ++iter) {
         if (*(iter) == node) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ssl_cert_loader/domain-tree.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ssl_cert_loader/domain-tree.h b/plugins/experimental/ssl_cert_loader/domain-tree.h
index 0efcb24..392fb6d 100644
--- a/plugins/experimental/ssl_cert_loader/domain-tree.h
+++ b/plugins/experimental/ssl_cert_loader/domain-tree.h
@@ -27,15 +27,15 @@
 
 class DomainNameTree {
 public:
-  
+
   class DomainNameNode {
   public:
     DomainNameNode()
-      : order(-1), payload(NULL), parent(NULL), is_wild(false) 
+      : order(-1), payload(NULL), parent(NULL), is_wild(false)
     { }
 
     DomainNameNode(std::string key, void *payload, int order, bool is_wild)
-      : key(key), order(order), payload(payload), parent(NULL), is_wild(is_wild)  
+      : key(key), order(order), payload(payload), parent(NULL), is_wild(is_wild)
     { }
 
     DomainNameNode *match(std::string value);
@@ -68,7 +68,7 @@ public:
     root->key = "";
     root->order = 0x7FFFFFFF;
     root->is_wild = true;
-    tree_mutex = TSMutexCreate(); 
+    tree_mutex = TSMutexCreate();
   }
 
   ~DomainNameTree()
@@ -82,7 +82,7 @@ public:
     DomainNameNode *retval = this->find(key, true);
     TSMutexUnlock(this->tree_mutex);
     return retval;
-  } 
+  }
 
   DomainNameNode *findFirstMatch(std::string key)
   {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ssl_cert_loader/ssl-cert-loader.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/ssl_cert_loader/ssl-cert-loader.cc b/plugins/experimental/ssl_cert_loader/ssl-cert-loader.cc
index 7bf72cc..c7a5843 100644
--- a/plugins/experimental/ssl_cert_loader/ssl-cert-loader.cc
+++ b/plugins/experimental/ssl_cert_loader/ssl-cert-loader.cc
@@ -55,8 +55,8 @@ public:
 class SslEntry {
 public:
   SslEntry()
-    : ctx(NULL), op(TS_SSL_HOOK_OP_DEFAULT) 
-  { 
+    : ctx(NULL), op(TS_SSL_HOOK_OP_DEFAULT)
+  {
     this->mutex = TSMutexCreate();
   }
 
@@ -68,7 +68,7 @@ public:
   // If the CTX is not already created, use these
   // files to load things up
   std::string certFileName;
-  std::string keyFileName; 
+  std::string keyFileName;
   TSMutex mutex;
   std::deque<TSVConn> waitingVConns;
 };
@@ -95,7 +95,7 @@ Parse_Addr_String(ts::ConstBuffer const &text, IpRange &range)
   } else { // Assume it is a single address
     newAddr.load(text);
     range.first = newAddr;
-    range.second = newAddr; 
+    range.second = newAddr;
   }
 }
 
@@ -181,7 +181,7 @@ Load_Certificate(SslEntry const *entry, std::deque<std::string> &names)
   // Fetch out the names associated with the certificate
   if (cert != NULL) {
     X509_NAME *name = X509_get_subject_name(cert);
-    char  subjectCn[256]; 
+    char  subjectCn[256];
 
     if (X509_NAME_get_text_by_NID(name, NID_commonName, subjectCn, sizeof(subjectCn)) >= 0) {
       std::string tmp_name(subjectCn);
@@ -193,14 +193,14 @@ Load_Certificate(SslEntry const *entry, std::deque<std::string> &names)
       unsigned count = sk_GENERAL_NAME_num(alt_names);
       for (unsigned i = 0; i < count; i++) {
         GENERAL_NAME *alt_name = sk_GENERAL_NAME_value(alt_names, i);
-  
+
         if (alt_name->type == GEN_DNS) {
           // Current name is a DNS name, let's check it
           char *name_ptr = (char *) ASN1_STRING_data(alt_name->d.dNSName);
           std::string tmp_name(name_ptr);
           names.push_back(tmp_name);
         }
-      } 
+      }
       sk_GENERAL_NAME_pop_free(alt_names, GENERAL_NAME_free);
     }
   }
@@ -217,23 +217,23 @@ Load_Certificate(SslEntry const *entry, std::deque<std::string> &names)
 SslEntry *
 Load_Certificate_Entry(ParsedSslValues const &values, std::deque<std::string> &names)
 {
-  SslEntry *retval = NULL; 
+  SslEntry *retval = NULL;
   std::string cert_file_path;
   std::string priv_file_path;
 
   retval = new SslEntry();
-  if (values.server_cert_name.length() > 0) { 
+  if (values.server_cert_name.length() > 0) {
     if (values.server_cert_name[0] != '/') {
-      cert_file_path = std::string(TSConfigDirGet()) + '/' + values.server_cert_name; 
-    } else { 
+      cert_file_path = std::string(TSConfigDirGet()) + '/' + values.server_cert_name;
+    } else {
       cert_file_path = values.server_cert_name;
     }
     retval->certFileName = cert_file_path;
   }
   if (values.server_priv_key_file.length() > 0) {
     if (values.server_priv_key_file[0] != '/') {
-      priv_file_path = std::string(TSConfigDirGet()) + '/' + values.server_priv_key_file; 
-    } else { 
+      priv_file_path = std::string(TSConfigDirGet()) + '/' + values.server_priv_key_file;
+    } else {
       priv_file_path = values.server_priv_key_file;
     }
     retval->keyFileName = priv_file_path;
@@ -241,7 +241,7 @@ Load_Certificate_Entry(ParsedSslValues const &values, std::deque<std::string> &n
   // Must go ahead and load the cert to get the names
   if (values.server_name.length() == 0 &&
       values.server_ips.size() == 0) {
-    retval->ctx = Load_Certificate(retval, names); 
+    retval->ctx = Load_Certificate(retval, names);
   }
   if (values.action.length() > 0) {
     if (values.action == "tunnel") {
@@ -287,21 +287,21 @@ Parse_Config(Value &parent, ParsedSslValues &orig_values)
 
   val = parent.find("child-match");
   if (val) {
-    Parse_Config_Rules(val, cur_values); 
+    Parse_Config_Rules(val, cur_values);
   } else { // We are terminal, enter a match case
-    TSDebug(PN, "Terminal SSL Config: server_priv_key_file=%s server_name=%s server_cert_name=%s action=%s", 
-      cur_values.server_priv_key_file.c_str(), 
-      cur_values.server_name.c_str(), 
-      cur_values.server_cert_name.c_str(), 
-      cur_values.action.c_str() 
+    TSDebug(PN, "Terminal SSL Config: server_priv_key_file=%s server_name=%s server_cert_name=%s action=%s",
+      cur_values.server_priv_key_file.c_str(),
+      cur_values.server_name.c_str(),
+      cur_values.server_cert_name.c_str(),
+      cur_values.action.c_str()
     );
     // Load the certificate and create a context if appropriate
     std::deque<std::string> cert_names;
     SslEntry *entry  = Load_Certificate_Entry(cur_values, cert_names);
-    
+
     // Store in appropriate table
     if (cur_values.server_name.length() > 0) {
-      Lookup.tree.insert(cur_values.server_name, entry, Parse_order++); 
+      Lookup.tree.insert(cur_values.server_name, entry, Parse_order++);
     }
     if (cur_values.server_ips.size() > 0) {
       for (size_t i = 0; i < cur_values.server_ips.size(); i++) {
@@ -347,7 +347,7 @@ Load_Certificate_Thread(void *arg)
       entry->waitingVConns.pop_back();
       TSSslConnection sslobj = TSVConnSSLConnectionGet(vc);
       SSL *ssl = reinterpret_cast<SSL *>(sslobj);
-      SSL_set_SSL_CTX(ssl, entry->ctx); 
+      SSL_set_SSL_CTX(ssl, entry->ctx);
       TSVConnReenable(vc);
     }
     TSMutexUnlock(entry->mutex);
@@ -408,24 +408,24 @@ CB_Pre_Accept(TSCont /*contp*/, TSEvent event, void *edata)
     } else {
       if (entry->ctx == NULL) {
         if (entry->waitingVConns.begin() == entry->waitingVConns.end()) {
-          entry->waitingVConns.push_back(ssl_vc);  
+          entry->waitingVConns.push_back(ssl_vc);
           TSMutexUnlock(entry->mutex);
-    
+
           TSThreadCreate(Load_Certificate_Thread, entry);
         } else { // Just add yourself to the queue
-          entry->waitingVConns.push_back(ssl_vc);  
+          entry->waitingVConns.push_back(ssl_vc);
           TSMutexUnlock(entry->mutex);
         }
         // Return before we reenable
         return TS_SUCCESS;
       } else { // if (entry->ctx != NULL) {
-        SSL_set_SSL_CTX(ssl, entry->ctx); 
+        SSL_set_SSL_CTX(ssl, entry->ctx);
         TSDebug(PN, "Replace cert based on IP");
         TSMutexUnlock(entry->mutex);
       }
     }
   }
-  
+
   // All done, reactivate things
   TSVConnReenable(ssl_vc);
 
@@ -459,17 +459,17 @@ CB_servername(TSCont /*contp*/, TSEvent /*event*/, void *edata)
       if (entry->ctx == NULL) {
         // Spawn off a thread to load a potentially expensive certificate
         if (entry->waitingVConns.begin() == entry->waitingVConns.end()) {
-          entry->waitingVConns.push_back(ssl_vc);  
+          entry->waitingVConns.push_back(ssl_vc);
           TSMutexUnlock(entry->mutex);
           TSThreadCreate(Load_Certificate_Thread, entry);
         } else { // Just add yourself to the queue
-          entry->waitingVConns.push_back(ssl_vc);  
+          entry->waitingVConns.push_back(ssl_vc);
           TSMutexUnlock(entry->mutex);
         }
         // Won't reenable until the certificate has been loaded
         return TS_SUCCESS;
       } else { //if (entry->ctx != NULL) {
-        SSL_set_SSL_CTX(ssl, entry->ctx); 
+        SSL_set_SSL_CTX(ssl, entry->ctx);
         TSDebug(PN, "Replace cert based on name %s", servername);
       }
       TSMutexUnlock(entry->mutex);
@@ -511,7 +511,7 @@ TSPluginInit(int argc, const char *argv[])
       ConfigPath = std::string(TSConfigDirGet()) + '/' + std::string(optarg);
       break;
     }
-  } 
+  }
   if (ConfigPath.length() == 0) {
     static char const * const DEFAULT_CONFIG_PATH = "ssl_start.cfg";
     ConfigPath = std::string(TSConfigDirGet()) + '/' + std::string(DEFAULT_CONFIG_PATH);
@@ -534,7 +534,7 @@ TSPluginInit(int argc, const char *argv[])
     TSHttpHookAdd(TS_SSL_SNI_HOOK, cb_sni);
     success = true;
   }
- 
+
   if (!success) {
     if (cb_pa) TSContDestroy(cb_pa);
     if (cb_lc) TSContDestroy(cb_lc);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua.c b/plugins/experimental/ts_lua/ts_lua.c
index 49930b7..93d8abe 100644
--- a/plugins/experimental/ts_lua/ts_lua.c
+++ b/plugins/experimental/ts_lua/ts_lua.c
@@ -8,7 +8,7 @@
   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.
@@ -169,9 +169,9 @@ TSRemapDoRemap(void *ih, TSHttpTxn rh, TSRemapRequestInfo * rri)
   if(http_ctx->has_hook) {
     TSDebug(TS_LUA_DEBUG_TAG, "[%s] has txn hook -> adding txn close hook handler to release resources", __FUNCTION__);
     TSHttpTxnHookAdd(rh, TS_HTTP_TXN_CLOSE_HOOK, contp);
-  } else {    
+  } else {
     TSDebug(TS_LUA_DEBUG_TAG, "[%s] no txn hook -> release resources now", __FUNCTION__);
-    ts_lua_destroy_http_ctx(http_ctx); 
+    ts_lua_destroy_http_ctx(http_ctx);
     TSContDestroy(contp);
   }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_cached_response.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_cached_response.c b/plugins/experimental/ts_lua/ts_lua_cached_response.c
index 3de9925..abc30b7 100644
--- a/plugins/experimental/ts_lua/ts_lua_cached_response.c
+++ b/plugins/experimental/ts_lua/ts_lua_cached_response.c
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_cached_response.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_cached_response.h b/plugins/experimental/ts_lua/ts_lua_cached_response.h
index 6865ba5..72bdf8a 100644
--- a/plugins/experimental/ts_lua/ts_lua_cached_response.h
+++ b/plugins/experimental/ts_lua/ts_lua_cached_response.h
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_client_request.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_client_request.c b/plugins/experimental/ts_lua/ts_lua_client_request.c
index b17679c..9d6cd26 100644
--- a/plugins/experimental/ts_lua/ts_lua_client_request.c
+++ b/plugins/experimental/ts_lua/ts_lua_client_request.c
@@ -8,7 +8,7 @@
   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.
@@ -373,7 +373,7 @@ ts_lua_client_request_get_url_host(lua_State * L)
     char *key = "Host";
     char *l_key = "host";
     int key_len = 4;
-    
+
 
     TSMLoc field_loc;
 
@@ -388,7 +388,7 @@ ts_lua_client_request_get_url_host(lua_State * L)
       field_loc = TSMimeHdrFieldFind(http_ctx->client_request_bufp, http_ctx->client_request_hdrp, l_key, key_len);
       if(field_loc) {
         host =
-          TSMimeHdrFieldValueStringGet(http_ctx->client_request_bufp, http_ctx->client_request_hdrp, field_loc, 
+          TSMimeHdrFieldValueStringGet(http_ctx->client_request_bufp, http_ctx->client_request_hdrp, field_loc,
                                        -1, &len);
         TSHandleMLocRelease(http_ctx->client_request_bufp, http_ctx->client_request_hdrp, field_loc);
       }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_client_request.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_client_request.h b/plugins/experimental/ts_lua/ts_lua_client_request.h
index d279b19..936e1e4 100644
--- a/plugins/experimental/ts_lua/ts_lua_client_request.h
+++ b/plugins/experimental/ts_lua/ts_lua_client_request.h
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_client_response.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_client_response.c b/plugins/experimental/ts_lua/ts_lua_client_response.c
index 7e22eef..ac98869 100644
--- a/plugins/experimental/ts_lua/ts_lua_client_response.c
+++ b/plugins/experimental/ts_lua/ts_lua_client_response.c
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_client_response.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_client_response.h b/plugins/experimental/ts_lua/ts_lua_client_response.h
index eb20467..f9b530f 100644
--- a/plugins/experimental/ts_lua/ts_lua_client_response.h
+++ b/plugins/experimental/ts_lua/ts_lua_client_response.h
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_common.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_common.h b/plugins/experimental/ts_lua/ts_lua_common.h
index 6c245f3..1ba925d 100644
--- a/plugins/experimental/ts_lua/ts_lua_common.h
+++ b/plugins/experimental/ts_lua/ts_lua_common.h
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_context.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_context.c b/plugins/experimental/ts_lua/ts_lua_context.c
index 5d967a9..dd6952d 100644
--- a/plugins/experimental/ts_lua/ts_lua_context.c
+++ b/plugins/experimental/ts_lua/ts_lua_context.c
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_context.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_context.h b/plugins/experimental/ts_lua/ts_lua_context.h
index e77abfd..228bc7c 100644
--- a/plugins/experimental/ts_lua/ts_lua_context.h
+++ b/plugins/experimental/ts_lua/ts_lua_context.h
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_crypto.c
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_crypto.c b/plugins/experimental/ts_lua/ts_lua_crypto.c
index 77718d4..addd128 100644
--- a/plugins/experimental/ts_lua/ts_lua_crypto.c
+++ b/plugins/experimental/ts_lua/ts_lua_crypto.c
@@ -8,7 +8,7 @@
   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.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/ab5ba9a8/plugins/experimental/ts_lua/ts_lua_crypto.h
----------------------------------------------------------------------
diff --git a/plugins/experimental/ts_lua/ts_lua_crypto.h b/plugins/experimental/ts_lua/ts_lua_crypto.h
index 6f0da12..bbe8d66 100644
--- a/plugins/experimental/ts_lua/ts_lua_crypto.h
+++ b/plugins/experimental/ts_lua/ts_lua_crypto.h
@@ -8,7 +8,7 @@
   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.