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

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched_no_qos.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched_no_qos.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched_no_qos.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched_no_qos.c Thu May 13 17:43:56 2010
@@ -193,7 +193,7 @@ inkudp_add_split_rule(queue_t * incoming
   redirect_passthrough = 1;
 
 
-  /* 
+  /*
    * bail out if this is an error or we have successfully added to
    * the appropriate split list; otherwise, try to add the thing.
    */
@@ -863,7 +863,7 @@ inkudp_find_pkt_to_send(struct ink_redir
   min_list = NULL;
   cur_list = G_redirect_incoming_list;
 
-  /* 
+  /*
    *  Initialize the min. element.  Order here is critical: in the next loop,
    * we are deref'ing min_list->m_recvPktQ.m_head; better make sure that the
    * m_head pointer is not NULL.

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/solaris.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/solaris.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/solaris.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/solaris.c Thu May 13 17:43:56 2010
@@ -100,7 +100,7 @@ memcpy(void *s1, void *s2, size_t n)
 /*
  * Notes:
  *       - Do I need to screw with the packet size, watermarks?
- *       - where can I get a unique id number 
+ *       - where can I get a unique id number
  */
 static struct module_info minfo = {
   0xbabf,                       /* mi_idnum   module ID number */
@@ -476,14 +476,14 @@ getBlockPtr(uint16_t id)
 }
 
 /*
- * Initialize a STREAMS UDP request message body 
+ * Initialize a STREAMS UDP request message body
  */
 inline void
 inkudp_udppkt_init(struct udppkt *p)
 {
   /* the magic numbers get hardcoded
    *
-   * Fixme: are these platform-dependant?  
+   * Fixme: are these platform-dependant?
    * How will they work on sparc?
    */
 #ifdef i386

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/fiotest.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/fiotest.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/fiotest.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/fiotest.c Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /*
  *
  * libfastio tests
- * 
- * 
+ *
+ *
  *
  *
  */
@@ -109,7 +109,7 @@ main()
 
 
   /*record a sendto */
-  /* err = sendto(fd, blocks[0]->ptr, 1466, 0, (struct sockaddr *) &sa, 
+  /* err = sendto(fd, blocks[0]->ptr, 1466, 0, (struct sockaddr *) &sa,
      sizeof(struct sockaddr_in)); */
 
   if (err < 0)

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.c Thu May 13 17:43:56 2010
@@ -23,8 +23,8 @@
 
 /*
  *
- * FastIO Userland Library 
- * 
+ * FastIO Userland Library
+ *
  *
  *
  *
@@ -187,7 +187,7 @@ fastIO_fio_init(struct fastIO_state *fio
 
 
 /*
- * Initialize the fastIO system for a file descriptor 
+ * Initialize the fastIO system for a file descriptor
  */
 struct fastIO_state *
 fastIO_init(int blockcount)
@@ -229,7 +229,7 @@ fastIO_init(int blockcount)
 
 
   /* you don't need to call mutex_init() on an intraprocess mutex.
-   * just make sure it's zero'ed out 
+   * just make sure it's zero'ed out
    */
   bzero(&fio->mem_mutex, sizeof(mutex_t));
 
@@ -239,7 +239,7 @@ fastIO_init(int blockcount)
 
 
 /*
- * Create a fastIO session 
+ * Create a fastIO session
  */
 struct fastIO_session *
 fastIO_udpsession_create(struct fastIO_state *fio, int fd)
@@ -280,7 +280,7 @@ fastIO_udpsession_create(struct fastIO_s
 
 
 /*
- * Create a fastIO virtual session 
+ * Create a fastIO virtual session
  */
 struct fastIO_session *
 fastIO_vsession_create(struct fastIO_state *fio)
@@ -313,8 +313,8 @@ fastIO_vsession_create(struct fastIO_sta
 }
 
 
-/* 
- * Delete a fastIO Session 
+/*
+ * Delete a fastIO Session
  */
 void
 fastIO_session_destroy(struct fastIO_session *sessioncookie)
@@ -407,7 +407,7 @@ fastIO_sendto(struct fastIO_session *fio
   switch (fio->type) {
 
   case FASTIO_SESSION_UDP:
-/*	printf("sending on destination queue 0x%x.\n", 
+/*	printf("sending on destination queue 0x%x.\n",
 		fio->udp_queue);*/
 
     req->destQ = fio->udp_queue;
@@ -650,7 +650,7 @@ fastIO_fini(struct fastIO_state *cookie)
   printf("fastIO_fini:\n");
 #endif
 
-  /* This doesn't seem to result in a devunmap handler inside inkfio, 
+  /* This doesn't seem to result in a devunmap handler inside inkfio,
    * so I clean up memory in DDI close()
    */
   munmap((char *) cookie->buffer, cookie->size);

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/libfastio.h Thu May 13 17:43:56 2010
@@ -23,8 +23,8 @@
 
 /*
  *
- * FastIO Userland Library 
- * 
+ * FastIO Userland Library
+ *
  *
  *
  *
@@ -115,18 +115,18 @@ typedef u_int32_t uint32_t;
   struct fastIO_state *fastIO_init(int blockcount);
 
 /*
- * Create a fastIO UDP session 
+ * Create a fastIO UDP session
  */
   struct fastIO_session *fastIO_udpsession_create(struct fastIO_state *cookie, int fd);
 
 /*
- * Create a fastIO virtual session 
+ * Create a fastIO virtual session
  */
   struct fastIO_session *fastIO_vsession_create(struct fastIO_state *cookie);
 
 
-/* 
- * Delete a fastIO Session 
+/*
+ * Delete a fastIO Session
  */
   void fastIO_session_destroy(struct fastIO_session *sessioncookie);
 
@@ -199,7 +199,7 @@ typedef u_int32_t uint32_t;
 
 
 /*
- * Create a fastIO UDP session 
+ * Create a fastIO UDP session
  */
   static struct fastIO_session *fastIO_udpsession_create(struct fastIO_state *cookie, int fd)
   {
@@ -207,7 +207,7 @@ typedef u_int32_t uint32_t;
   }
 
 /*
- * Create a fastIO virtual session 
+ * Create a fastIO virtual session
  */
   static struct fastIO_session *fastIO_vsession_create(struct fastIO_state *cookie)
   {
@@ -215,8 +215,8 @@ typedef u_int32_t uint32_t;
   }
 
 
-/* 
- * Delete a fastIO Session 
+/*
+ * Delete a fastIO Session
  */
   static void fastIO_session_destroy(struct fastIO_session *sessioncookie)
   {

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/metafiotest.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/metafiotest.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/metafiotest.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/libfastIO/metafiotest.c Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /*
  *
  * libfastio tests
- * 
- * 
+ *
+ *
  *
  *
  */
@@ -121,7 +121,7 @@ main()
 
 
     /*record a sendto */
-    /* err = sendto(fd, blocks[0]->ptr, 1466, 0, (struct sockaddr *) &sa, 
+    /* err = sendto(fd, blocks[0]->ptr, 1466, 0, (struct sockaddr *) &sa,
        sizeof(struct sockaddr_in)); */
 
     if (err < 0)

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.c Thu May 13 17:43:56 2010
@@ -41,7 +41,7 @@
 
 /*
  *  Build a fastIO request
- *  Allocates required packet and data blocks, 
+ *  Allocates required packet and data blocks,
  *  returns the ID of the request block
  *
  *

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/requtil.h Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /*
  *
  * Benchmark for fastIO and userIO
- * 
- * 
+ *
+ *
  *
  *
  */
@@ -88,7 +88,7 @@ extern struct bmark_options bmark;
 
 /*
  *  Build a fastIO request
- *  Allocates required packet and data blocks, 
+ *  Allocates required packet and data blocks,
  *  returns the ID of the request block
  */
 uint32_t bmark_build_request();

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/udpbmark.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/udpbmark.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/udpbmark.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/tools/advbmark/udpbmark.c Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /*
  *
  * Solaris UDP FastIO bench
- * 
- * 
+ *
+ *
  *
  *
  */
@@ -93,7 +93,7 @@ intsig(int nuttin)
 }
 
 /*
- * Signal handler for SIGUSR1.  
+ * Signal handler for SIGUSR1.
  * Required for memory management
  */
 void

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/HostDB.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/HostDB.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/HostDB.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/HostDB.cc Thu May 13 17:43:56 2010
@@ -322,7 +322,7 @@ HostDBCache::start(int flags)
   struct stat s;
   int err;
   if ((err = stat(storage_path, &s)) < 0) {
-    ink_strncpy(storage_path,system_local_state_dir,sizeof(storage_path)); 
+    ink_strncpy(storage_path,system_local_state_dir,sizeof(storage_path));
     if ((err = stat(storage_path, &s)) < 0) {
       Warning("Unable to stat() directory '%s': %d %d, %s", storage_path, err, errno, strerror(errno));
       Warning(" Please set 'proxy.config.hostdb.storage_path' or 'proxy.config.local_state_dir' ");
@@ -396,10 +396,10 @@ HostDBProcessor::start(int)
   /* mgmt stuff
      ink64 ii = pmgmt->record_data->readConfigInteger(
      "proxy.config.hostdb.strict_round_robin", &found);
-     if (found) { 
+     if (found) {
      hostdb_strict_round_robin = (ink32) ii;
      pmgmt->record_data->registerConfigUpdateFunc(
-     "proxy.config.hostdb.strict_round_robin",config_int_cb, 
+     "proxy.config.hostdb.strict_round_robin",config_int_cb,
      (void*)&hostdb_strict_round_robin);
      }
    */
@@ -699,10 +699,10 @@ HostDBProcessor::getby(Continuation * co
     // INK_MD5 the ip, pad on both sizes with 0's
     // so that it does not intersect the string space
     //
-    // suvasv: Changed from this 
+    // suvasv: Changed from this
     //    inku64 dummy = ip << 16;
     //  to inku64 dummy = ip*64*1024 for bug INKqa10029.
-    //  Problem was that ip << 16 would not work for architectures with 
+    //  Problem was that ip << 16 would not work for architectures with
     //  a different byte order. This takes cares of all byte orders.
     inku64 dummy = ((inku64) ip) * 64 * 1024;
     md5.encodeBuffer((char *) &dummy, 8);
@@ -997,10 +997,10 @@ HostDBProcessor::setby(char *hostname, i
     // so that it does not intersect the string space
     //
 
-    // suvasv: Changed from this 
+    // suvasv: Changed from this
     //    inku64 dummy = ip << 16;
     //  to inku64 dummy = ip*64*1024 for bug INKqa10029.
-    //  Problem was that ip << 16 would not work for architectures with 
+    //  Problem was that ip << 16 would not work for architectures with
     //  a different byte order. This takes cares of all byte orders.
     inku64 dummy = ((inku64) ip) * 64 * 1024;
     md5.encodeBuffer((char *) &dummy, 8);
@@ -1907,7 +1907,7 @@ HostDBContinuation::clusterEvent(int eve
 
       if (!action.cancelled) {
         if (reply_to_cont(action.continuation, r)) {
-          // if we are not the owner and neither was the sender, 
+          // if we are not the owner and neither was the sender,
           // fill the owner
           //
           if (hostdb_migrate_on_demand) {
@@ -1982,7 +1982,7 @@ get_hostinfo_ClusterFunction(ClusterMach
   /* -----------------------------------------
      we make a big assumption here! we presume
      that all the machines in the cluster are
-     set to use the same configuration for 
+     set to use the same configuration for
      DNS servers
      ----------------------------------------- */
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDB.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDB.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDB.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDB.h Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
 
   I_HostDB.h
 
-  
+
  ****************************************************************************/
 
 #ifndef _I_HostDB_h_

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDBProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDBProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDBProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/I_HostDBProcessor.h Thu May 13 17:43:56 2010
@@ -368,8 +368,8 @@ struct HostDBRoundRobin
   static int size(int nn, bool using_srv)
   {
     if (using_srv) {
-      /*     sizeof this struct       
-         minus    
+      /*     sizeof this struct
+         minus
          unused round-robin entries [info]
          minus
          unused srv host data [rr_srv_hosts]

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/Inline.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/Inline.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/Inline.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/Inline.cc Thu May 13 17:43:56 2010
@@ -28,6 +28,6 @@
 #define TS_INLINE
 #define INLINE_CC
 
-#include "P_HostDB.h" 
+#include "P_HostDB.h"
 
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/MultiCache.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/MultiCache.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/MultiCache.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/MultiCache.cc Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   MultiCache.cc
 
-  
+
  ****************************************************************************/
 
 #include "inktomi++.h"
@@ -437,7 +437,7 @@ MultiCacheBase::mmap_data(bool private_f
     // lots of useless stuff
 #if (HOST_OS == darwin)
     cur = (char *) mmap(0, totalsize, PROT_READ, MAP_SHARED_MAP_NORESERVE | MAP_ANON, -1, 0);
-#else 
+#else
     cur = (char *) mmap(0, totalsize, PROT_READ, MAP_SHARED_MAP_NORESERVE, fd, 0);
 #endif
     if (cur == NULL || cur == (caddr_t) MAP_FAILED) {
@@ -1034,7 +1034,7 @@ MultiCacheBase::sync_all()
 }
 
 //
-// Syncs MulitCache 
+// Syncs MulitCache
 //
 struct MultiCacheSync;
 typedef int (MultiCacheSync::*MCacheSyncHandler) (int, void *);

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDB.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDB.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDB.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDB.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   P_HostDB.h
 
-  
+
  ****************************************************************************/
 
 #ifndef _P_HostDB_h_

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDBProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDBProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDBProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_HostDBProcessor.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   P_HostDBProcessor.h
 
-  
+
  ****************************************************************************/
 
 #ifndef _P_HostDBProcessor_h_
@@ -231,8 +231,8 @@ HostDBRoundRobin::select_best_http(unsig
       } else {
         // Entry is marked down.  Make sure some nasty clock skew
         //  did not occur.  Use the retry time to set an upper bound
-        //  as to how far in the future we should tolerate bogus last 
-        //  failure times.  This sets the upper bound that we would ever 
+        //  as to how far in the future we should tolerate bogus last
+        //  failure times.  This sets the upper bound that we would ever
         //  consider a server down to 2*down_server_timeout
         if (now + fail_window < (ink32) (info[i].app.http_data.last_failure)) {
 #ifdef DEBUG

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_MultiCache.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_MultiCache.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_MultiCache.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/P_MultiCache.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   MultiCache.h
 
-  
+
  ****************************************************************************/
 
 
@@ -181,7 +181,7 @@ struct UnsunkPtrRegistry
 #define PtrMutex Ptr<ProxyMutex>
 
 //
-// used by windows only - to keep track 
+// used by windows only - to keep track
 // of mapping handles
 //
 struct Unmaper

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/include/Machine.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/include/Machine.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/include/Machine.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/include/Machine.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   Machine.h
 
-  
+
  ****************************************************************************/
 
 
@@ -38,7 +38,7 @@
 #define _Machine_h
 
 //
-// Timeout the Machine * this amount of time after they 
+// Timeout the Machine * this amount of time after they
 // fall out of the current configuration that are deleted.
 //
 #define MACHINE_TIMEOUT            (HRTIME_DAY*2)
@@ -50,8 +50,8 @@
 //  For example, a Machine * is returned by the hash and used to do
 //  a remote invoke.  For the pointer to remain valid (or be recognized as
 //  invalid) he resource should not be raclaimed for NO_RACE_DELAY.
-//  
-//  Long running operations should use more sophisticated synchronization. 
+//
+//  Long running operations should use more sophisticated synchronization.
 //
 #define NO_RACE_DELAY                  HRTIME_HOUR      // a long long time
 
@@ -77,7 +77,7 @@ struct Machine:Server
     Machine(char *hostname = NULL, unsigned int ip = 0, int acluster_port = 0);
    ~Machine();
 
-  // Cluster message protocol version 
+  // Cluster message protocol version
   inku16 msg_proto_major;
   inku16 msg_proto_minor;
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/hostdb/test_I_HostDB.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/hostdb/test_I_HostDB.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/hostdb/test_I_HostDB.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/hostdb/test_I_HostDB.cc Thu May 13 17:43:56 2010
@@ -70,7 +70,7 @@ reconfigure_diags()
   diags->deactivate_all(DiagsTagType_Action);
 
   //////////////////////////////////////////////////////////////////////
-  //                     add new tag tables 
+  //                     add new tag tables
   //////////////////////////////////////////////////////////////////////
 
   if (diags->base_debug_tags)

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/I_NetConfig.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/I_NetConfig.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/I_NetConfig.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/I_NetConfig.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 #define __I_NETCONFIG_H__
 
 /*
- * Temporary file specifying all configurable parameters for the 
+ * Temporary file specifying all configurable parameters for the
  * net sub system.
  * For the default values look at NetConfig.cc
  */

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/I_NetProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/I_NetProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/I_NetProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/I_NetProcessor.h Thu May 13 17:43:56 2010
@@ -254,7 +254,7 @@ private:
 extern inkcoreapi NetProcessor & netProcessor;
 
 #ifdef HAVE_LIBSSL
-/** 
+/**
   Global netProcessor singleton object for making ssl enabled net
   calls. As far as the SM is concerned this behaves excatly like
   netProcessor. The only difference is that the connections are

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/I_NetVConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/I_NetVConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/I_NetVConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/I_NetVConnection.h Thu May 13 17:43:56 2010
@@ -172,7 +172,7 @@ public:
         <td>signified that error occured during write.</td>
       </tr>
     </table>
-   
+
     The vio returned during callbacks is the same as the one returned
     by do_io_write(). The vio can be changed only during call backs
     from the vconnection. The vconnection deallocates the reader
@@ -205,7 +205,7 @@ public:
   */
   virtual void do_io_close(int lerrno = -1) = 0;
 
-  /** 
+  /**
     Shuts down read side, write side, or both. do_io_shutdown() can
     be used to terminate one or both sides of the VConnection. The
     howto is one of IO_SHUTDOWN_READ, IO_SHUTDOWN_WRITE,
@@ -224,7 +224,7 @@ public:
   virtual void do_io_shutdown(ShutdownHowTo_t howto) = 0;
 
 
-  /** 
+  /**
     Sends out of band messages over the connection. This function
     is used to send out of band messages (is this still useful?).
     cont is called back with VC_EVENT_OOB_COMPLETE - on successful
@@ -261,7 +261,7 @@ public:
   // or the NetVConnection creation callback.               //
   ////////////////////////////////////////////////////////////
 
-  /** 
+  /**
     Sets time after which SM should be notified.
 
     Sets the amount of time (in nanoseconds) after which the state
@@ -299,7 +299,7 @@ public:
   */
   virtual void set_active_timeout(ink_hrtime timeout_in) = 0;
 
-  /** 
+  /**
     Sets time after which SM should be notified if the requested
     IO could not be performed. Sets the amount of time (in nanoseconds),
     if the NetVConnection is idle on both the read or write side,
@@ -313,14 +313,14 @@ public:
    */
   virtual void set_inactivity_timeout(ink_hrtime timeout_in) = 0;
 
-  /** 
+  /**
     Clears the active timeout. No active timeouts will be sent until
     set_active_timeout() is used to reset the active timeout.
 
   */
   virtual void cancel_active_timeout() = 0;
 
-  /** 
+  /**
     Clears the inactivity timeout. No inactivity timeouts will be
     sent until set_inactivity_timeout() is used to reset the
     inactivity timeout.

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPConnection.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   I_UDPConnection.h
   UDPConnection interface
-  
-  
+
+
  ****************************************************************************/
 
 #ifndef __I_UDPCONNECTION_H_
@@ -37,8 +37,8 @@
 class UDPPacket;
 /**
    UDP Connection endpoint
-   
-   You can schedule packet to be sent immediately or for the future, 
+
+   You can schedule packet to be sent immediately or for the future,
    and set up a persistent receive() operation.
  */
 
@@ -62,11 +62,11 @@ public:
   double get_allocatedBandwidth();
   /**
      <p>
-     <b>Callbacks:</b><br> 
+     <b>Callbacks:</b><br>
      cont->handleEvent(NET_EVENT_DATAGRAM_WRITE_ERROR, UDPPacket *) on error
      <br>
      no callback on success.
-     
+
      @return Action* send can't be cancelled via this Action
      @param c continuation to be called back
      @param p packet to be sent.
@@ -75,7 +75,7 @@ public:
 
   /**
      <p>
-     <b>Callbacks:</b><br> 
+     <b>Callbacks:</b><br>
      cont->handleEvent(NET_EVENT_DATAGRAM_ERROR, UDPConnection *) on error
      <br>
      cont->handleEvent(NET_EVENT_DATAGRAM_READ_READY, Queue&lt;UDPPacketInternal&gt; *) on incoming packets.

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPNet.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPNet.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPNet.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPNet.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   I_UDPNet.h
   This file provides UDP interface. To be included in I_Net.h
-  
-  
+
+
  ****************************************************************************/
 
 #ifndef __UDPNET_H_
@@ -53,14 +53,14 @@ public:
 
   /**
      create UDPConnection
-     
+
      Why was this implemented as an asynchronous call?  Just in case
      Windows requires it...
      <p>
-     <b>Callbacks:</b><br> 
+     <b>Callbacks:</b><br>
      cont->handleEvent( NET_EVENT_DATAGRAM_OPEN, UDPConnection *) is
      called for new socket.
-     
+
      @param c Continuation that is called back with newly created
      socket.
      @param my_port Local port to be bound (required)

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPPacket.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPPacket.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPPacket.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/I_UDPPacket.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   I_UDPPacket.h
   UDPPacket interface
-  
-  
+
+
  ****************************************************************************/
 
 #ifndef __I_UDPPACKET_H_
@@ -59,7 +59,7 @@ public:
   void setPktTSSeq(ink64 seqno);
   int getPktLength();
   /**
-     Add IOBufferBlock (chain) to end of packet.	
+     Add IOBufferBlock (chain) to end of packet.
      @param block block chain to add.
 
    */

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/Net.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/Net.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/Net.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/Net.cc Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
 
    Net.cc
 
-   
+
 ************************************************************************/
 
 #include "P_Net.h"

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/NetConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/NetConfig.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/NetConfig.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/NetConfig.cc Thu May 13 17:43:56 2010
@@ -31,7 +31,7 @@ int net_config_max_poll_delay = 0;
 int net_config_listen_backlog = 1024;
 
 
-// SSL config   
+// SSL config
 // # proxy.config.ssl.enabled should be:
 // #   0 - none
 // #   1 - SSL enabled

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-http-server.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-http-server.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-http-server.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-http-server.c Thu May 13 17:43:56 2010
@@ -103,8 +103,8 @@ struct NetTesterSM:public Continuation
     case VC_EVENT_ERROR:
     case VC_EVENT_INACTIVITY_TIMEOUT:
       vc->do_io_close();
-      // fixme 
-      // handle timeout events      
+      // fixme
+      // handle timeout events
       break;
     default:
       ink_release_assert(!"unknown event");

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-simple-proxy.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-simple-proxy.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-simple-proxy.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/NetTest-simple-proxy.c Thu May 13 17:43:56 2010
@@ -132,8 +132,8 @@ struct NetTesterSM:public Continuation
     case VC_EVENT_ERROR:
     case VC_EVENT_INACTIVITY_TIMEOUT:
       close_client_vc();
-      // fixme 
-      // handle timeout events      
+      // fixme
+      // handle timeout events
       break;
     default:
       ink_release_assert(!"unknown event");

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/NetVCTest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/NetVCTest.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/NetVCTest.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/NetVCTest.cc Thu May 13 17:43:56 2010
@@ -26,12 +26,12 @@
    NetVCTest.cc
 
    Description:
-       Unit test for infastructure for VConnections implementing the 
+       Unit test for infastructure for VConnections implementing the
          NetVConnection interface
 
-  
 
-  
+
+
  ****************************************************************************/
 
 #include "P_Net.h"

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/NetVConnection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/NetVConnection.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/NetVConnection.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/NetVConnection.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   This file implements an I/O Processor for network I/O.
 
-  
+
  ****************************************************************************/
 
 #include "P_Net.h"

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_Connection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_Connection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_Connection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_Connection.h Thu May 13 17:43:56 2010
@@ -28,23 +28,23 @@
   struct Connection
   struct Server
   struct ConnectionManager
- 
+
   struct ConnectionManager
   ========================
 
   struct ConnectionManager provides the interface for network or disk
   connections.  There is a global ConnectionManager in the system
-  (connectionManager).  
+  (connectionManager).
 
-  Connection * connect() 
-  Connection * accept() 
+  Connection * connect()
+  Connection * accept()
 
   The accept call is a blocking call while connect is non-blocking. They
   returns a new Connection instance which is an handle to the newly created
   connection. The connection `q instance can be used later for read/writes
   using an intance of IOProcessor class.
 
-   
+
   **************************************************************************/
 
 #ifndef __CONNECTION_H__

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_InkBulkIO.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_InkBulkIO.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_InkBulkIO.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_InkBulkIO.h Thu May 13 17:43:56 2010
@@ -30,7 +30,7 @@
 #include <netinet/udp.h>
 #endif
 
-/* 
+/*
  * We are following the convention of the ioctl cmd constants:
  *  - the first 8 bits contain the character representing the device
  *  - bits 8-15 refer to the ioctl
@@ -116,7 +116,7 @@ struct InkBulkIOSendtoRequest
  *      describes if there is a per-receiver specific header that has to be
  *      tacked on before each data-payload.
  *   - a list of InkBulkIOPkt that describes the payload being split;
- *   - a list of tuples <receiver info, {optional InkBulkIOPkt}> 
+ *   - a list of tuples <receiver info, {optional InkBulkIOPkt}>
  *      terminate list by 0xffffffff
  */
 
@@ -152,7 +152,7 @@ struct InkBulkIORequest
 #define MAX(x, y) (x > y ? x : y)
 #endif
 
-/* 
+/*
  * Purposely, under specify the size; we need to leave space for the "terminating" packet.
  * Every block contains at least 1 request.
  */

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_Net.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_Net.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_Net.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_Net.h Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /****************************************************************************
 
   Net Subsystem
-  
-  
+
+
 **************************************************************************/
 #ifndef __P_NET_H__
 #define __P_NET_H__
@@ -35,7 +35,7 @@
 #define TS_INLINE inline
 #endif
 
-// Net Stats 
+// Net Stats
 
 enum Net_Stats
 {

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_NetAccept.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_NetAccept.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_NetAccept.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_NetAccept.h Thu May 13 17:43:56 2010
@@ -25,16 +25,16 @@
 
   NetAccept.h
 
-  
+
    NetAccept is a generalized facility which allows
    Connections of different classes to be accepted either
    from a blockable thread or by adaptive polling.
-  
+
    It is used by the NetProcessor and the ClusterProcessor
    and should be considered PRIVATE to processor implementations.
 
 
-  
+
  ****************************************************************************/
 #ifndef __P_NETACCEPT_H__
 #define __P_NETACCEPT_H__

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_NetVCTest.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_NetVCTest.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_NetVCTest.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_NetVCTest.h Thu May 13 17:43:56 2010
@@ -26,12 +26,12 @@
   P_NetVCTest.h
 
    Description:
-       Unit test for infastructure for VConnections implementing the 
+       Unit test for infastructure for VConnections implementing the
          NetVConnection interface
 
-  
 
-  
+
+
  ****************************************************************************/
 
 #ifndef _P_NET_VC_TEST_H_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetAccept.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetAccept.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetAccept.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetAccept.h Thu May 13 17:43:56 2010
@@ -25,16 +25,16 @@
 
   P_SSLNetAccept.h
 
-  
+
    NetAccept is a generalized facility which allows
    Connections of different classes to be accepted either
    from a blockable thread or by adaptive polling.
-  
+
    It is used by the NetProcessor and the ClusterProcessor
    and should be considered PRIVATE to processor implementations.
 
 
-  
+
  ****************************************************************************/
 #if !defined (_SSLNetAccept_h_)
 #define _SSLNetAccept_h_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetProcessor.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   This file implements an I/O Processor for network I/O.
 
-  
+
  ****************************************************************************/
 #ifndef __P_SSLNETPROCESSOR_H
 #define __P_SSLNETPROCESSOR_H
@@ -97,11 +97,11 @@ SSLNetProcessor():UnixNetProcessor(), ve
 #if !defined (_IOCORE_WIN32_WINNT)
 
   // Virtual function allows etype
-  // to be set to ET_SSL for SSLNetProcessor.  
+  // to be set to ET_SSL for SSLNetProcessor.
   virtual void setEtype(EventType & etype);
   // Functions all THREAD_FREE and THREAD_ALLOC to be performed
   // for both SSL and regular NetVConnection transparent to
-  // netProcessor connect functions. 
+  // netProcessor connect functions.
   virtual UnixNetVConnection *allocateThread(EThread * t);
   virtual void freeThread(UnixNetVConnection * vc, EThread * t);
   virtual NetAccept *createNetAccept();

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetVConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetVConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetVConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_SSLNetVConnection.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   This file implements an I/O Processor for network I/O.
 
-  
+
  ****************************************************************************/
 #if !defined (_SSLNetVConnection_h_)
 #define _SSLNetVConnection_h_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPConnection.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   P_UDPConnection.h
   Internal UDPConnection holds data members and defines member functions
-  
-  
+
+
  ****************************************************************************/
 #ifndef __P_UDPCONNECTION_H_
 #define __P_UDPCONNECTION_H_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPNet.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPNet.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPNet.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPNet.h Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /****************************************************************************
   P_UDPNet.h
   Private header for UDPNetProcessor
-  
-  
+
+
  ****************************************************************************/
 
 #ifndef __P_UDPNET_H_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPPacket.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPPacket.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPPacket.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UDPPacket.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   P_UDPPacket.h
   Implementation of UDPPacket
-  
-  
+
+
  ****************************************************************************/
 
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNet.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNet.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNet.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNet.h Thu May 13 17:43:56 2010
@@ -141,7 +141,7 @@ struct EventIO
   int refresh(int events);
   int stop();
   int close();
-  EventIO() { 
+  EventIO() {
 #ifndef USE_LIBEV
     fd = 0;
 #endif
@@ -177,7 +177,7 @@ extern int http_accept_port_number;
 
 //#define INACTIVITY_TIMEOUT
 //
-// Configuration Parameter had to move here to share 
+// Configuration Parameter had to move here to share
 // between UnixNet and UnixUDPNet or SSLNet modules.
 // Design notes are in Memo.NetDesign
 //
@@ -487,7 +487,7 @@ write_disable(NetHandler * nh, UnixNetVC
     }
   }
 #else
-  if (vc->next_inactivity_timeout_at) 
+  if (vc->next_inactivity_timeout_at)
     if (!vc->read.enabled)
       vc->next_inactivity_timeout_at = 0;
 #endif
@@ -585,8 +585,8 @@ TS_INLINE int EventIO::start(EventLoop l
     EV_SET(&ev[n++], fd, EVFILT_WRITE, EV_ADD|INK_EV_EDGE_TRIGGER, 0, 0, this);
   return kevent(l->kqueue_fd, &ev[0], n, NULL, 0, NULL);
 #elif defined(USE_PORT)
-  events = e; 
-  int retval = port_associate(event_loop->port_fd, PORT_SOURCE_FD, fd, events, this); 
+  events = e;
+  int retval = port_associate(event_loop->port_fd, PORT_SOURCE_FD, fd, events, this);
   NetDebug("iocore_eventio", "[EventIO::start] e(%d), events(%d), %d[%s]=port_associate(%d,%d,%d,%d,%p)", e, events, retval, retval<0? strerror(errno) : "ok", event_loop->port_fd, PORT_SOURCE_FD, fd, events, this);
   return retval;
 #else
@@ -644,7 +644,7 @@ TS_INLINE int EventIO::modify(int e) {
 	n++;
       if ((-e) & EVENTIO_WRITE)
 	n++;
-    } 
+    }
   } else {
     if (!(e & events)) {
       ne = events | e;
@@ -652,11 +652,11 @@ TS_INLINE int EventIO::modify(int e) {
 	n++;
       if (e & EVENTIO_WRITE)
 	n++;
-    } 
+    }
   }
   if (n && ne && event_loop) {
     events = ne;
-    int retval = port_associate(event_loop->port_fd, PORT_SOURCE_FD, fd, events, this); 
+    int retval = port_associate(event_loop->port_fd, PORT_SOURCE_FD, fd, events, this);
     NetDebug("iocore_eventio", "[EventIO::modify] e(%d), ne(%d), events(%d), %d[%s]=port_associate(%d,%d,%d,%d,%p)", e, ne, events, retval, retval<0? strerror(errno) : "ok", event_loop->port_fd, PORT_SOURCE_FD, fd, events, this);
     return retval;
   }
@@ -690,11 +690,11 @@ TS_INLINE int EventIO::refresh(int e) {
       n++;
     if (n && ne && event_loop) {
       events = ne;
-      int retval = port_associate(event_loop->port_fd, PORT_SOURCE_FD, fd, events, this); 
+      int retval = port_associate(event_loop->port_fd, PORT_SOURCE_FD, fd, events, this);
       NetDebug("iocore_eventio", "[EventIO::refresh] e(%d), ne(%d), events(%d), %d[%s]=port_associate(%d,%d,%d,%d,%p)", e, ne, events, retval, retval<0? strerror(errno) : "ok", event_loop->port_fd, PORT_SOURCE_FD, fd, events, this);
       return retval;
-    } 
-  } 
+    }
+  }
   return 0;
 #else
   return 0;

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetState.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetState.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetState.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetState.h Thu May 13 17:43:56 2010
@@ -25,17 +25,17 @@
 
   UnixNetState.h
 
-  
+
    NetState
-  
+
    State information for a particular channel of a NetVConnection
    This information is private to the Net module.   It is only here
    because of the the C++ compiler needs it to define NetVConnection.
-  
+
    Shared with Cluster.cc
-  
 
-  
+
+
  ****************************************************************************/
 #if !defined (_UnixNetState_h_)
 #define _UnixNetState_h_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetVConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetVConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetVConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixNetVConnection.h Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
 
   This file implements an I/O Processor for network I/O on Unix.
 
-  
+
  ****************************************************************************/
 
 #ifndef __P_UNIXNETVCONNECTION_H__

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixPollDescriptor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixPollDescriptor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixPollDescriptor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixPollDescriptor.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   UnixPollDescriptor.h
 
-  
+
 *****************************************************************************/
 #ifndef __P_UNIXPOLLDESCRIPTOR_H__
 #define __P_UNIXPOLLDESCRIPTOR_H__
@@ -81,7 +81,7 @@ struct PollDescriptor
 #define ev_next_event(a,x)
 #elif defined(USE_KQUEUE)
   struct kevent kq_Triggered_Events[POLL_DESCRIPTOR_SIZE];
-  /* we define these here as numbers, because for kqueue mapping them to a combination of 
+  /* we define these here as numbers, because for kqueue mapping them to a combination of
  * filters / flags is hard to do. */
 #define get_ev_port(a) ((a)->kqueue_fd)
 #define get_ev_events(a,x) ((a)->kq_event_convert((a)->kq_Triggered_Events[(x)].filter, (a)->kq_Triggered_Events[(x)].flags))

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixUDPConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixUDPConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixUDPConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/P_UnixUDPConnection.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   P_UnixUDPConnection.h
   Unix UDPConnection implementation
-  
-  
+
+
  ****************************************************************************/
 #ifndef __UNIXUDPCONNECTION_H_
 #define __UNIXUDPCONNECTION_H_

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/SSLCertLookup.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/SSLCertLookup.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/SSLCertLookup.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/SSLCertLookup.cc Thu May 13 17:43:56 2010
@@ -124,18 +124,18 @@ SSLCertLookup::buildTable()
           priKey = NULL;
         }
       }                         // else
-    }                           // if(*line != '\0' && *line != '#') 
+    }                           // if(*line != '\0' && *line != '#')
 
     line = tokLine(NULL, &tok_state);
   }                             //  while(line != NULL)
 
-/*  if(num_el == 0) 
+/*  if(num_el == 0)
   {
     Warning("%s No entries in %s. Using default server cert for all connections",
 	    moduleName, configFilePath);
   }
 
-  if(is_debug_tag_set("ssl")) 
+  if(is_debug_tag_set("ssl"))
   {
     Print();
   }

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/SSLConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/SSLConfig.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/SSLConfig.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/SSLConfig.cc Thu May 13 17:43:56 2010
@@ -275,7 +275,7 @@ SslConfigParams::initialize()
 
   snprintf(serverCertPathOnly, serverCertPathOnlySize, "%s%s%s%s",
 	   system_root_dir, DIR_SEP,serverCertRelativePath,DIR_SEP);
-  snprintf(serverCertPath, serverCertPathSize, 
+  snprintf(serverCertPath, serverCertPathSize,
 	   "%s%s",serverCertPathOnly, serverCertFilename);
 
 #ifdef _WIN32

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/SSLNet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/SSLNet.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/SSLNet.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/SSLNet.cc Thu May 13 17:43:56 2010
@@ -321,7 +321,7 @@ SSLNetProcessor::initSSL(SslConfigParams
   // if no path is given for the server private key,
   // assume it is contained in the server certificate file.
 /*  serverKeyPtr = param->serverKeyPath;
-  if (serverKeyPtr == NULL) 
+  if (serverKeyPtr == NULL)
 	  serverKeyPtr = param->serverCertPath;
 */
   return (initSSLServerCTX(param, ctx, param->serverCertPath, param->serverKeyPath, true));
@@ -332,27 +332,27 @@ SSLNetProcessor::initSSL(SslConfigParams
   // if no path is given for the server private key,
   // assume it is contained in the server certificate file.
   serverKeyPtr = param->serverKeyPath;
-  if (serverKeyPtr == NULL) 
+  if (serverKeyPtr == NULL)
 	  serverKeyPtr = param->serverCertPath;
 
-  if (SSL_CTX_use_certificate_file(ctx, param->serverCertPath, SSL_FILETYPE_PEM) <= 0) 
+  if (SSL_CTX_use_certificate_file(ctx, param->serverCertPath, SSL_FILETYPE_PEM) <= 0)
   {
     logSSLError("Cannot use server certificate file");
     return(-2);
   }
-  
-  if(SSL_CTX_use_PrivateKey_file(ctx, serverKeyPtr, SSL_FILETYPE_PEM) <= 0) 
+
+  if(SSL_CTX_use_PrivateKey_file(ctx, serverKeyPtr, SSL_FILETYPE_PEM) <= 0)
   {
     logSSLError("Cannot use server private key file");
     return(-3);
   }
 
-  if(!SSL_CTX_check_private_key(ctx)) 
+  if(!SSL_CTX_check_private_key(ctx))
   {
     logSSLError("Server private key does not match the certificate public key");
     return(-4);
   }
-  
+
 
   if(param->clientCertLevel != 0)
   {

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/SSLNetVConnection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/SSLNetVConnection.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/SSLNetVConnection.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/SSLNetVConnection.cc Thu May 13 17:43:56 2010
@@ -47,7 +47,7 @@ do_SSL_write(SSL * ssl, void *buf, int s
 {
   int r = 0;
   do {
-    // need to check into SSL error handling 
+    // need to check into SSL error handling
     // to see if this is good enough.
     r = SSL_write(ssl, (const char *) buf, size);
     if (r >= 0)
@@ -173,9 +173,9 @@ SSLNetVConnection::net_read_io(NetHandle
   if (!lock) {
     return;
   }
-  // If it is not enabled, lower its priority.  This allows 
-  // a fast connection to speed match a slower connection by 
-  // shifting down in priority even if it could read. 
+  // If it is not enabled, lower its priority.  This allows
+  // a fast connection to speed match a slower connection by
+  // shifting down in priority even if it could read.
   if (!s->enabled || s->vio.op != VIO::READ) {
     read_disable(nh, this);
     return;
@@ -206,11 +206,11 @@ SSLNetVConnection::net_read_io(NetHandle
       write.triggered = 1;
       if (write.enabled)
         nh->write_ready_list.in_or_enqueue(this);
-    } else 
+    } else
       readReschedule(nh);
     return;
   }
-  // If there is nothing to do, disable connection 
+  // If there is nothing to do, disable connection
   int ntodo = s->vio.ntodo();
   if (ntodo <= 0) {
     read_disable(nh, this);
@@ -492,10 +492,10 @@ SSLNetVConnection::sslServerHandShakeEve
     if (client_cert != NULL) {
 /*		str = X509_NAME_oneline (X509_get_subject_name (client_cert), 0, 0);
 		Free (str);
-    
+
 		str = X509_NAME_oneline (X509_get_issuer_name  (client_cert), 0, 0);
 		Free (str);
-    
+
 		// Add any extra client cert verification stuff here.  SSL
 		// is set up in SSLNetProcessor::start to automatically verify
 		// the client cert's CA, if required.
@@ -564,7 +564,7 @@ SSLNetVConnection::sslClientHandShakeEve
 */
 
 /*	 Add certificate verification stuff here before
-     deallocating the certificate. 
+     deallocating the certificate.
 */
 
     X509_free(server_cert);

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/SSLUnixNet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/SSLUnixNet.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/SSLUnixNet.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/SSLUnixNet.cc Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
   This file implements an I/O Processor for network I/O for Unix.
   Contains additions for handling port pairs for RTSP/RTP.
 
-  
+
  ****************************************************************************/
 #include "ink_config.h"
 
@@ -85,7 +85,7 @@ SSLNetProcessor::setEtype(EventType & et
 
 // Virtual function allows the correct
 // etype to be used in NetAccept functions (ET_SSL
-// or ET_NET). 
+// or ET_NET).
 EventType
 SSLNetAccept::getEtype()
 {

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/Socks.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/Socks.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/Socks.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/Socks.cc Thu May 13 17:43:56 2010
@@ -23,9 +23,9 @@
 
 /*
   Socks.cc
-  
-  
-  
+
+
+
   This file contains the Socks client functionality. Previously this code was
   duplicated in UnixNet.cc and NTNetProcessor.cc
 */
@@ -350,7 +350,7 @@ SocksEntry::mainEvent(int event, void *d
 
     if (ret == EVENT_CONT)
       break;
-    // Fall Through 
+    // Fall Through
   case VC_EVENT_READ_COMPLETE:
     if (timeout) {
       timeout->cancel(this);
@@ -447,7 +447,7 @@ loadSocksConfiguration(socks_conf_struct
 
   error_msg[0] = 0;
 
-  socks_conf_stuff->accept_enabled = 0; //initialize it INKqa08593 
+  socks_conf_stuff->accept_enabled = 0; //initialize it INKqa08593
   socks_conf_stuff->socks_needed = IOCORE_ConfigReadInteger("proxy.config.socks.socks_needed");
   if (!socks_conf_stuff->socks_needed) {
     Debug("Socks", "Socks Turned Off");

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixConnection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixConnection.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixConnection.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixConnection.cc Thu May 13 17:43:56 2010
@@ -157,7 +157,7 @@ Lerror:
 
 int
 Connection::bind_connect(unsigned int target_ip, int target_port, unsigned int my_ip,
-                         NetVCOptions *opt, int sock, bool non_blocking_connect, bool use_tcp, 
+                         NetVCOptions *opt, int sock, bool non_blocking_connect, bool use_tcp,
                          bool non_blocking, bool bc_no_connect, bool bc_no_bind)
 {
   ink_assert(fd == NO_FD);
@@ -180,7 +180,7 @@ Connection::bind_connect(unsigned int ta
 
     fd = res;
 
-    if ((res = safe_setsockopt(fd, SOL_SOCKET, SO_REUSEADDR, (char *) &enable_reuseaddr, sizeof(enable_reuseaddr)) < 0)) 
+    if ((res = safe_setsockopt(fd, SOL_SOCKET, SO_REUSEADDR, (char *) &enable_reuseaddr, sizeof(enable_reuseaddr)) < 0))
       goto Lerror;
 
     struct sockaddr_in bind_sa;

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixNet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixNet.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixNet.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixNet.cc Thu May 13 17:43:56 2010
@@ -138,7 +138,7 @@ PollCont::pollEvent(int event, Event *e)
   ptimeout.tv_sec = poll_timeout / 1000;
   ptimeout.tv_nsec = 1000000 * (poll_timeout % 1000);
   unsigned nget = 1;
-  if((retval = port_getn(pollDescriptor->port_fd, 
+  if((retval = port_getn(pollDescriptor->port_fd,
 			pollDescriptor->Port_Triggered_Events,
 			POLL_DESCRIPTOR_SIZE, &nget, &ptimeout)) < 0) {
     pollDescriptor->result = 0;
@@ -157,8 +157,8 @@ PollCont::pollEvent(int event, Event *e)
   } else {
     pollDescriptor->result = (int)nget;
   }
-  NetDebug("iocore_net_poll", "[PollCont::pollEvent] %d[%s]=port_getn(%d,%p,%d,%d,%d),results(%d)", 
-	   retval,retval < 0 ? strerror(errno) : "ok", 
+  NetDebug("iocore_net_poll", "[PollCont::pollEvent] %d[%s]=port_getn(%d,%p,%d,%d,%d),results(%d)",
+	   retval,retval < 0 ? strerror(errno) : "ok",
 	   pollDescriptor->port_fd, pollDescriptor->Port_Triggered_Events,
 	   POLL_DESCRIPTOR_SIZE, nget, poll_timeout, pollDescriptor->result);
 #else
@@ -175,7 +175,7 @@ net_signal_hook_callback(EThread *thread
 #else
   char dummy[1024];
   NOWARN_UNUSED_RETURN(read(thread->evpipe[0], &dummy[0], 1024));
-#endif  
+#endif
 }
 
 static void
@@ -186,7 +186,7 @@ net_signal_hook_function(EThread *thread
 #else
   char dummy;
   NOWARN_UNUSED_RETURN(write(thread->evpipe[1], &dummy, 1));
-#endif  
+#endif
 }
 
 void
@@ -354,7 +354,7 @@ NetHandler::mainNetEvent(int event, Even
   ptimeout.tv_sec = poll_timeout / 1000;
   ptimeout.tv_nsec = 1000000 * (poll_timeout % 1000);
   unsigned nget = 1;
-  if((retval = port_getn(pd->port_fd, pd->Port_Triggered_Events, 
+  if((retval = port_getn(pd->port_fd, pd->Port_Triggered_Events,
 			POLL_DESCRIPTOR_SIZE, &nget, &ptimeout)) < 0) {
     pd->result = 0;
     switch(errno) {
@@ -372,8 +372,8 @@ NetHandler::mainNetEvent(int event, Even
   } else {
     pd->result = (int)nget;
   }
-  NetDebug("iocore_net_main_poll", "[NetHandler::mainNetEvent] %d[%s]=port_getn(%d,%p,%d,%d,%d),results(%d)", 
-	   retval,retval < 0 ? strerror(errno) : "ok", 
+  NetDebug("iocore_net_main_poll", "[NetHandler::mainNetEvent] %d[%s]=port_getn(%d,%p,%d,%d,%d),results(%d)",
+	   retval,retval < 0 ? strerror(errno) : "ok",
 	   pd->port_fd, pd->Port_Triggered_Events,
 	   POLL_DESCRIPTOR_SIZE, nget, poll_timeout, pd->result);
 #else
@@ -418,11 +418,11 @@ NetHandler::mainNetEvent(int event, Even
 	epd->refresh(EVENTIO_READ);
 #endif
       }
-    } 
+    }
 #if !defined(USE_OLD_EVENTFD)
     else if (epd->type == EVENTIO_ASYNC_SIGNAL){
       net_signal_hook_callback(trigger_event->ethread);
-    } 
+    }
 #else /* USE_OLD_EVENTFD */
     else if (epd->type == EVENTFD) { // use: EVENTIO_ASYNC_SIGNAL
       char buf[1024];

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetAccept.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetAccept.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetAccept.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetAccept.cc Thu May 13 17:43:56 2010
@@ -176,7 +176,7 @@ NetAccept::freeThread(UnixNetVConnection
 
 // Virtual function allows the correct
 // etype to be used in NetAccept functions (ET_SSL
-// or ET_NET). 
+// or ET_NET).
 EventType NetAccept::getEtype()
 {
   return (ET_NET);

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetPages.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetPages.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetPages.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetPages.cc Thu May 13 17:43:56 2010
@@ -72,7 +72,7 @@ struct ShowNet:ShowCont
       char interbuf[80];
       snprintf(interbuf, sizeof(interbuf), "%u.%u.%u.%u", PRINT_IP(vc->_interface));
       CHECK_SHOW(show("<tr>"
-                      // "<td><a href=\"/connection/%d\">%d</a></td>" 
+                      // "<td><a href=\"/connection/%d\">%d</a></td>"
                       "<td>%d</td>" "<td>%s</td>"       // ipbuf
                       "<td>%d</td>"     // port
                       "<td>%d</td>"     // fd

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetProcessor.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetProcessor.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetProcessor.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetProcessor.cc Thu May 13 17:43:56 2010
@@ -194,8 +194,8 @@ UnixNetProcessor::connect_re_internal(Co
     bool using_socks = (socks_conf_stuff->socks_needed && opt->socks_support != NO_SOCKS
 #ifdef SOCKS_WITH_TS
                         && (opt->socks_version != SOCKS_DEFAULT_VERSION ||
-                            /* This implies we are tunnelling. 
-                             * we need to connect using socks server even 
+                            /* This implies we are tunnelling.
+                             * we need to connect using socks server even
                              * if this ip is in no_socks list.
                              */
                             !socks_conf_stuff->ip_range.match(ip))
@@ -372,7 +372,7 @@ struct CheckConnect:public Continuation
           /* disable write on vc */
           vc->write.enabled = 0;
           vc->cancel_inactivity_timeout();
-          //write_disable(get_NetHandler(this_ethread()), vc); 
+          //write_disable(get_NetHandler(this_ethread()), vc);
           /* clean up vc fields */
           vc->write.vio.nbytes = 0;
           vc->write.vio.op = VIO::NONE;
@@ -454,7 +454,7 @@ UnixNetProcessor::start(int)
   netHandler_offset = eventProcessor.allocate(sizeof(NetHandler));
   pollCont_offset = eventProcessor.allocate(sizeof(PollCont));
 
-  // customize the threads for net 
+  // customize the threads for net
   setEtype(etype);
   // etype is ET_NET for netProcessor
   // and      ET_SSL for sslNetProcessor
@@ -487,7 +487,7 @@ UnixNetProcessor::start(int)
     }
   }
 #endif /*INK_NO_SOCKS */
-  // commented by vijay -  bug 2489945 
+  // commented by vijay -  bug 2489945
   /*if (use_accept_thread) // 0
      { NetAccept * na = createNetAccept();
      SET_CONTINUATION_HANDLER(na,&NetAccept::acceptLoopEvent);
@@ -524,7 +524,7 @@ UnixNetProcessor::freeThread(UnixNetVCon
 }
 
 
-// Virtual function allows creation of an 
+// Virtual function allows creation of an
 // SSLNetAccept or NetAccept transparent to NetProcessor.
 NetAccept *
 UnixNetProcessor::createNetAccept()

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetVConnection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetVConnection.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetVConnection.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixNetVConnection.cc Thu May 13 17:43:56 2010
@@ -206,7 +206,7 @@ write_signal_error(NetHandler *nh, UnixN
 }
 
 // Read the data for a UnixNetVConnection.
-// Rescheduling the UnixNetVConnection by moving the VC 
+// Rescheduling the UnixNetVConnection by moving the VC
 // onto or off of the ready_list.
 // Had to wrap this function with net_read_io for SSL.
 static void
@@ -225,7 +225,7 @@ read_from_net(NetHandler *nh, UnixNetVCo
     read_reschedule(nh, vc);
     return;
   }
-  // if it is not enabled.  
+  // if it is not enabled.
   if (!s->enabled || s->vio.op != VIO::READ) {
     vc->addLogMessage("not enabled");
     read_disable(nh, vc);
@@ -405,7 +405,7 @@ write_to_net_io(NetHandler *nh, UnixNetV
     } else if (ret == EVENT_DONE) {
       vc->read.triggered = 1;
       if (vc->read.enabled)
-        nh->read_ready_list.in_or_enqueue(vc); 
+        nh->read_ready_list.in_or_enqueue(vc);
     } else
       write_reschedule(nh, vc);
     return;
@@ -458,7 +458,7 @@ write_to_net_io(NetHandler *nh, UnixNetV
   ink64 r = vc->load_buffer_and_write(towrite, wattempted, total_wrote, buf);
   if (vc->loggingEnabled()) {
     char message[256];
-    snprintf(message, sizeof(message), "rval: %lld towrite: %lld ntodo: %lld total_wrote: %lld", 
+    snprintf(message, sizeof(message), "rval: %lld towrite: %lld ntodo: %lld total_wrote: %lld",
              r, towrite, ntodo, total_wrote);
     vc->addLogMessage(message);
   }
@@ -1033,7 +1033,7 @@ UnixNetVConnection::mainEvent(int event,
   *signal_timeout = 0;
   *signal_timeout_at = 0;
   writer_cont = write.vio._cont;
-  
+
   if (closed) {
     close_UnixNetVConnection(this, thread);
     return EVENT_DONE;
@@ -1113,7 +1113,7 @@ UnixNetVConnection::connectUp(EThread *t
 
   SET_HANDLER(&UnixNetVConnection::mainEvent);
   // This function is empty for regular UnixNetVConnection, it has code
-  // in it for the inherited SSLUnixNetVConnection.  Allows the connectUp 
+  // in it for the inherited SSLUnixNetVConnection.  Allows the connectUp
   // function code not to be duplicated in the inherited SSL class.
   //  sslStartHandShake (SSL_EVENT_CLIENT, err);
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPConnection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPConnection.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPConnection.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPConnection.cc Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   UnixUDPConnection.cc
   Unix UDPConnection implementation
-  
-  
+
+
  ****************************************************************************/
 
 #include "P_Net.h"
@@ -138,7 +138,7 @@ UDPConnection::send(Continuation * c, UD
 }
 
 void
-UDPConnection::Release() 
+UDPConnection::Release()
 {
   UnixUDPConnection *p = (UnixUDPConnection *) this;
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPNet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPNet.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPNet.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/UnixUDPNet.cc Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   UnixUDPNet.cc
   UDPNet implementation
-  
-  
+
+
  ****************************************************************************/
 
 #include "P_Net.h"
@@ -488,7 +488,7 @@ UDPNetProcessor::sendmsg_re(Continuation
  *      buf->consume(len);
  *      return ACTION_RESULT_DONE
  *   else
- *      return error 
+ *      return error
  *
  */
 Action *
@@ -934,7 +934,7 @@ UDPQueue::service(UDPNetHandler * nh)
       totalBw = 1.0;
 
     for (i = 0; i < G_inkPipeInfo.numPipes + 1; i++) {
-      // bw is in Mbps 
+      // bw is in Mbps
       bw = (G_inkPipeInfo.perPipeInfo[i].bytesSent * 8.0 * 1000.0) / (timeSpent * 1024.0 * 1024.0);
       snprintf(p1, sizeof(temp), "\t class[%d] = %f Mbps, alloc = %f Mbps, (conf'ed = %f, got = %f) \n",
                i, bw, (G_inkPipeInfo.perPipeInfo[i].bwAlloc / (1024.0 * 1024.0)),
@@ -1201,7 +1201,7 @@ UDPNetHandler::mainNetEvent(int event, E
   EventIO *temp_eptr = NULL;
   for (i = 0; i < pc->pollDescriptor->result; i++) {
     temp_eptr = (EventIO*) get_ev_data(pc->pollDescriptor,i);
-    if ((get_ev_events(pc->pollDescriptor,i) & EVENTIO_READ) 
+    if ((get_ev_events(pc->pollDescriptor,i) & EVENTIO_READ)
         && temp_eptr->type == EVENTIO_UDP_CONNECTION) {
       uc = temp_eptr->data.uc;
       ink_assert(uc && uc->mutex && uc->continuation);
@@ -1213,7 +1213,7 @@ UDPNetHandler::mainNetEvent(int event, E
         udpNetInternal.udp_read_from_net(this, uc, pc->pollDescriptor, trigger_event->ethread);
         nread++;
       }
-    }                           //if EPOLLIN        
+    }                           //if EPOLLIN
   }                             //end for
 
   // remove dead UDP connections

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/test_I_Net.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/test_I_Net.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/test_I_Net.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/test_I_Net.cc Thu May 13 17:43:56 2010
@@ -72,7 +72,7 @@ reconfigure_diags()
   diags->deactivate_all(DiagsTagType_Action);
 
   //////////////////////////////////////////////////////////////////////
-  //                     add new tag tables 
+  //                     add new tag tables
   //////////////////////////////////////////////////////////////////////
 
   if (diags->base_debug_tags)
@@ -162,7 +162,7 @@ main()
   eventProcessor.start(nproc);
   RecProcessStart();
 
-  /* 
+  /*
    *  Reset necessary config variables
    */
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/test_I_UDPNet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/test_I_UDPNet.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/test_I_UDPNet.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/test_I_UDPNet.cc Thu May 13 17:43:56 2010
@@ -74,7 +74,7 @@ reconfigure_diags()
   diags->deactivate_all(DiagsTagType_Action);
 
   //////////////////////////////////////////////////////////////////////
-  //                     add new tag tables 
+  //                     add new tag tables
   //////////////////////////////////////////////////////////////////////
 
   if (diags->base_debug_tags)

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/test_I_simple_proxy.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/test_I_simple_proxy.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/test_I_simple_proxy.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/test_I_simple_proxy.cc Thu May 13 17:43:56 2010
@@ -245,7 +245,7 @@ struct NetTesterAccept:public Continuati
 
   int handle_accept(int event, void *data)
   {
-    //printf("Accepted a connection\n");        
+    //printf("Accepted a connection\n");
     NetVConnection *vc = (NetVConnection *) data;
     NEW(new NetTesterSM(new_ProxyMutex(), vc));
     return EVENT_CONT;

Modified: trafficserver/traffic/tags/2.1.0/iocore/net/test_P_UDPNet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/net/test_P_UDPNet.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/net/test_P_UDPNet.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/net/test_P_UDPNet.cc Thu May 13 17:43:56 2010
@@ -74,7 +74,7 @@ reconfigure_diags()
   diags->deactivate_all(DiagsTagType_Action);
 
   //////////////////////////////////////////////////////////////////////
-  //                     add new tag tables 
+  //                     add new tag tables
   //////////////////////////////////////////////////////////////////////
 
   if (diags->base_debug_tags)

Modified: trafficserver/traffic/tags/2.1.0/iocore/utils/I_MTInteractor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/utils/I_MTInteractor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/utils/I_MTInteractor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/utils/I_MTInteractor.h Thu May 13 17:43:56 2010
@@ -172,7 +172,7 @@ class MTClient:public Continuation { pub
 
     @param t interactor to attach to
     @return return value for state handler.
-    
+
   */
   virtual int startAttach(MTInteractor * t);
 
@@ -196,7 +196,7 @@ class MTClient:public Continuation { pub
 
   /**
     Handler for detached state.
-    
+
   */
   virtual int handleDetached(int event, void *data);
 
@@ -211,14 +211,14 @@ class MTClient:public Continuation { pub
   };
 private:
   /**
-    Intermediate state when trying to attach. 
-    
+    Intermediate state when trying to attach.
+
   */
   int handleAttaching(int event, void *data);
 
   /**
-    Intermediate state when trying to detach. 
-    
+    Intermediate state when trying to detach.
+
   */
   int handleDetaching(int event, void *data);
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayMultiTunnel.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayMultiTunnel.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayMultiTunnel.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayMultiTunnel.h Thu May 13 17:43:56 2010
@@ -137,7 +137,7 @@ struct OneWayMultiTunnel:OneWayTunnel
             VIO * SourceVio, VIO ** TargetVios, int n_vioTargets, bool aclose_source = true, bool aclose_target = true);
 
   //
-  // Private 
+  // Private
   //
   int startEvent(int event, void *data);
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayTunnel.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayTunnel.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayTunnel.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/utils/I_OneWayTunnel.h Thu May 13 17:43:56 2010
@@ -69,7 +69,7 @@ struct OneWayTunnel:Continuation
   //
 
   //  Copy nbytes from vcSource to vcTarget.  When done, call
-  //  aCont back with either VC_EVENT_EOS (on success) or 
+  //  aCont back with either VC_EVENT_EOS (on success) or
   //  VC_EVENT_ERROR (on error)
   //
 
@@ -144,7 +144,7 @@ struct OneWayTunnel:Continuation
     @param aCont The Continuation to call back when the tunnel
       finishes. If not specified, the tunnel deallocates itself without
       calling back anybody.
-    @param SourceVio VIO of the vcSource. 
+    @param SourceVio VIO of the vcSource.
     @param reader IOBufferReader that reads from the vcSource. This
       reader is provided to vcTarget.
     @param aclose_source if true, the tunnel closes vcSource at the
@@ -159,14 +159,14 @@ struct OneWayTunnel:Continuation
 
   /**
     Use this init function if both the read and the write sides have
-    already been setup. The tunnel assumes that the read VC and the 
+    already been setup. The tunnel assumes that the read VC and the
     write VC are using the same buffer and frees that buffer
     when the transfer is done (either successful or unsuccessful)
-    @param aCont The Continuation to call back when the tunnel finishes. If 
+    @param aCont The Continuation to call back when the tunnel finishes. If
     not specified, the tunnel deallocates itself without calling back
     anybody.
 
-    @param SourceVio read VIO of the Source VC. 
+    @param SourceVio read VIO of the Source VC.
     @param TargetVio write VIO of the Target VC.
     @param aclose_source if true, the tunnel closes vcSource at the
       end. If aCont is not specified, this should be set to true.

Modified: trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayMultiTunnel.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayMultiTunnel.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayMultiTunnel.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayMultiTunnel.cc Thu May 13 17:43:56 2010
@@ -23,7 +23,7 @@
 
 /****************************************************************************
 
-   OneWayMultiTunnel.h 
+   OneWayMultiTunnel.h
  ****************************************************************************/
 
 #include "P_EventSystem.h"

Modified: trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayTunnel.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayTunnel.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayTunnel.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/utils/OneWayTunnel.cc Thu May 13 17:43:56 2010
@@ -318,7 +318,7 @@ OneWayTunnel::startEvent(int event, void
   return ret;
 }
 
-// If result is Non-zero, the vc should be aborted. 
+// If result is Non-zero, the vc should be aborted.
 void
 OneWayTunnel::close_source_vio(int result)
 {

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/Allocator.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/Allocator.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/Allocator.cc (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/Allocator.cc Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
 
   Allocator.h
 
-  
+
 *****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/DAllocator.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/DAllocator.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/DAllocator.cc (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/DAllocator.cc Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
    A pool allocator with some debugging feature including double free
      detection and integration with the mem-tracker
 
-   
+
   ****************************************************************************/
 
 #include "DAllocator.h"

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/DAllocator.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/DAllocator.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/DAllocator.h (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/DAllocator.h Thu May 13 17:43:56 2010
@@ -35,7 +35,7 @@
      it self well to this approach as it's typically allocated through
      wrapper functions
 
-   
+
   ****************************************************************************/
 
 #ifndef _D_ALLOCATOR_H_

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/Diags.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/Diags.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/Diags.cc (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/Diags.cc Thu May 13 17:43:56 2010
@@ -31,7 +31,7 @@
 
   Joe User should only need to use the macros at the bottom of Diags.h
 
-  
+
  ****************************************************************************/
 
 #include "ink_config.h"

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/Diags.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/Diags.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/Diags.h (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/Diags.h Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@
   warnings and errors at runtime.  Action tags and debugging tags are
   supported, allowing run-time conditionals affecting diagnostics.
 
-  
+
  ****************************************************************************/
 
 #ifndef __DIAGS_H___

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/I_Version.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/I_Version.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/I_Version.h (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/I_Version.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   Version.h
 
-  
+
   **************************************************************************/
 
 #ifndef _Version_h

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/InkPool.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/InkPool.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/InkPool.h (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/InkPool.h Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
 
 //
 // Template of a static size pool of objects.
-// 
+//
 //
 template<class C> class InkStaticPool {
 public:

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/InkTime.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/InkTime.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/InkTime.cc (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/InkTime.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   Implements general time functions.
 
-  
+
  ****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/tags/2.1.0/libinktomi++/InkTime.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/libinktomi%2B%2B/InkTime.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/libinktomi++/InkTime.h (original)
+++ trafficserver/traffic/tags/2.1.0/libinktomi++/InkTime.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   Implements general time functions.
 
-  
+
  ****************************************************************************/
 
 #ifndef _Time_h_