You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by mt...@apache.org on 2010/05/13 09:09:56 UTC

svn commit: r943821 [7/18] - in /trafficserver/traffic/trunk: example/add-header/ example/app-template/ example/append-transform/ example/basic-auth/ example/blacklist-0/ example/blacklist-1/ example/bnull-transform/ example/cache_scan/ example/file-1/...

Modified: trafficserver/traffic/trunk/proxy/congest/Congestion.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/congest/Congestion.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/congest/Congestion.cc (original)
+++ trafficserver/traffic/trunk/proxy/congest/Congestion.cc Thu May 13 07:09:39 2010
@@ -245,7 +245,7 @@ CongestionControlRecord::Init(matcher_li
       prefix = xstrdup(val);
       prefix_len = strlen(prefix);
       rank += 1;
-      // prefix will be used in the ControlBase 
+      // prefix will be used in the ControlBase
       continue;
     } else if (strcasecmp(label, "port") == 0) {
       port = atoi(val);
@@ -352,7 +352,7 @@ struct CongestionControl_UpdateContinuat
 
 extern void initCongestionDB();
 
-// place holder for congestion control enable config 
+// place holder for congestion control enable config
 static int
 CongestionControlEnabledChanged(const char *name, RecDataT data_type, RecData data, void *cookie)
 {
@@ -777,7 +777,7 @@ CongestionEntry::sprint(char *buf, int b
 
 //-------------------------------------------------------------
 // When a connection failure happened, try to get the lock
-//  first and change register the event, if we can not get 
+//  first and change register the event, if we can not get
 //  the lock, discard the event
 //-------------------------------------------------------------
 void

Modified: trafficserver/traffic/trunk/proxy/congest/Congestion.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/congest/Congestion.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/congest/Congestion.h (original)
+++ trafficserver/traffic/trunk/proxy/congest/Congestion.h Thu May 13 07:09:39 2010
@@ -289,7 +289,7 @@ struct CongestionEntry:RequestData
   void stat_inc_F();
   void stat_inc_M();
 
-  // fail history operations 
+  // fail history operations
   void clearFailHistory();
   bool compCongested();
 
@@ -463,7 +463,7 @@ inku64 make_key(char *hostname, unsigned
 inku64 make_key(char *hostname, int len, unsigned long ip, char *prefix, int prelen, short port = 0);
 
 //----------------------------------------------------
-// the following functions are actually declared in 
+// the following functions are actually declared in
 // CongestionDB.h and defined in CongestionDB.cc
 // They are included here only to make the
 // editing & compiling process faster

Modified: trafficserver/traffic/trunk/proxy/congest/CongestionDB.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/congest/CongestionDB.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/congest/CongestionDB.cc (original)
+++ trafficserver/traffic/trunk/proxy/congest/CongestionDB.cc Thu May 13 07:09:39 2010
@@ -43,9 +43,9 @@ int CONGESTION_DB_SIZE = 1024;
 CongestionDB *theCongestionDB = NULL;
 
 
-/* 
+/*
  * the CongestionDBCont is the continuation to do the congestion db related work
- * when the CongestionDB's corresponding function does not get the lock in the 
+ * when the CongestionDB's corresponding function does not get the lock in the
  * first try
  */
 
@@ -131,7 +131,7 @@ Free_CongestRequestParam(CongestRequestP
 static long
   congestEntryGCTime = 0;
 
-// Before the garbage collection of the congestion db, set the 
+// Before the garbage collection of the congestion db, set the
 //  current GC time, CongestionEntry::usefulInfo(t) will use the
 //  timestamp to determine if the entry contains useful infomation
 
@@ -305,7 +305,7 @@ CongestionDB::revalidateBucket(int buckI
     if (!cur->validate()) {
       remove_entry(buckId, &it);
       cur->put();
-      // the next entry has been moved to the current pos 
+      // the next entry has been moved to the current pos
       //because of the remove_entry
       cur = cur_entry(buckId, &it);
     } else
@@ -501,7 +501,7 @@ get_congest_entry(Continuation * cont, H
       Debug("congestion_control", "get_congest_entry, found entry 0x%x done", (void *) *ppEntry);
       return ACTION_RESULT_DONE;
     } else {
-      // create a new entry and add it to the congestDB 
+      // create a new entry and add it to the congestDB
       *ppEntry = new CongestionEntry(data->get_host(), data->get_ip(), p, key);
       (*ppEntry)->get();
       theCongestionDB->insert_entry(key, *ppEntry);
@@ -566,7 +566,7 @@ get_congest_list(Continuation * cont, MI
 }
 
 /*
- * this function is to suport removing the congested state for a 
+ * this function is to suport removing the congested state for a
  * specific server when the administrator knows it is online again
  */
 
@@ -588,10 +588,10 @@ remove_congested_entry(inku64 key)
 
 //--------------------------------------------------------------
 //  remove_congested_entry(char* buf, MIOBuffer *out_buffer)
-//   INPUT: buf 
+//   INPUT: buf
 //         format: "all",
 //                 "host=<hostname>[/<prefix>]",
-//                 "ip=<ip addr>[/<prefix>]", 
+//                 "ip=<ip addr>[/<prefix>]",
 //                 "key=<internal key>"
 //   OUTPUT: out_buffer
 //           message to the Raf

Modified: trafficserver/traffic/trunk/proxy/congest/CongestionDB.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/congest/CongestionDB.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/congest/CongestionDB.h (original)
+++ trafficserver/traffic/trunk/proxy/congest/CongestionDB.h Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
  *
  ****************************************************************************/
 
-/* 
+/*
  * CongestionDB is implemented in a Multithread-Safe hash table
  * the Data will be wrote to a disk file for recovery purpose.
  */
@@ -58,11 +58,11 @@ void initCongestionDB();
 
 /*
  * CongestRequestParam is the data structure passed to the request
- * to update the congestion db with the appropriate info 
- * It is used when the TS missed a try_lock, the request info will be 
+ * to update the congestion db with the appropriate info
+ * It is used when the TS missed a try_lock, the request info will be
  * stored in the CongestRequestParam and insert in the to-do list of the
  * approperiate DB partition.
- * The first operation after the TS get the lock for a partition is 
+ * The first operation after the TS get the lock for a partition is
  * to run the to do list
  */
 

Modified: trafficserver/traffic/trunk/proxy/congest/CongestionTest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/congest/CongestionTest.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/congest/CongestionTest.cc (original)
+++ trafficserver/traffic/trunk/proxy/congest/CongestionTest.cc Thu May 13 07:09:39 2010
@@ -37,7 +37,7 @@
 //-------------------------------------------------------------
 // Test the HashTable implementation
 //-------------------------------------------------------------
-/* all of the elements inserted into the HashTable should be in the 
+/* all of the elements inserted into the HashTable should be in the
  * table and can be easily retrived
  * also exercise the resizing of the table
  */
@@ -166,7 +166,7 @@ EXCLUSIVE_REGRESSION_TEST(Congestion_Has
 //-------------------------------------------------------------
 // Test the FailHistory implementation
 //-------------------------------------------------------------
-/* regesiter events into the FailHistory and the number of events 
+/* regesiter events into the FailHistory and the number of events
  * should be correct
  */
 struct CCFailHistoryTestCont:Continuation
@@ -361,7 +361,7 @@ EXCLUSIVE_REGRESSION_TEST(Congestion_Fai
 //-------------------------------------------------------------
 // Test the CongestionDB implementation
 //-------------------------------------------------------------
-/* Insert simulated CongestionEntry into the CongestionDB and 
+/* Insert simulated CongestionEntry into the CongestionDB and
  * exercise the GC of the DB, remove entries from DB
  */
 

Modified: trafficserver/traffic/trunk/proxy/congest/MT_hashtable.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/congest/MT_hashtable.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/congest/MT_hashtable.h (original)
+++ trafficserver/traffic/trunk/proxy/congest/MT_hashtable.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   Multithread Safe Hash table implementation
 
-  
+
  ****************************************************************************/
 #ifndef MT_HASHTABLE_H_
 #define MT_HASHTABLE_H_
@@ -194,8 +194,8 @@ private:
   IMTHashTable(IMTHashTable &);
 };
 
-/* 
- * we can use ClassAllocator here if the malloc performance becomes a problem 
+/*
+ * we can use ClassAllocator here if the malloc performance becomes a problem
  */
 
 template<class key_t, class data_t> inline data_t IMTHashTable<key_t, data_t>::insert_entry(key_t key, data_t data)

Modified: trafficserver/traffic/trunk/proxy/cust_log_fmt_cnvrt.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/cust_log_fmt_cnvrt.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/cust_log_fmt_cnvrt.cc (original)
+++ trafficserver/traffic/trunk/proxy/cust_log_fmt_cnvrt.cc Thu May 13 07:09:39 2010
@@ -173,7 +173,7 @@ process_format(SimpleTokenizer * tok, Lo
   char *header = tok->getRest();
 
 
-  // check if we have already defined a LogFormat we can use 
+  // check if we have already defined a LogFormat we can use
 
   char *escaped_fmt_string = create_escaped_string(fmt_string);
 
@@ -495,7 +495,7 @@ main(int argc, char **argv)
   // build the application information structure
   //
   AppVersionInfo appVersionInfo;
-  appVersionInfo.setup(PACKAGE_NAME, PROGRAM_NAME, PACKAGE_VERSION, __DATE__, 
+  appVersionInfo.setup(PACKAGE_NAME, PROGRAM_NAME, PACKAGE_VERSION, __DATE__,
                        __TIME__, BUILD_MACHINE, BUILD_PERSON, "");
 
   // process command-line arguments

Modified: trafficserver/traffic/trunk/proxy/dns_cache/DNS_cache.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/dns_cache/DNS_cache.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/dns_cache/DNS_cache.cc (original)
+++ trafficserver/traffic/trunk/proxy/dns_cache/DNS_cache.cc Thu May 13 07:09:39 2010
@@ -241,7 +241,7 @@ DNS_Cache::process_hostdb_info(HostDBInf
     }
 
     // round_robin indicates multiple ip's associate
-    // with host alias. 
+    // with host alias.
     if (!r->round_robin) {
       hp->rd = 1;
       //          hp->ra = (NoRecurse == 0);
@@ -287,13 +287,13 @@ DNS_Cache::process_hostdb_info(HostDBInf
       HostDBRoundRobin *rr = r->rr();
 
       // First, set up the hostname in reply with type being CNAME,
-      // Then need to put additional canonical name 
+      // Then need to put additional canonical name
 
       // Get ttl from r
       // Currently, the only ttl that is valid is from the initial
       // HostDBInfo structure, all HostDBInfo structs from HostDBInfoRoundRobin
       // are invalid. For now, just use ttl in initial HostDBInfo structures
-      // for all ttl in RR answers. 
+      // for all ttl in RR answers.
       ttl = r->ip_time_remaining() * 60;
       Debug("dns_cache", "first entries in ROUNDROBIN has ttl %d\n", ttl);
       // Jump over header section

Modified: trafficserver/traffic/trunk/proxy/hdrs/HTTP.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HTTP.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HTTP.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HTTP.cc Thu May 13 07:09:39 2010
@@ -1673,8 +1673,8 @@ HTTPInfo::marshal(char *buf, int len)
   buf += HTTP_ALT_MARSHAL_SIZE;
   used += HTTP_ALT_MARSHAL_SIZE;
 
-  // The m_{request,response}_hdr->m_heap pointers are converted 
-  //    to zero based offsets from the start of the buffer we're 
+  // The m_{request,response}_hdr->m_heap pointers are converted
+  //    to zero based offsets from the start of the buffer we're
   //    marshalling in to
   if (m_alt->m_request_hdr.valid()) {
     tmp = m_alt->m_request_hdr.m_heap->marshal(buf, len - used);
@@ -1763,7 +1763,7 @@ HTTPInfo::unmarshal(char *buf, int len, 
   return alt->m_unmarshal_len;
 }
 
-// bool HTTPInfo::check_marshalled(char* buf, int len) 
+// bool HTTPInfo::check_marshalled(char* buf, int len)
 //  Checks a marhshalled HTTPInfo buffer to make
 //    sure it's sane.  Returns true if sane, false otherwise
 //

Modified: trafficserver/traffic/trunk/proxy/hdrs/HTTP.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HTTP.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HTTP.h (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HTTP.h Thu May 13 07:09:39 2010
@@ -489,7 +489,7 @@ HTTPStatus http_parse_status(const char 
 ink32 http_parse_version(const char *start, const char *end);
 
 
-/*    
+/*
 HTTPValAccept*         http_parse_accept (const char *buf, Arena *arena);
 HTTPValAcceptCharset*  http_parse_accept_charset (const char *buf, Arena *arena);
 HTTPValAcceptEncoding* http_parse_accept_encoding (const char *buf, Arena *arena);

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "inktomi++.h"
@@ -102,7 +102,7 @@ HdrHeap::init()
 
   // We need to clear m_ptr directly since it's garbage and
   //  using the operator functions will to free() what ever
-  //  garbage it is pointing to 
+  //  garbage it is pointing to
   m_read_write_heap.m_ptr = NULL;
 
   m_ronly_heap[0].m_heap_start = NULL;
@@ -344,7 +344,7 @@ HdrHeap::expand_str(const char *old_str,
 //
 //  Allocates a new string and copies the old data.
 //  Returns the new string pointer.
-// 
+//
 char *
 HdrHeap::duplicate_str(const char *str, int nbytes)
 {
@@ -359,7 +359,7 @@ HdrHeap::duplicate_str(const char *str, 
 //  Returns 0 on success and non-zero failure
 //   Failure means all the read only heap slots
 //   were full
-// 
+//
 int
 HdrHeap::demote_rw_str_heap()
 {
@@ -373,7 +373,7 @@ HdrHeap::demote_rw_str_heap()
       m_ronly_heap[i].m_heap_start = (char *) m_read_write_heap.m_ptr;
       m_ronly_heap[i].m_heap_len = m_read_write_heap->m_heap_size - m_read_write_heap->m_free_size;
 
-//          Debug("hdrs", "Demoted rw heap of %d size", m_read_write_heap->m_heap_size); 
+//          Debug("hdrs", "Demoted rw heap of %d size", m_read_write_heap->m_heap_size);
       m_read_write_heap = NULL;
       return 0;
     }
@@ -644,7 +644,7 @@ HdrHeap::marshal(char *buf, int len)
   int str_heaps = 0;
 
   // Variables used later on.  Sunpro doesn't like
-  //   bypassing initializations with gotos 
+  //   bypassing initializations with gotos
   int used;
   int i;
 
@@ -753,7 +753,7 @@ HdrHeap::marshal(char *buf, int len)
     }
   }
 
-  // Patch the str heap len 
+  // Patch the str heap len
   marshal_hdr->m_ronly_heap[0].m_heap_len = str_size;
 
   // Take our translation tables and loop over the objects
@@ -875,7 +875,7 @@ HdrHeap::check_marshalled(inku32 buf_len
 //     type obj_type in the heap
 //
 //   Return value is the number of bytes unmarshalled or -1
-//     if error.  Caller is responsible for memory 
+//     if error.  Caller is responsible for memory
 //     management policy
 //
 int
@@ -1068,13 +1068,13 @@ HdrHeap::inherit_string_heaps(const HdrH
 
   if (free_slots < 0 || new_lost_space > (int)MAX_LOST_STR_SPACE) {
     // Not enough free slots.  We need to force a coalesce of
-    //  string heaps for both old heaps and the inherited from heaps.  
+    //  string heaps for both old heaps and the inherited from heaps.
     // Coalesce can't know the inherited str size so we pass it
     //  it in so that it can allocate a new read-write string heap
-    //  large enough (INKqa07513).  
-    // INVARIENT: inherit_str_heaps can only be called after 
+    //  large enough (INKqa07513).
+    // INVARIENT: inherit_str_heaps can only be called after
     //  all the objects the callee wants to inherit strings for
-    //  are put into the heap 
+    //  are put into the heap
     coalesce_str_heaps(inherit_str_size);
   } else {
 
@@ -1086,7 +1086,7 @@ HdrHeap::inherit_string_heaps(const HdrH
                                str_size, inherit_from->m_read_write_heap, &first_free);
       ink_release_assert(result != 0);
     }
-    // Copy over read only string heaps 
+    // Copy over read only string heaps
     for (int i = 0; i < HDR_BUF_RONLY_HEAPS; i++) {
       if (inherit_from->m_ronly_heap[i].m_heap_start) {
         result = attach_str_heap(inherit_from->m_ronly_heap[i].m_heap_start,

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.h (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrHeap.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _HDR_HEAP_H_
@@ -267,7 +267,7 @@ HdrHeap::free_string(const char *s, int 
 }
 
 
-// 
+//
 struct MarshalXlate
 {
   char *start;
@@ -373,7 +373,7 @@ if (ptr) { \
    } \
 }
 
-// Nasty macro to do verify all strings it 
+// Nasty macro to do verify all strings it
 //   in attached heaps
 #define CHECK_STR(str, len, _heaps, _num_heaps) \
 { \
@@ -391,7 +391,7 @@ if (ptr) { \
 
 // struct HdrHeapSDKHandle()
 //
-//   Handle to a HdrHeap.  
+//   Handle to a HdrHeap.
 //
 //   Intended to be subclassed and contain a
 //     object pointer that points into the heap

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrTSOnly.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrTSOnly.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrTSOnly.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrTSOnly.cc Thu May 13 07:09:39 2010
@@ -34,7 +34,7 @@
         we put the functions that only traffic_server uses since they
         need to know about IOBuffers.
 
-   
+
  ****************************************************************************/
 
 #include "inktomi++.h"
@@ -127,17 +127,17 @@ HTTPHdr::parse_resp(HTTPParser * parser,
   return state;
 }
 
-// void HdrHeap::set_ronly_str_heap_end(int slot) 
+// void HdrHeap::set_ronly_str_heap_end(int slot)
 //
 //    The end pointer is where the header parser stopped parsing
 //      so that we don't get extraneous space in the block
 //      that then has to get marshalled (INKqa07409)
 //
-//    NOTE: the shortening the block relies on the fact that 
+//    NOTE: the shortening the block relies on the fact that
 //      IOBuffers are write once.  It's therefore not possible
 //      that a previous call actually used more the block than
 //      the current call which would mean we can't shorten the block
-//     
+//
 void
 HdrHeap::set_ronly_str_heap_end(int slot, const char *end)
 {
@@ -156,7 +156,7 @@ HdrHeap::set_ronly_str_heap_end(int slot
 //      to expand an existing string heap entry if necessary
 //
 //    Because the block may contain data at the front of it that
-//      we don't want (and will end up getting marshalled) 
+//      we don't want (and will end up getting marshalled)
 //      use_start specificies where we start using the block (INKqa07409)
 //
 int
@@ -177,7 +177,7 @@ RETRY:
       m_ronly_heap[i].m_heap_start = (char *) use_start;
       m_ronly_heap[i].m_heap_len = (int) (b->end() - b->start());
       m_ronly_heap[i].m_ref_count_ptr = b->data;
-//          printf("Attaching block at %X for %d in slot %d\n", 
+//          printf("Attaching block at %X for %d in slot %d\n",
 //                 m_ronly_heap[i].m_heap_start,
 //                 m_ronly_heap[i].m_heap_len,
 //                 i);
@@ -186,7 +186,7 @@ RETRY:
       // This block is already on the heap so just extend
       //   it's range
       m_ronly_heap[i].m_heap_len = (int) (b->end() - b->buf());
-//          printf("Extending block at %X to %d in slot %d\n", 
+//          printf("Extending block at %X to %d in slot %d\n",
 //                 m_ronly_heap[i].m_heap_start,
 //                 m_ronly_heap[i].m_heap_len,
 //                 i);

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrTest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrTest.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrTest.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrTest.cc Thu May 13 07:09:39 2010
@@ -25,11 +25,11 @@
 
    HdrTest.cc
 
-   Description: 
+   Description:
        Unit test code for sanity checking the header system is functioning
          properly
 
-   
+
  ****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrTest.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrTest.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrTest.h (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrTest.h Thu May 13 07:09:39 2010
@@ -25,11 +25,11 @@
 
    HdrTest.cc
 
-   Description: 
+   Description:
        Unit test code for sanity checking the header system is functioning
          properly
 
-   
+
  ****************************************************************************/
 
 #ifndef _HdrTest_H_

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.cc Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
    Description: Convenience routines for dealing with hdrs and
                  values
 
-   
+
  ****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.h (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HdrUtils.h Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
    Description: Convenience routines for dealing with hdrs and
                  values
 
-   
+
  ****************************************************************************/
 
 #ifndef _HDR_UTILS_H_
@@ -72,13 +72,13 @@ private:
   //                 been skipped over
   // m_csv_len - the length of the current comma separated value
   //                 not including leading whitespace, trailing
-  //                 whitespace (unless quoted) or the terminating 
+  //                 whitespace (unless quoted) or the terminating
   //                 comma, or trailing quotes have been removed
   // m_csv_end - the terminating comma of the csv unit.  Either
   //                 the terminating comma or the final character
   //                 if this is the last csv in the string
   // m_cvs_index - the integer index of current csv starting
-  //                 at zero 
+  //                 at zero
   const char *m_csv_start;
   int m_csv_len;
   const char *m_csv_end;

Modified: trafficserver/traffic/trunk/proxy/hdrs/HttpCompat.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/HttpCompat.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/HttpCompat.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/HttpCompat.cc Thu May 13 07:09:39 2010
@@ -401,7 +401,7 @@ HttpCompat::parse_mime_type_with_len(con
 //         Vary header are present in the new request, and all of the stored
 //         selecting request-headers from the previous request match the
 //         corresponding headers in the new request.
-//      
+//
 //         The selecting request-headers from two requests are defined to
 //         match if and only if the selecting request-headers in the first
 //         request can be transformed to the selecting request-headers in

Modified: trafficserver/traffic/trunk/proxy/hdrs/MIME.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/MIME.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/MIME.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/MIME.cc Thu May 13 07:09:39 2010
@@ -1099,7 +1099,7 @@ mime_hdr_destroy(HdrHeap * heap, MIMEHdr
   mime_hdr_destroy_field_block_list(heap, mh->m_first_fblock.m_next);
 
   // INKqa11458: if we deallocate mh here and call INKMLocRelease
-  // again, the plugin fails in assert. We leave deallocating to 
+  // again, the plugin fails in assert. We leave deallocating to
   // the plugin using INKMLocRelease
 
   //heap->deallocate_obj(mh);
@@ -1115,7 +1115,7 @@ mime_hdr_copy_onto(MIMEHdrImpl * s_mh, H
   MIMEFieldBlockImpl *s_fblock, *d_fblock, *prev_d_fblock;
 
   // If there are chained field blocks beyond the first one, we're just going to
-  //   destroy them.  Ideally, we'd use them if the copied in header needed 
+  //   destroy them.  Ideally, we'd use them if the copied in header needed
   //   extra blocks.  It's too late in the Tomcat code cycle to implement
   //   reuse.
   if (d_mh->m_first_fblock.m_next) {
@@ -2841,8 +2841,8 @@ mime_parser_parse(MIMEParser * parser,
     field_name_first = line_c;
         /**
 	 * Fix for INKqa09141. The is_token function fails for '@' character.
-	 * Header names starting with '@' signs are valid headers. Hence we 
-	 * have to add one more check to see if the first parameter is '@' 
+	 * Header names starting with '@' signs are valid headers. Hence we
+	 * have to add one more check to see if the first parameter is '@'
 	 * character then, the header name is valid.
 	 **/
     if ((!ParseRules::is_token(*field_name_first)) && (*field_name_first != '@'))
@@ -3146,7 +3146,7 @@ mime_str_u16_set(HdrHeap * heap, const c
 {
   // INKqa08287 - keep track of free string space.
   //  INVARIENT: passed in result pointers must be to
-  //    either NULL or be valid ptr for a string already 
+  //    either NULL or be valid ptr for a string already
   //    the string heaps
   heap->free_string(*d_str, *d_len);
 
@@ -3616,17 +3616,17 @@ mime_parse_uint(const char *buf, const c
   table shows string, hash (24 bit values of 3 characters), and the
   resulting string index.
 
-        Fri 0x467269 5    Apr 0x417072 3 
-        Mon 0x4D6F6E 1    Aug 0x417567 7 
+        Fri 0x467269 5    Apr 0x417072 3
+        Mon 0x4D6F6E 1    Aug 0x417567 7
         Sat 0x536174 6    Dec 0x446563 11
-        Sun 0x53756E 0    Feb 0x466562 1 
-        Thu 0x546875 4    Jan 0x4A616E 0 
-        Tue 0x547565 2    Jul 0x4A756C 6 
-        Wed 0x576564 3    Jun 0x4A756E 5 
-                          Mar 0x4D6172 2 
-                          May 0x4D6179 4 
+        Sun 0x53756E 0    Feb 0x466562 1
+        Thu 0x546875 4    Jan 0x4A616E 0
+        Tue 0x547565 2    Jul 0x4A756C 6
+        Wed 0x576564 3    Jun 0x4A756E 5
+                          Mar 0x4D6172 2
+                          May 0x4D6179 4
                           Nov 0x4E6F76 10
-                          Oct 0x4F6374 9 
+                          Oct 0x4F6374 9
                           Sep 0x536570 8
 
   -------------------------------------------------------------------------*/

Modified: trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.cc Thu May 13 07:09:39 2010
@@ -25,9 +25,9 @@
 
   SDKAllocator.cc
 
-  Description: 
+  Description:
+
 
-  
  ****************************************************************************/
 
 #include "SDKAllocator.h"
@@ -107,7 +107,7 @@ SDKAllocator::free_str(char *str)
 
   SDKAllocHdr *obj = (SDKAllocHdr *) (str - SDKAllocHdrSize);
 
-  // Sanity check the object to make sure it's 
+  // Sanity check the object to make sure it's
   //   good and from the correct allocator
   if (obj->m_magic != SDK_ALLOC_MAGIC_STR) {
     return 0;
@@ -128,7 +128,7 @@ SDKAllocator::free_mfield(MIMEField * f)
 
   SDKAllocHdr *obj = (SDKAllocHdr *) (((char *) f) - SDKAllocHdrSize);
 
-  // Sanity check the object to make sure it's 
+  // Sanity check the object to make sure it's
   //   good and from the correct allocator
   if (obj->m_magic != SDK_ALLOC_MAGIC_STAND_ALONE_FIELD) {
     return 0;
@@ -150,7 +150,7 @@ SDKAllocator::free_mhandle(MIMEFieldSDKH
 
   SDKAllocHdr *obj = (SDKAllocHdr *) (((char *) h) - SDKAllocHdrSize);
 
-  // Sanity check the object to make sure it's 
+  // Sanity check the object to make sure it's
   //   good and from the correct allocator
   if (obj->m_magic != SDK_ALLOC_MAGIC_MIME_FIELD_HANDLE) {
     return 0;
@@ -186,7 +186,7 @@ SDKAllocator::free_all()
       break;
     case SDK_ALLOC_MAGIC_DEAD:
     default:
-      // Bad element 
+      // Bad element
       ink_assert(0);
     }
   }

Modified: trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.h (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/SDKAllocator.h Thu May 13 07:09:39 2010
@@ -25,9 +25,9 @@
 
    SDKAllocator.h
 
-   Description: 
+   Description:
+
 
-   
  ****************************************************************************/
 
 #ifndef _SDK_ALLOCATOR_H_

Modified: trafficserver/traffic/trunk/proxy/hdrs/URL.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/URL.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/URL.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/URL.cc Thu May 13 07:09:39 2010
@@ -1657,7 +1657,7 @@ memcpy_tolower(char *d, const char *s, i
 
 #define BUFSIZE 512
 
-// fast path for MMH, HTTP, no user/password/params/query, 
+// fast path for MMH, HTTP, no user/password/params/query,
 // no buffer overflow, no unescaping needed
 
 static inline void

Modified: trafficserver/traffic/trunk/proxy/hdrs/load_http_hdr.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/load_http_hdr.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/load_http_hdr.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/load_http_hdr.cc Thu May 13 07:09:39 2010
@@ -29,7 +29,7 @@
 
    Opens a file with a dbx dump of an http hdr and loads it
 
-   
+
  ****************************************************************************/
 
 /***************************************************************************
@@ -39,7 +39,7 @@
  *    are more complicated but much faster.  This program has been adapted
  *    read headers that have been unmarshalled from cache, in which
  *    case they are contiguious.  It's conversion is in a half baked
- *    state and is therefore not useful for must purposes.  
+ *    state and is therefore not useful for must purposes.
  ***************************************************************************/
 
 

Modified: trafficserver/traffic/trunk/proxy/hdrs/test_header.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/test_header.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/test_header.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/test_header.cc Thu May 13 07:09:39 2010
@@ -25,11 +25,11 @@
 
    test_header.cc
 
-   Description: 
+   Description:
        test code for sanity checking the header system is functioning
          properly
 
-   
+
  ****************************************************************************/
 
 #include <stdlib.h>

Modified: trafficserver/traffic/trunk/proxy/http2/Hash_Table.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/Hash_Table.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/Hash_Table.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/Hash_Table.cc Thu May 13 07:09:39 2010
@@ -28,9 +28,9 @@
 #include "HttpTransactCache.h"
 
 /* void HashTable::createHashTable()
-** 
+**
 ** Allocates memory for the Buckets and initializes the mutexes
-** 
+**
 */
 void
 HashTable::createHashTable()
@@ -45,9 +45,9 @@ HashTable::createHashTable()
 
 
 /* HashTable::~HashTable()
-** 
+**
 ** Deallocates memory for the Buckets and destroys the mutexes
-** 
+**
 */
 HashTable::~HashTable()
 {
@@ -60,10 +60,10 @@ HashTable::~HashTable()
 }
 
 /* unsigned int HashTable::KeyToIndex(register char * string)
-** 
+**
 ** Creates an index from <string> which is the url to be used in the hash table
 ** Used before lookup(), insert() and remove()
-** 
+**
 */
 unsigned int
 HashTable::KeyToIndex(register char *string)
@@ -85,10 +85,10 @@ HashTable::KeyToIndex(register char *str
 }
 
 /* RequestNode *HashTable::find_request(int index, char *url)
-** 
+**
 ** Searches Bucket[<index>] for <url> and returns the found RequestNode.
 ** If match is not found, returns NULL.
-** 
+**
 */
 RequestNode *
 HashTable::find_request(int index, char *url)
@@ -109,11 +109,11 @@ HashTable::find_request(int index, char 
 }
 
 /* HeaderAlternate *HashTable::lookup(int index, char *url, HTTPHdr *hdr)
-** 
+**
 ** Searches for <url> in Bucket[<index>] and then finds a match amoung the
 ** header alternates of that <url>. Returns the HeaderAlternate matched. If no
 ** match is found, returns NULL.
-** 
+**
 */
 HeaderAlternate *
 HashTable::lookup(int index, char *url, HTTPHdr * hdr)
@@ -140,14 +140,14 @@ HashTable::lookup(int index, char *url, 
 }
 
 /* int HashTable::insert(int index, char *url, HeaderAlternate *alternate)
-** 
+**
 ** Inserts <url> and <alternate> if <url> is not in the hash table,
 ** else, finds <url> in the hash table and adds <alternate> as a header
 ** alternate to that node. Waits for current readers of bucket to
 ** complete operation and then tries to acquire write lock on the bucket.
 ** If after HT_WRITER_MAX_RETRIES readers are still active,
 ** then returns 0, indicating that the alternate was not inserted to the hash table.
-** 
+**
 */
 HeaderAlternate *
 HashTable::insert(int index, HttpRequestData * url, bool revalidation)
@@ -212,11 +212,11 @@ HashTable::insert(int index, HttpRequest
 }
 
 /* int HashTable::remove(int index, char *url, HeaderAlternate *alternate)
-** 
+**
 ** Removes <url> and <alternate> if <alternate> is the only alternate of <url>,
 ** else, removes only <alternate> from that node. Waits for current readers of
-** bucket to complete operation and then tries to acquire write lock on the bucket 
-** 
+** bucket to complete operation and then tries to acquire write lock on the bucket
+**
 */
 int
 HashTable::remove(int index, char *url, HeaderAlternate * alternate)
@@ -303,11 +303,11 @@ HashTable::remove(int index, char *url, 
 }
 
 /* float HashTable::match_Headers( HTTPHdr * client_request, HTTPHdr * existing_request)
-** 
+**
 ** Api to match two HTTPHdr objects and return a 'quality of match'
-** The logic has been customized from the functionality used by cache to find match among 
+** The logic has been customized from the functionality used by cache to find match among
 ** alternates.
-** 
+**
 */
 float
 HashTable::match_Headers(HTTPHdr * client_request, HTTPHdr * existing_request)
@@ -367,10 +367,10 @@ HashTable::match_Headers(HTTPHdr * clien
 }
 
 /* HeaderAlternate *HashTable::update_revalidation_start_time(int index, char *url, HTTPHdr *hdr)
-** 
+**
 ** Updates the revalidation_start_time for a particular request url.Acquires the lock for
 ** updating the same
-** 
+**
 */
 void
 HashTable::update_revalidation_start_time(int index, HeaderAlternate * alternate)

Modified: trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.cc Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
 
   HttpBodyFactory.cc
 
-  
+
  ****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpBodyFactory.h Thu May 13 07:09:39 2010
@@ -49,7 +49,7 @@
     HttpBodyTemplate      The template loaded from the directory to be
                           instantiated with variables, producing a body.
 
-  
+
  ****************************************************************************/
 
 #ifndef _HttpBodyFactory_h_

Modified: trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "HttpCacheSM.h"
@@ -90,7 +90,7 @@ lookup_url(NULL), lookup_max_recursive(0
 //     machine. Keep in mind that the document may NOT
 //     match any of the request headers - it just matches
 //     the URL. In other words, the document that is being
-//     written to by another state machine may be an 
+//     written to by another state machine may be an
 //     alternate of the document the request wants.
 // - EVENT_INTERVAL
 //   - a previous open_read returned "failed_in_progress". we
@@ -139,7 +139,7 @@ HttpCacheSM::state_cache_open_read(int e
 
   case EVENT_INTERVAL:
     // Retry the cache open read if the number retries is less
-    // than or equal to the max number of open read retries, 
+    // than or equal to the max number of open read retries,
     // else treat as a cache miss.
     ink_assert(open_read_tries <= master_sm->t_state.http_config_param->max_cache_open_read_retries || write_locked);
     Debug("http_cache", "[%lld] [state_cache_open_read] cache open read failure %d. "
@@ -253,7 +253,7 @@ HttpCacheSM::open_read(URL * url, HTTPHd
   current_lookup_level++;
   open_read_cb = false;
   act_return = do_cache_open_read();
-  // the following logic is based on the assumption that the secnod 
+  // the following logic is based on the assumption that the secnod
   // lookup won't happen if the HttpSM hasn't been called back for the
   // first lookup
   if (current_lookup_level == lookup_max_recursive) {
@@ -297,7 +297,7 @@ HttpCacheSM::open_write(URL * url,
   this->read_request_hdr = request;
 
   // Make sure we are not stuck in a loop where the write
-  //  fails but the retry read succeeds causing to issue 
+  //  fails but the retry read succeeds causing to issue
   //  a new write (could happen on a very busy document
   //  that must be revalidated every time)
   // Changed by YTS Team, yamsat Plugin

Modified: trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpCacheSM.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _HTTP_CACHE_SM_H_

Modified: trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "ink_config.h"
@@ -204,7 +204,7 @@ HttpClientSession::new_connection(NetVCo
   HTTP_INCREMENT_DYN_STAT(http_current_client_connections_stat);
   conn_decrease = true;
   HTTP_INCREMENT_DYN_STAT(http_total_client_connections_stat);
-  /* inbound requests stat should be incremented here, not after the 
+  /* inbound requests stat should be incremented here, not after the
    * header has been read */
   HTTP_INCREMENT_DYN_STAT(http_total_incoming_connections_stat);
   // Record api hook set state
@@ -289,8 +289,8 @@ HttpClientSession::do_io_close(int alerr
     ka_vio = client_vc->do_io_read(this, INT_MAX, read_buffer);
     ink_assert(slave_ka_vio != ka_vio);
 
-    // [bug 2610799] Drain any data read.  
-    // If the buffer is full and the client writes again, we will not receive a 
+    // [bug 2610799] Drain any data read.
+    // If the buffer is full and the client writes again, we will not receive a
     // READ_READY event.
     sm_reader->consume(sm_reader->read_avail());
 

Modified: trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _HTTP_CLIENT_SESSION_H_
@@ -146,7 +146,7 @@ private:
   APIHook *cur_hook;
   int cur_hooks;
 
-  // api_hooks must not be changed directly  
+  // api_hooks must not be changed directly
   //  Use ssn_hook_{ap,pre}pend so hooks_set is
   //  updated
   HttpAPIHooks api_hooks;
@@ -160,7 +160,7 @@ public:
   bool m_bAuthComplete;
   SecurityContext *secCtx;
 
-  // for DI. An active connection is one that a request has 
+  // for DI. An active connection is one that a request has
   // been successfully parsed (PARSE_DONE) and it remains to
   // be active until the transaction goes through or the client
   // aborts.

Modified: trafficserver/traffic/trunk/proxy/http2/HttpConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpConfig.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpConfig.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpConfig.cc Thu May 13 07:09:39 2010
@@ -1540,7 +1540,7 @@ HttpConfig::reconfigure()
 
   ///////////////////////////////////////////////////////////////////////////
   //  Added by YTS Team, yamsat                                                 //
-  //   Connection collapsing Configuration parameters                      //            
+  //   Connection collapsing Configuration parameters                      //
   // 1. hashtable_enabled: if set to 1, requests will first search the     //
   //    hashtable to see if another similar request is already being served//
   // 2. rww_wait_time: read-while-write wait time: While read while write  //
@@ -1577,7 +1577,7 @@ HttpConfig::reconfigure()
 
 #undef INT_TO_BOOL
 
-// Connection collapsing debug statements 
+// Connection collapsing debug statements
   Debug("http_init", "proxy.config.connection_collapsing.hashtable_enabled = %d", params->hashtable_enabled);
   Debug("http_init", "proxy.config.connection_collapsing.rww_wait_time = %d", params->rww_wait_time);
   Debug("http_init", "proxy.config.connection_collapsing.revalidate_window_period = %d",
@@ -1616,7 +1616,7 @@ HttpConfig::release(HttpConfigParams * p
   configProcessor.release(m_id, params);
 }
 
-/* 
+/*
   Static Accept-Encoding/User-Agent filtering table
   The format of this table is compatible with ae_ua.config file
   */
@@ -1929,7 +1929,7 @@ HttpConfig::parse_url_expansions(char *u
   // First count the number of URL expansions in the string
   char *start = url_expansions_str, *end;
   while (1) {
-    // Skip whitespace 
+    // Skip whitespace
     while (isspace(*start))
       start++;
     if (*start == '\0')
@@ -1937,7 +1937,7 @@ HttpConfig::parse_url_expansions(char *u
     count++;
     end = start + 1;
 
-    // Find end of expansion 
+    // Find end of expansion
     while (!isspace(*end) && *end != '\0')
       end++;
     start = end;
@@ -1948,7 +1948,7 @@ HttpConfig::parse_url_expansions(char *u
     expansions = (char **) xmalloc(count * sizeof(char *));
     start = url_expansions_str;
     for (i = 0; i < count; i++) {
-      // Skip whitespace 
+      // Skip whitespace
       while (isspace(*start))
         start++;
       expansions[i] = start;

Modified: trafficserver/traffic/trunk/proxy/http2/HttpConfig.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpConfig.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpConfig.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpConfig.h Thu May 13 07:09:39 2010
@@ -22,14 +22,14 @@
  */
 
 /*************************** -*- Mod: C++ -*- ******************************
- 
+
   HttpConfig.h
    Created On      : Tue Oct 22 20:19:04 1996
- 
+
    Description:
    Http Configurations
- 
-   
+
+
  ****************************************************************************/
 #ifndef _HttpConfig_h_
 #define _HttpConfig_h_
@@ -720,7 +720,7 @@ public:
   MgmtInt revalidate_window_period;
   MgmtInt srv_enabled;          /* added by: ebalsa */
 
-  //############################################################################## 
+  //##############################################################################
 //#
   //# Redirection
   //#

Modified: trafficserver/traffic/trunk/proxy/http2/HttpConnectionCount.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpConnectionCount.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpConnectionCount.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpConnectionCount.h Thu May 13 07:09:39 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-// 
+//
 
 #ifndef _HTTP_CONNECTION_COUNT_H_
 

Modified: trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "HttpNcaClient.h"

Modified: trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpNcaClient.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _HTTP_CLIENT_NCA_H_

Modified: trafficserver/traffic/trunk/proxy/http2/HttpPages.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpPages.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpPages.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpPages.cc Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
    Description:
        Data structurs and stat page generators for http info
 
-   
+
  ****************************************************************************/
 #ifndef INK_NO_STAT_PAGES
 #include "HttpPages.h"
@@ -222,7 +222,7 @@ HttpPagesHandler::dump_history(HttpSM * 
   int size;
 
   // Figure out how big the history is and look
-  //  for wrap around 
+  //  for wrap around
   if (sm->history_pos > HISTORY_SIZE) {
     size = HISTORY_SIZE;
   } else {

Modified: trafficserver/traffic/trunk/proxy/http2/HttpPages.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpPages.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpPages.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpPages.h Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
    Description:
        Data structurs and stat page generators for http info
 
-   
+
  ****************************************************************************/
 
 #ifndef _HTTP_PAGES_H_

Modified: trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc Thu May 13 07:09:39 2010
@@ -191,7 +191,7 @@ init_HttpProxyServer(void)
 
 #ifndef INK_NO_API
   // Used to give plugins the ability to create http requests
-  //   The equivalent of the connecting to localhost on the  proxy 
+  //   The equivalent of the connecting to localhost on the  proxy
   //   port but without going through the operating system
   //
   if (plugin_http_accept == NULL) {

Modified: trafficserver/traffic/trunk/proxy/http2/HttpSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpSM.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpSM.cc Thu May 13 07:09:39 2010
@@ -1702,12 +1702,12 @@ HttpSM::state_http_server_open(int event
   switch (event) {
   case NET_EVENT_OPEN:
     session = THREAD_ALLOC_INIT(httpServerSessionAllocator, mutex->thread_holding);
-    // If origin_max_connections or origin_min_keep_alive_connections is 
+    // If origin_max_connections or origin_min_keep_alive_connections is
     // set then we are metering the max and or min number
     // of connections per host.  Set enable_origin_connection_limiting
     // to true in the server session so it will increment and decrement
     // the connection count.
-    if (t_state.http_config_param->origin_max_connections > 0 || 
+    if (t_state.http_config_param->origin_max_connections > 0 ||
         t_state.http_config_param->origin_min_keep_alive_connections > 0) {
       Debug("http_ss", "[%lld] max number of connections: %u",
             sm_id, t_state.http_config_param->origin_max_connections);
@@ -7378,16 +7378,16 @@ int HttpSM::get_http_schedule(int event,
       ink_debug_assert(pending_action == NULL);
       pending_action = mutex->thread_holding->schedule_in(this, HRTIME_MSECONDS(10));
       return 0;
-    }    
+    }
   } else {
     plugin_lock = false;
-  }    
+  }
 
   //handle Mutex;
   schedule_cont->handleEvent ( event, this);
   if (plugin_lock) {
     Mutex_unlock(plugin_mutex, mutex->thread_holding);
-  }    
+  }
 
   return 0;
 }

Modified: trafficserver/traffic/trunk/proxy/http2/HttpSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpSM.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpSM.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpSM.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _HTTP_SM_H_

Modified: trafficserver/traffic/trunk/proxy/http2/HttpServerSession.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpServerSession.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpServerSession.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpServerSession.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "ink_config.h"
@@ -50,7 +50,7 @@ VConnection(NULL),
 server_ip(0), server_port(0), hostname_hash(),
 host_hash_computed(false), con_id(0), transact_count(0),
 state(HSS_INIT), to_parent_proxy(false), server_trans_stat(0),
-private_session(false), 
+private_session(false),
 enable_origin_connection_limiting(false),
 connection_count(NULL),
 read_buffer(NULL), server_vc(NULL), magic(HTTP_SS_MAGIC_DEAD), buf_reader(NULL)

Modified: trafficserver/traffic/trunk/proxy/http2/HttpServerSession.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpServerSession.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpServerSession.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpServerSession.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _HTTP_SERVER_SESSION_H_
@@ -39,7 +39,7 @@
 * the net code in read_from_net when data is actually written into
 * the buffer. By allocating memory only when it is required we can
 * reduce the memory consumed by TS process.
-* 
+*
 * IMPORTANT NOTE: enable/disable LAZY_BUF_ALLOC in HttpSM.h as well.
 */
 #define LAZY_BUF_ALLOC
@@ -115,7 +115,7 @@ public:
   // Used to determine whether the session is for parent proxy
   // it is session to orgin server
   // We need to determine whether a closed connection was to
-  // close parent proxy to update the 
+  // close parent proxy to update the
   // proxy.process.http.current_parent_proxy_connections
   bool to_parent_proxy;
 

Modified: trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "HttpSessionManager.h"
@@ -81,9 +81,9 @@ SessionBucket::session_handler(int event
   while (s != NULL) {
     if (s->get_netvc() == net_vc) {
 
-      // if there was a timeout of some kind on a keep alive connection, and 
+      // if there was a timeout of some kind on a keep alive connection, and
       // keeping the connection alive will not keep us above the # of max connections
-      // to the origin and we are below the min number of keep alive connections to this 
+      // to the origin and we are below the min number of keep alive connections to this
       // origin, then reset the timeouts on our end and do not close the connection
       if( (event == VC_EVENT_INACTIVITY_TIMEOUT || event == VC_EVENT_ACTIVE_TIMEOUT) &&
            s->state == HSS_KA_SHARED &&
@@ -160,7 +160,7 @@ HttpSessionManager::purge_keepalives()
         sess->do_io_close();
       }
     } else {
-      // Fix me, should retry 
+      // Fix me, should retry
     }
   }
 }
@@ -174,13 +174,13 @@ HttpSessionManager::acquire_session(Cont
   // We compute the mmh for matching the hostname as the last
   //  check for a match between the session the HttpSM is
   //  looking for and the sessions we have.  The reason it's
-  //  the last check is to save the cycles of needless 
-  //  computing extra mmhs.  We have to use the hostname 
-  //  as part of the match because some stupid servers can't 
+  //  the last check is to save the cycles of needless
+  //  computing extra mmhs.  We have to use the hostname
+  //  as part of the match because some stupid servers can't
   //  handle getting request for different virtual hosts over
-  //  the same keep-alive session (INKqa05429).  
-  // Also, note the ip is required as well to maintain client 
-  //  to server affinity so that we don't break certain types 
+  //  the same keep-alive session (INKqa05429).
+  // Also, note the ip is required as well to maintain client
+  //  to server affinity so that we don't break certain types
   //  of authentication.
   bool hash_computed = false;
   INK_MD5 hostname_hash;
@@ -243,9 +243,9 @@ HttpSessionManager::acquire_session(Cont
         if (hostname_hash == b->hostname_hash) {
 
           // We found a match.  Since the lock for the 1st level
-          //  bucket is the same one that we use for the read 
-          //  on the keep alive connection, we are safe since 
-          //  we can not get called back from the netProcessor 
+          //  bucket is the same one that we use for the read
+          //  on the keep alive connection, we are safe since
+          //  we can not get called back from the netProcessor
           //  here.  The SM will do a do_io when it gets the session,
           //  effectively canceling the keep-alive read
           bucket->lru_list.remove(b);

Modified: trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpSessionManager.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/