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 [3/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/cache/P_CacheDisk.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheDisk.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheDisk.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheDisk.h Thu May 13 17:43:56 2010
@@ -67,7 +67,7 @@ struct DiskPartBlockQueue
 
 struct DiskPart
 {
-  int num_partblocks;           /* number of disk partition blocks in this discrete 
+  int num_partblocks;           /* number of disk partition blocks in this discrete
                                    partition */
   int part_number;              /* the partition number of this partition */
   ink_off_t size;               /* size in store blocks */

Modified: trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheInternal.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheInternal.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheInternal.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheInternal.h Thu May 13 17:43:56 2010
@@ -247,17 +247,17 @@ struct CacheVC:CacheVConnection
     ink_assert(vio.op == VIO::READ);
     return !f.not_from_ram_cache;
   }
-  int get_header(void **ptr, int *len) 
+  int get_header(void **ptr, int *len)
   {
     if (first_buf.m_ptr) {
       Doc *doc = (Doc*)first_buf->data();
       *ptr = doc->hdr();
-      *len = doc->hlen;   
+      *len = doc->hlen;
       return 0;
     } else
       return -1;
   }
-  int set_header(void *ptr, int len) 
+  int set_header(void *ptr, int len)
   {
     header_to_write = ptr;
     header_to_write_len = len;
@@ -405,8 +405,8 @@ struct CacheVC:CacheVConnection
   // These variables are memset to 0 when the structure is freed.
   // The size of this region is size_to_init which is initialized
   // in the CacheVC constuctor. It assumes that vio is the start
-  // of this region. 
-  // NOTE: NOTE: NOTE: If vio is NOT the start, then CHANGE the 
+  // of this region.
+  // NOTE: NOTE: NOTE: If vio is NOT the start, then CHANGE the
   // size_to_init initialization
   VIO vio;
   EThread *initial_thread;  // initial thread open_XX was called on
@@ -447,7 +447,7 @@ struct CacheVC:CacheVConnection
   CacheVC *write_vc;
   char *hostname;
   int host_len;
-  int header_to_write_len;  
+  int header_to_write_len;
   void *header_to_write;
   short writer_lock_retry;
 
@@ -490,12 +490,12 @@ struct CacheVC:CacheVConnection
 #define POP_HANDLER do {                                          \
     handler = save_handler;                                       \
     ink_assert(handler != (ContinuationHandler)(&CacheVC::dead)); \
-  } while (0) 
+  } while (0)
 
 struct CacheRemoveCont:Continuation
 {
   int event_handler(int event, void *data);
-  
+
   CacheRemoveCont():Continuation(NULL) { }
 };
 
@@ -952,7 +952,7 @@ struct Cache
                                 CacheFragType frag_type, int options = 0,
                                 time_t pin_in_cache = (time_t) 0, char *hostname = 0, int host_len = 0);
   inkcoreapi Action *remove(Continuation *cont, CacheKey *key,
-                            CacheFragType type = CACHE_FRAG_TYPE_HTTP, 
+                            CacheFragType type = CACHE_FRAG_TYPE_HTTP,
                             bool user_agents = true, bool link = false,
                             char *hostname = 0, int host_len = 0);
   Action *scan(Continuation *cont, char *hostname = 0, int host_len = 0, int KB_per_second = 2500);
@@ -1133,8 +1133,8 @@ CacheProcessor::open_read_buffer(Continu
 
 
 TS_INLINE inkcoreapi Action *
-CacheProcessor::open_write(Continuation *cont, CacheKey *key, CacheFragType frag_type, 
-                           int expected_size, int options, time_t pin_in_cache, 
+CacheProcessor::open_write(Continuation *cont, CacheKey *key, CacheFragType frag_type,
+                           int expected_size, int options, time_t pin_in_cache,
                            char *hostname, int host_len)
 {
   (void) expected_size;
@@ -1152,9 +1152,9 @@ CacheProcessor::open_write(Continuation 
 }
 
 TS_INLINE Action *
-CacheProcessor::open_write_buffer(Continuation *cont, MIOBuffer *buf, CacheKey *key, 
-                                  CacheFragType frag_type, int options, time_t pin_in_cache, 
-                                  char *hostname, int host_len) 
+CacheProcessor::open_write_buffer(Continuation *cont, MIOBuffer *buf, CacheKey *key,
+                                  CacheFragType frag_type, int options, time_t pin_in_cache,
+                                  char *hostname, int host_len)
 {
   (void)cont;
   (void)buf;

Modified: trafficserver/traffic/tags/2.1.0/iocore/cache/P_CachePart.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cache/P_CachePart.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cache/P_CachePart.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cache/P_CachePart.h Thu May 13 17:43:56 2010
@@ -293,7 +293,7 @@ struct Frag {
   inku64 offset; // start offset of data stored in this fragment
 };
 
-// Note : hdr() needs to be 8 byte aligned. 
+// Note : hdr() needs to be 8 byte aligned.
 // If you change this, change sizeofDoc above
 struct Doc
 {
@@ -338,7 +338,7 @@ part_headerlen(Part *d) {
 TS_INLINE int
 part_dirlen(Part * d)
 {
-  return ROUND_TO_BLOCK(d->buckets * DIR_DEPTH * d->segments * SIZEOF_DIR) + 
+  return ROUND_TO_BLOCK(d->buckets * DIR_DEPTH * d->segments * SIZEOF_DIR) +
     part_headerlen(d) + ROUND_TO_BLOCK(sizeof(PartHeaderFooter));
 }
 TS_INLINE int
@@ -407,7 +407,7 @@ Doc::single_fragment()
   return (total_len && (data_len() == total_len));
 }
 TS_INLINE inku32
-Doc::nfrags() { 
+Doc::nfrags() {
   return flen / sizeof(Frag);
 }
 TS_INLINE Frag *

Modified: trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheTest.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheTest.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheTest.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cache/P_CacheTest.h Thu May 13 17:43:56 2010
@@ -58,7 +58,7 @@ struct CacheTestHost {
   double xprev_host_prob;
   double xnext_host_prob;
 
-  CacheTestHost():name(NULL), xlast_cachable_id(0), 
+  CacheTestHost():name(NULL), xlast_cachable_id(0),
                   xprev_host_prob(0), xnext_host_prob(0) {}
 };
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/cache/RamCacheCLFUS.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cache/RamCacheCLFUS.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cache/RamCacheCLFUS.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cache/RamCacheCLFUS.cc Thu May 13 17:43:56 2010
@@ -311,7 +311,7 @@ void RamCacheCLFUS::compress_entries(int
   while (compressed && target > ncompressed) {
     RamCacheCLFUSEntry *e = compressed;
     if (e->incompressible || e->compressed)
-      goto Lcontinue; 
+      goto Lcontinue;
     n++;
     if (do_at_most < n)
       break;
@@ -340,7 +340,7 @@ void RamCacheCLFUS::compress_entries(int
 #if HAVE_LIBZ
         case CACHE_COMPRESSION_LIBZ: {
           uLongf ll = l;
-          if ((Z_OK != compress((Bytef*)b, &ll, (Bytef*)e->data->data(), e->len))) 
+          if ((Z_OK != compress((Bytef*)b, &ll, (Bytef*)e->data->data(), e->len)))
             goto Lfailed;
           l = (int)ll;
           break;
@@ -349,7 +349,7 @@ void RamCacheCLFUS::compress_entries(int
 #ifdef HAVE_LZMA
         case CACHE_COMPRESSION_LIBLZMA: {
           size_t pos = 0, ll = l;
-          if (LZMA_OK != lzma_easy_buffer_encode(LZMA_PRESET_DEFAULT, LZMA_CHECK_NONE, NULL, 
+          if (LZMA_OK != lzma_easy_buffer_encode(LZMA_PRESET_DEFAULT, LZMA_CHECK_NONE, NULL,
                                                  (uint8_t*)e->data->data(), e->len, (uint8_t*)b, &pos, ll))
             goto Lfailed;
           l = (int)pos;
@@ -387,12 +387,12 @@ void RamCacheCLFUS::compress_entries(int
       check_accounting(this);
     }
     goto Lcontinue;
-  Lfailed:    
+  Lfailed:
     xfree(b);
     e->incompressible = 1;
   Lcontinue:;
-    DDebug("ram_cache", "compress %X %d %d %d %d %d %d", 
-           e->key.word(3), e->auxkey1, e->auxkey2, e->incompressible, e->compressed, 
+    DDebug("ram_cache", "compress %X %d %d %d %d %d %d",
+           e->key.word(3), e->auxkey1, e->auxkey2, e->incompressible, e->compressed,
            e->len, e->compressed_len);
     if (!e->lru_link.next)
       break;
@@ -403,11 +403,11 @@ void RamCacheCLFUS::compress_entries(int
 
 void RamCacheCLFUS::requeue_victims(RamCacheCLFUS *c, Que(RamCacheCLFUSEntry, lru_link) &victims) {
   RamCacheCLFUSEntry *victim = 0;
-  while ((victim = victims.dequeue())) { 
-    c->bytes += victim->size + ENTRY_OVERHEAD; 
+  while ((victim = victims.dequeue())) {
+    c->bytes += victim->size + ENTRY_OVERHEAD;
     CACHE_SUM_DYN_STAT_THREAD(cache_ram_cache_bytes_stat, victim->size);
     victim->hits = REQUEUE_HITS(victim->hits);
-    c->lru[0].enqueue(victim); 
+    c->lru[0].enqueue(victim);
   }
 }
 
@@ -497,7 +497,7 @@ int RamCacheCLFUS::put(INK_MD5 *key, IOB
       if (bytes + victim->size + size > max_bytes && CACHE_VALUE(victim) > CACHE_VALUE(e)) {
         requeue_victims(this, victims);
         lru[1].enqueue(e);
-        DDebug("ram_cache", "put %X %d %d size %d INC %d HISTORY", 
+        DDebug("ram_cache", "put %X %d %d size %d INC %d HISTORY",
                key->word(3), auxkey1, auxkey2, e->size, e->hits);
         return 0;
       }

Modified: trafficserver/traffic/tags/2.1.0/iocore/cache/Store.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cache/Store.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cache/Store.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cache/Store.cc Thu May 13 17:43:56 2010
@@ -75,7 +75,7 @@ const char *STORAGE_CONFIG_HEADER = "# 	
 #									\n\
 ";
 
-// Global 
+// Global
 Store theStore;
 
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterAPI.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterAPI.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterAPI.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterAPI.cc Thu May 13 17:43:56 2010
@@ -293,8 +293,8 @@ clusterAPI_init()
  *  Add the given function to the node status callout list which is
  *  invoked on each machine up/down transition.
  *
- *  Note: Using blocking mutex since interface is synchronous and is only 
- *	  called at plugin load time. 
+ *  Note: Using blocking mutex since interface is synchronous and is only
+ *	  called at plugin load time.
  */
 int
 INKAddClusterStatusFunction(INKClusterStatusFunction Status_Function, INKMutex m, INKClusterStatusHandle_t * h)
@@ -321,11 +321,11 @@ INKAddClusterStatusFunction(INKClusterSt
 }
 
 /*
- *  Remove the given function from the node status callout list 
+ *  Remove the given function from the node status callout list
  *  established via INKAddClusterStatusFunction().
  *
- *  Note: Using blocking mutex since interface is synchronous and is only 
- *	  called at plugin unload time (unload currently not supported). 
+ *  Note: Using blocking mutex since interface is synchronous and is only
+ *	  called at plugin unload time (unload currently not supported).
  */
 int
 INKDeleteClusterStatusFunction(INKClusterStatusHandle_t * h)
@@ -431,8 +431,8 @@ machine_offline_APIcallout(int Ipaddr)
 /*
  *  Associate the given RPC function with the given key.
  *
- *  Note: Using blocking mutex since interface is synchronous and is only 
- *	  called at plugin load time. 
+ *  Note: Using blocking mutex since interface is synchronous and is only
+ *	  called at plugin load time.
  */
 int
 INKAddClusterRPCFunction(INKClusterRPCKey_t k, INKClusterRPCFunction func, INKClusterRPCHandle_t * h)
@@ -461,7 +461,7 @@ INKAddClusterRPCFunction(INKClusterRPCKe
 /*
  *  Remove the given RPC function added via INKAddClusterRPCFunction().
  *
- *  Note: Using blocking mutex since interface is synchronous and is only 
+ *  Note: Using blocking mutex since interface is synchronous and is only
  *	  called at plugin unload time (unload currently not supported).
  */
 int

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterCache.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterCache.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterCache.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterCache.cc Thu May 13 17:43:56 2010
@@ -154,7 +154,7 @@ dump_sndtrace_table()
 // Cluster write VC cache.
 ///////////////////////////////////////////////////////////////////////
 //
-// In the event that a remote open read fails (HTTP only), an 
+// In the event that a remote open read fails (HTTP only), an
 // open write is issued and if successful a open write connection
 // is returned for the open read.  We cache the open write VC and
 // resolve the subsequent open write locally from the write VC cache
@@ -192,7 +192,7 @@ public:
 
   enum
   { MAX_TABLE_ENTRIES = 256,    // must be power of 2
-    SCAN_INTERVAL = 10          // seconds 
+    SCAN_INTERVAL = 10          // seconds
   };
   Queue<Entry> hash_table[MAX_TABLE_ENTRIES];
   Ptr<ProxyMutex> hash_lock[MAX_TABLE_ENTRIES];
@@ -733,15 +733,15 @@ CacheContinuation::lookupOpenWriteVC()
     SET_CONTINUATION_HANDLER(this, (CacheContHandler)
                              & CacheContinuation::lookupOpenWriteVCEvent);
     //
-    // Note: In the lookupOpenWriteVCEvent handler, we use EVENT_IMMEDIATE 
-    //       to distinguish the lookup retry from a request timeout 
+    // Note: In the lookupOpenWriteVCEvent handler, we use EVENT_IMMEDIATE
+    //       to distinguish the lookup retry from a request timeout
     //       which uses EVENT_INTERVAL.
     //
     lookup_open_write_vc_event = eventProcessor.schedule_imm(this, ET_CACHE_CONT_SM);
 
   } else if (vc != ((ClusterVConnection *) - 1)) {
-    // Hit, found open_write VC in cache.  
-    // Post open_write completion by simulating a 
+    // Hit, found open_write VC in cache.
+    // Post open_write completion by simulating a
     // remote cache op result message.
 
     vc->action_ = action;       // establish new continuation
@@ -857,8 +857,8 @@ CacheContinuation::localVCsetupEvent(int
       CLUSTER_INCREMENT_DYN_STAT(CLUSTER_REMOTE_OP_TIMEOUTS_STAT);
       timeout = (Event *) 1;    // Note timeout
       /////////////////////////////////////////////////////////////////
-      // Note: Failure callback is sent now, but the deallocation of 
-      //       the CacheContinuation is deferred until we receive the 
+      // Note: Failure callback is sent now, but the deallocation of
+      //       the CacheContinuation is deferred until we receive the
       //       open_local() callback.
       /////////////////////////////////////////////////////////////////
       if (!action.cancelled)
@@ -1493,7 +1493,7 @@ CacheContinuation::setupVCdataRead(int e
     MIOBuffer *buf = new_MIOBuffer(size_index);
     readahead_reader = buf->alloc_reader();
 
-    MUTEX_TRY_LOCK(lock, mutex, this_ethread());        // prevent immediate callback 
+    MUTEX_TRY_LOCK(lock, mutex, this_ethread());        // prevent immediate callback
     readahead_vio = vc->do_io_read(this, caller_buf_freebytes, buf);
     return EVENT_DONE;
 
@@ -1599,7 +1599,7 @@ CacheContinuation::setupReadWriteVC(int 
   case CACHE_EVENT_OPEN_READ_FAILED:
     {
       if (frag_type == CACHE_FRAG_TYPE_HTTP) {
-        // HTTP open read failed, attempt open write now to avoid an additional 
+        // HTTP open read failed, attempt open write now to avoid an additional
         //  message round trip
 
         CacheKey key(url_md5);
@@ -1672,7 +1672,7 @@ CacheContinuation::replyOpEvent(int even
   if ((request_opcode == CACHE_OPEN_READ_LONG)
       && cvc && (event == CACHE_EVENT_OPEN_WRITE)) {
     //////////////////////////////////////////////////////////////////////////
-    // open read failed, but open write succeeded, set result to 
+    // open read failed, but open write succeeded, set result to
     // CACHE_EVENT_OPEN_READ_FAILED and make result token non zero to
     // signal to the remote node that we have established a write connection.
     //////////////////////////////////////////////////////////////////////////
@@ -1837,7 +1837,7 @@ CacheContinuation::setupReadBufTunnel(VC
   tunnel_cont->tunnel = tunnel;
   tunnel_cont->tunnel_cont = tunnel_cont;
 
-  // Disable cluster_write_vc 
+  // Disable cluster_write_vc
   ((ClusterVConnection *) cluster_write_vc)->write.enabled = 0;
 
   // Disable cache read VC
@@ -1845,7 +1845,7 @@ CacheContinuation::setupReadBufTunnel(VC
 
   /////////////////////////////////////////////////////////////////////
   // At this point, the OneWayTunnel is blocked awaiting a reenable
-  // on both the source and target VCs. Reenable occurs after the 
+  // on both the source and target VCs. Reenable occurs after the
   // message containing the initial data and open read reply are sent.
   /////////////////////////////////////////////////////////////////////
 }
@@ -1915,7 +1915,7 @@ CacheContinuation::disposeOfDataBuffer(v
 
   if (cc->have_all_data) {
     //
-    // All object data resides in the buffer, no OneWayTunnel 
+    // All object data resides in the buffer, no OneWayTunnel
     // started and the Cache VConnection has already been closed.
     // Close write_cluster_vc and set remote close to avoid send of
     // close message to remote node.
@@ -1944,7 +1944,7 @@ CacheContinuation::handleDisposeEvent(in
   ink_assert(cc->magicno == (int) MagicNo);
   MUTEX_TRY_LOCK(lock, cc->tunnel_mutex, this_ethread());
   if (lock) {
-    // Write of initial object data is complete.  
+    // Write of initial object data is complete.
 
     if (!cc->tunnel_closed) {
       // Start tunnel by reenabling source and target VCs.
@@ -2249,7 +2249,7 @@ retry:
         timeout = 0;
         //
         // Post error completion now and defer deallocation of
-        // the continuation until we receive the reply or the 
+        // the continuation until we receive the reply or the
         // target node goes down.
         //
         if (!action.cancelled)
@@ -2408,13 +2408,13 @@ retry:
       ink_assert(read_cluster_vc && !write_cluster_vc);
       //
       // OPEN_READ_LONG has failed, but the remote node was able to
-      // establish an OPEN_WRITE_LONG connection.  
+      // establish an OPEN_WRITE_LONG connection.
       // Convert the cluster read VC to a write VC and insert it
-      // into the global write VC cache.  This will allow us to 
+      // into the global write VC cache.  This will allow us to
       // locally resolve the subsequent OPEN_WRITE_LONG request.
       //
 
-      // Note: We do not allow remote close on this VC while 
+      // Note: We do not allow remote close on this VC while
       //       it resides in cache
       //
       read_cluster_vc->set_type(CLUSTER_OPT_CONN_WRITE);
@@ -2657,7 +2657,7 @@ cache_lookup_ClusterFunction(ClusterMach
   log_cache_op_msg(msg->seq_number, 0, "cache_lookup");
 #endif
 
-  // Extract hostname data if passed.  
+  // Extract hostname data if passed.
 
   char *hostname;
   int hostname_len = len - op_to_sizeof_fixedlen_msg(CACHE_LOOKUP_OP);
@@ -2758,7 +2758,7 @@ ink32 CacheContinuation::getObjectSize(V
 }
 
 //////////////////////////////////////////////////////////////////////////
-// insert_cache_callback_user() 
+// insert_cache_callback_user()
 //  Insert write VC into global cache prior to performing user callback.
 //////////////////////////////////////////////////////////////////////////
 void

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterConfig.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterConfig.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterConfig.cc Thu May 13 17:43:56 2010
@@ -54,7 +54,7 @@ ClusterAccept::~ClusterAccept()
 void
 ClusterAccept::Init()
 {
-  // Setup initial accept by simulating EVENT_INTERVAL 
+  // Setup initial accept by simulating EVENT_INTERVAL
   // where cluster accept port has changed.
 
   current_cluster_port = ~*p_cluster_port;

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandler.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandler.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandler.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandler.cc Thu May 13 17:43:56 2010
@@ -368,7 +368,7 @@ ClusterHandler::close_free_lock(ClusterV
 
 bool ClusterHandler::build_data_vector(char *d, int len, bool read_flag)
 {
-  // Internal interface to general network i/o facility allowing  
+  // Internal interface to general network i/o facility allowing
   // single vector read/write to static data buffer.
 
   ClusterState & s = (read_flag ? read : write);
@@ -401,7 +401,7 @@ bool ClusterHandler::build_initial_vecto
 {
   //
   // Build initial read/write struct iovec and corresponding IOBufferData
-  // structures from the given struct descriptor(s).  
+  // structures from the given struct descriptor(s).
   // Required vector adjustments for partial i/o conditions is handled
   // by adjust_vector().
   //
@@ -502,10 +502,10 @@ bool ClusterHandler::build_initial_vecto
 
   ////////////////////////////////////////////////////////////
   // Build vector for data section of the cluster message.
-  // For read, we only do this if we are in data phase 
+  // For read, we only do this if we are in data phase
   // of the read (msg.state == 2)
   //////////////////////////////////////////////////////////////
-  //  Note: We are assuming that free space descriptors follow 
+  //  Note: We are assuming that free space descriptors follow
   //        the data descriptors.
   //////////////////////////////////////////////////////////////
   for (i = 0; i<(read_flag ? ((s.msg.state>= 2) ? s.msg.count : 0)
@@ -578,7 +578,7 @@ bool ClusterHandler::build_initial_vecto
             }
 
             ///////////////////////////////////////
-            // Allocate read data block 
+            // Allocate read data block
             ///////////////////////////////////////
             if (s.msg.descriptor[i].length) {
               vc->iov_map = new_n_iov;
@@ -720,7 +720,7 @@ bool ClusterHandler::get_read_locks()
       if (i < 0) {
         i = n;                  // note i/o start vector
 
-        // Now at vector where last transfer started, 
+        // Now at vector where last transfer started,
         // make considerations for the last transfer on this vector.
 
         vec_bytes_remainder = (s.iov[n].iov_len - iov_done[n]);
@@ -740,10 +740,10 @@ bool ClusterHandler::get_read_locks()
   }
   ink_release_assert(i >= 0);
 
-  // Start lock acquisition at the first vector where we started 
-  //  the last read.  
+  // Start lock acquisition at the first vector where we started
+  //  the last read.
   //
-  //  Note: We are assuming that free space descriptors follow 
+  //  Note: We are assuming that free space descriptors follow
   //        the data descriptors.
 
   for (; i < s.n_iov; ++i) {
@@ -798,7 +798,7 @@ bool ClusterHandler::get_write_locks()
 {
   ///////////////////////////////////////////////////////////////////////
   // Reacquire locks for the request setup by build_initial_vector().
-  // We are called after the entire write completes prior to 
+  // We are called after the entire write completes prior to
   // posting completion.
   ///////////////////////////////////////////////////////////////////////
   ClusterState & s = write;
@@ -849,11 +849,11 @@ void
 ClusterHandler::process_set_data_msgs()
 {
   inku32 cluster_function_index;
-  // 
+  //
   // Cluster set_data messages must always be processed ahead of all
   // messages and data.  By convention, set_data messages (highest priority
   // messages) always reside in the beginning of the descriptor
-  // and small control message structures.  
+  // and small control message structures.
   //
 
   /////////////////////////////////////////////
@@ -914,7 +914,7 @@ ClusterHandler::process_set_data_msgs()
           swap32((inku32 *) p); // length
           swap32((inku32 *) (p + sizeof(ink32)));       // function code
         }
-        // Mark message as processed.  
+        // Mark message as processed.
         // Defer dellocation until entire read is complete.
         *((inku32 *) p) = ~*((inku32 *) p);
 
@@ -1011,7 +1011,7 @@ ClusterHandler::process_large_control_ms
     ink_release_assert(cluster_function_index != SET_CHANNEL_DATA_CLUSTER_FUNCTION);
 
     if (cluster_function_index == (inku32) ~ SET_CHANNEL_DATA_CLUSTER_FUNCTION) {
-      // SET_CHANNEL_DATA_CLUSTER_FUNCTION already processed. 
+      // SET_CHANNEL_DATA_CLUSTER_FUNCTION already processed.
       // Just do memory deallocation.
 
       if (!clusterFunction[SET_CHANNEL_DATA_CLUSTER_FUNCTION].fMalloced)
@@ -1059,8 +1059,8 @@ ClusterHandler::process_freespace_msgs()
       if (c < n_channels && VALID_CHANNEL(channels[c]) &&
           (CLUSTER_SEQUENCE_NUMBER(channels[c]->token.sequence_number) == read.msg.descriptor[i].sequence_number)) {
         //
-        // VC received freespace message, move it to the 
-        // current bucket, since it may have data to 
+        // VC received freespace message, move it to the
+        // current bucket, since it may have data to
         // write (WRITE_VC_PRIORITY).
         //
         channels[c]->remote_free = read.msg.descriptor[i].length;
@@ -1335,7 +1335,7 @@ ClusterHandler::update_channels_partial_
                 Debug("cluster_vc_xfer", "Partial read, credit ch %d 0x%x %d bytes", vc->channel, vc, len);
                 s->vio.buffer.writer()->append_block(vc->read_block->clone());
                 if (complete_channel_read(len, vc)) {
-                  vc->read_block->consume(len); // note bytes moved to user 
+                  vc->read_block->consume(len); // note bytes moved to user
                 }
 
               } else {
@@ -1403,7 +1403,7 @@ bool ClusterHandler::complete_channel_re
 
   } else {
     //
-    // VC received data, move VC to current bucket since 
+    // VC received data, move VC to current bucket since
     // it may have freespace data to send (READ_VC_PRIORITY).
     //
     ClusterVC_remove_read(vc);
@@ -2279,7 +2279,7 @@ retry:
     }
   }
   // At this point, all initial read data passed in the open_read reply
-  // has been moved into the user VC.  
+  // has been moved into the user VC.
   // Now allow send of freespace to receive additional data.
 
   int nextfree = vc->read.vio.ndone;
@@ -2866,7 +2866,7 @@ ClusterHandler::process_write(ink_hrtime
 #endif
         if (!on_stolen_thread && !only_write_control_msgs) {
           /////////////////////////////////////////////////////////////
-          // Build a complete write descriptor containing control, 
+          // Build a complete write descriptor containing control,
           // data and freespace message data.
           /////////////////////////////////////////////////////////////
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandlerBase.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandlerBase.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandlerBase.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterHandlerBase.cc Thu May 13 17:43:56 2010
@@ -333,7 +333,7 @@ ClusterState::~ClusterState()
 void
 ClusterState::build_do_io_vector()
 {
-  // 
+  //
   // Construct the do_io_xxx data structures allowing transfer
   // of the data described by the iovec structure.
   //
@@ -403,7 +403,7 @@ ClusterState::doIO()
     to_do = 0;
     return 1;
   }
-  // 
+  //
   // Setup and initiate or resume Cluster i/o request to the NetProcessor.
   //
   if ((to_do && (io_complete_event == VC_EVENT_READ_READY)) || (io_complete_event == VC_EVENT_WRITE_READY)) {
@@ -709,7 +709,7 @@ ClusterHandler::alloc_channel(ClusterVCo
     } while (loops--);
 
     ink_release_assert(i != 0); // required
-    ink_release_assert(channels[i] == (ClusterVConnection *) 1);        // required 
+    ink_release_assert(channels[i] == (ClusterVConnection *) 1);        // required
     Debug(CL_TRACE, "alloc_channel local chan=%d VC=0x%x", i, vc);
 
   } else {
@@ -1108,7 +1108,7 @@ ClusterHandler::startClusterEvent(int ev
           callout_events[n] = eventProcessor.schedule_every(callout_cont[n], COMPLETION_CALLBACK_PERIOD, ET_NET);
         }
 
-        // Start cluster interconnect load monitoring 
+        // Start cluster interconnect load monitoring
 
         if (!clm) {
           clm = new ClusterLoadMonitor(machine);
@@ -1212,7 +1212,7 @@ ClusterHandler::protoZombieEvent(int eve
     }
   }
   ///////////////////////////////////////////////////////////////
-  // Deallocate current read control data 
+  // Deallocate current read control data
   ///////////////////////////////////////////////////////////////
   IncomingControl *ic;
   while ((ic = incoming_control.dequeue())) {

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterLoadMonitor.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterLoadMonitor.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterLoadMonitor.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterLoadMonitor.cc Thu May 13 17:43:56 2010
@@ -108,7 +108,7 @@ ClusterLoadMonitor::~ClusterLoadMonitor(
   //
   // Note: Since the ClusterLoadMonitor is only associated
   //       with the ClusterHandler, a periodic callback operating
-  //       on a freed ClusterLoadMonitor is not possible, since the 
+  //       on a freed ClusterLoadMonitor is not possible, since the
   //       ClusterHandler is only deleted after several minutes.  Allowing
   //       plenty of time for the periodic to cancel itself via the
   //       "cancel_periodic" flag.
@@ -173,12 +173,12 @@ ClusterLoadMonitor::compute_cluster_load
   // the configured limits.  We determine the state as follows.
   //   if (cluster overloaded)
   //     Determine if it is still in the overload state by examining
-  //     the last 'cluster_load_clear_duration' entries in the history 
+  //     the last 'cluster_load_clear_duration' entries in the history
   //     buffer and declaring it not overloaded if none of the entries
   //     exceed the threshold.
   //   else
   //     Determine if it is now in the overload state by examining
-  //     the last 'cluster_load_exceed_duration' entries in the history 
+  //     the last 'cluster_load_exceed_duration' entries in the history
   //     buffer and declaring it overloaded if all of the entries
   //     exceed the threshold.
 
@@ -243,7 +243,7 @@ ClusterLoadMonitor::note_ping_response_t
 void
 ClusterLoadMonitor::recv_cluster_load_msg(cluster_load_ping_msg * m)
 {
-  // We have received back our ping message.  
+  // We have received back our ping message.
   ink_hrtime now = ink_get_hrtime();
 
   if ((now >= m->send_time)

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterProcessor.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterProcessor.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterProcessor.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterProcessor.cc Thu May 13 17:43:56 2010
@@ -735,7 +735,7 @@ ClusterProcessor::init()
   IOCORE_EstablishStaticConfigInt32(RPC_only_CacheCluster, "proxy.config.cluster.rpc_cache_cluster");
 
   int cluster_type = 0;
-  // note : local variables work now using the same function. 
+  // note : local variables work now using the same function.
   // They are demarcated by their names
   IOCORE_RegisterConfigInteger(RECT_LOCAL, "proxy.local.cluster.type", 3, RECU_NULL, RECC_NULL, NULL);
   IOCORE_ReadConfigInteger(cluster_type, "proxy.local.cluster.type");

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterRPC.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterRPC.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterRPC.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterRPC.cc Thu May 13 17:43:56 2010
@@ -139,7 +139,7 @@ ChannelToCacheWriteVC(ClusterHandler * c
     CLUSTER_INCREMENT_DYN_STAT(cluster_setdata_no_CLUSTERVC_STAT);
     return NULL;
   }
-  // Tunneling from cluster to cache (remote write). 
+  // Tunneling from cluster to cache (remote write).
   // Get cache VC pointer.
 
   OneWayTunnel *owt = (OneWayTunnel *) cvc->read.vio._cont;
@@ -235,7 +235,7 @@ post_setchan_send_ClusterFunction(Cluste
   // We are called on the ET_CLUSTER thread.
   // set_data() control message has been queued into cluster transfer message.
   // This allows us to assume that it has been sent.
-  // Decrement Cluster VC n_set_data_msgs to allow transmission of 
+  // Decrement Cluster VC n_set_data_msgs to allow transmission of
   // initial open_write data after (n_set_data_msgs == 0).
 
   SetChanDataMessage *m = (SetChanDataMessage *) data;
@@ -297,7 +297,7 @@ post_setchan_pin_ClusterFunction(Cluster
   // We are called on the ET_CLUSTER thread.
   // Control message has been queued into cluster transfer message.
   // This allows us to assume that it has been sent.
-  // Decrement Cluster VC n_set_data_msgs to allow transmission of 
+  // Decrement Cluster VC n_set_data_msgs to allow transmission of
   // initial open_write data after (n_set_data_msgs == 0).
 
   SetChanPinMessage *m = (SetChanPinMessage *) data;
@@ -359,7 +359,7 @@ post_setchan_priority_ClusterFunction(Cl
   // We are called on the ET_CLUSTER thread.
   // Control message has been queued into cluster transfer message.
   // This allows us to assume that it has been sent.
-  // Decrement Cluster VC n_set_data_msgs to allow transmission of 
+  // Decrement Cluster VC n_set_data_msgs to allow transmission of
   // initial open_write data after (n_set_data_msgs == 0).
 
   SetChanPriorityMessage *m = (SetChanPriorityMessage *) data;

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterVConnection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterVConnection.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterVConnection.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/ClusterVConnection.cc Thu May 13 17:43:56 2010
@@ -94,21 +94,21 @@ ClusterVConnectionBase::do_io_pread(Cont
 }
 
 int
-ClusterVConnection::get_header(void **ptr, int *len) 
+ClusterVConnection::get_header(void **ptr, int *len)
 {
   ink_assert(!"implemented");
   return -1;
 }
 
 int
-ClusterVConnection::set_header(void *ptr, int len) 
+ClusterVConnection::set_header(void *ptr, int len)
 {
   ink_assert(!"implemented");
   return -1;
 }
 
 int
-ClusterVConnection::get_single_data(void **ptr, int *len) 
+ClusterVConnection::get_single_data(void **ptr, int *len)
 {
   ink_assert(!"implemented");
   return -1;
@@ -496,7 +496,7 @@ ClusterVConnection::set_http_info(CacheH
   // Cache semantics dictate that set_http_info() be established prior
   // to transferring any data on the ClusterVConnection.
   //
-  ink_release_assert(this->write.vio.op == VIO::NONE);  // not true if do_io() 
+  ink_release_assert(this->write.vio.op == VIO::NONE);  // not true if do_io()
   //   already done
   ink_release_assert(this->read.vio.op == VIO::NONE);   // should always be true
 
@@ -548,7 +548,7 @@ bool ClusterVConnection::set_pin_in_cach
   // open_write() ClusterVConnection.  It is only allowed after a
   // successful open_write() and prior to issuing the do_io(VIO::WRITE).
   //
-  ink_release_assert(this->write.vio.op == VIO::NONE);  // not true if do_io() 
+  ink_release_assert(this->write.vio.op == VIO::NONE);  // not true if do_io()
   //   already done
   ink_release_assert(this->read.vio.op == VIO::NONE);   // should always be true
   time_pin = t;
@@ -591,7 +591,7 @@ bool ClusterVConnection::set_disk_io_pri
   // open_write() ClusterVConnection.  It is only allowed after a
   // successful open_write() and prior to issuing the do_io(VIO::WRITE).
   //
-  ink_release_assert(this->write.vio.op == VIO::NONE);  // not true if do_io() 
+  ink_release_assert(this->write.vio.op == VIO::NONE);  // not true if do_io()
   //   already done
   ink_release_assert(this->read.vio.op == VIO::NONE);   // should always be true
   disk_io_priority = priority;

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCache.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCache.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCache.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCache.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   Cluster.h
 
-  
+
 ****************************************************************************/
 
 #ifndef _P_Cluster_Cache_h
@@ -42,14 +42,14 @@
 //  is a test only mode where all cluster nodes reside on the same host.
 //
 //  Configuration notes:
-//   - For "cluster.config" entries, always use "127.0.0.1" as the IP 
+//   - For "cluster.config" entries, always use "127.0.0.1" as the IP
 //     address and select a host unique cluster port.
 //
 //  Restrictions:
-//   1) Does not work with the manager.  You must only run with the server 
+//   1) Does not work with the manager.  You must only run with the server
 //      and hand configure "cluster.config".
 //   2) Currently, this has only been tested in a two node configuration.
-//      
+//
 /****************************************************************************/
 
 #include "P_ClusterMachine.h"
@@ -366,7 +366,7 @@ struct ClusterVConnectionBase:CacheVConn
   //   enabled* during which the connection was unable to sink/provide data.
   // calling these functions repeatedly resets the timeout.
   //   NOT THREAD-SAFE, may only be called when handing an event from this
-  //                    ClusterVConnectionBase, or the ClusterVConnectionBase 
+  //                    ClusterVConnectionBase, or the ClusterVConnectionBase
   //                    creation callback.
   //
   void set_active_timeout(ink_hrtime timeout_in);
@@ -789,7 +789,7 @@ ClusterFunctionDescriptor clusterFunctio
   {false, true, CMSG_MAX_PRI, set_channel_priority_ClusterFunction,
    post_setchan_priority_ClusterFunction},
    /********************************************
-    * RESERVED for future cluster internal use * 
+    * RESERVED for future cluster internal use *
     ********************************************/
   {false, false, CMSG_LOW_PRI, 0, 0},
   {false, false, CMSG_LOW_PRI, 0, 0},
@@ -900,7 +900,7 @@ ClusterFuncToQpri(int cluster_func)
 #define SET_CHANNEL_PRIORITY_CLUSTER_FUNCTION  	     16
 
 /********************************************
- * RESERVED for future cluster internal use * 
+ * RESERVED for future cluster internal use *
  ********************************************/
 #define INTERNAL_RESERVED1_CLUSTER_FUNCTION  	     17
 #define INTERNAL_RESERVED2_CLUSTER_FUNCTION  	     18
@@ -990,7 +990,7 @@ ClusterFuncToQpri(int cluster_func)
 #define UNDEFINED_CLUSTER_FUNCTION                   0xFDEFFDEF
 
 //////////////////////////////////////////////
-// Initial cluster connect exchange message 
+// Initial cluster connect exchange message
 //////////////////////////////////////////////
 struct ClusterHelloMessage
 {

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCacheInternal.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCacheInternal.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCacheInternal.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterCacheInternal.h Thu May 13 17:43:56 2010
@@ -117,7 +117,7 @@ struct CacheContinuation:public Continua
   int request_opcode;
   bool local_lookup_only;
   bool no_reply_message;
-  bool request_timeout;         // timeout occurred before 
+  bool request_timeout;         // timeout occurred before
   //   op complete
   bool expect_cache_callback;
 
@@ -140,9 +140,9 @@ struct CacheContinuation:public Continua
   int cluster_vc_channel;
   ClusterVCToken open_local_token;
 
-  // Readahead on open read specific data 
+  // Readahead on open read specific data
 
-  int caller_buf_freebytes;     // remote bufsize for 
+  int caller_buf_freebytes;     // remote bufsize for
   //  initial data
   VIO *readahead_vio;
   IOBufferReader *readahead_reader;
@@ -343,7 +343,7 @@ CacheContinuation():
 // Cache OP specific args for do_op()  //
 /////////////////////////////////////////
 
-// Bit definitions for cfl_flags.  
+// Bit definitions for cfl_flags.
 // Note: Limited to 16 bits
 #define CFL_OVERWRITE_ON_WRITE 		(1 << 1)
 #define CFL_REMOVE_USER_AGENTS 		(1 << 2)
@@ -603,7 +603,7 @@ struct CacheOpReplyMsg:public ClusterMes
   inku32 seq_number;
   ink32 result;
   ClusterVCToken token;
-  inku8 moi[4];                 // Used by CACHE_OPEN_READ & CACHE_LINK reply 
+  inku8 moi[4];                 // Used by CACHE_OPEN_READ & CACHE_LINK reply
   enum
   {
     MIN_VERSION = 1,

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterHandler.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterHandler.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterHandler.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterHandler.h Thu May 13 17:43:56 2010
@@ -70,7 +70,7 @@ struct ClusterControl:Continuation
 
   enum
   {
-    // DATA_HDR = size_index (1 byte) + magicno (1 byte) + sizeof(this) 
+    // DATA_HDR = size_index (1 byte) + magicno (1 byte) + sizeof(this)
 
     DATA_HDR = (sizeof(ink64) * 2)      // must be multiple of sizeof(ink64)
   };
@@ -399,7 +399,7 @@ struct ClusterState:Continuation
 };
 
 //
-// ClusterHandlerBase superclass for processors with 
+// ClusterHandlerBase superclass for processors with
 // bi-directional VConnections.
 //
 struct ClusterHandlerBase:Continuation

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterInternal.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterInternal.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterInternal.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterInternal.h Thu May 13 17:43:56 2010
@@ -515,7 +515,7 @@ int machine_config_change(const char *, 
 extern void do_machine_config_change(void *, const char *);
 
 #ifdef NON_MODULAR
-// Cluster API support functions 
+// Cluster API support functions
 extern void clusterAPI_init();
 extern void machine_online_APIcallout(int);
 extern void machine_offline_APIcallout(int);

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterMachine.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterMachine.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterMachine.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/P_ClusterMachine.h Thu May 13 17:43:56 2010
@@ -36,7 +36,7 @@
 #define _P_ClusterMachine_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)
@@ -48,8 +48,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
 
@@ -73,7 +73,7 @@ struct ClusterMachine:Server
     ClusterMachine(char *hostname = NULL, unsigned int ip = 0, int acluster_port = 0);
    ~ClusterMachine();
 
-  // Cluster message protocol version 
+  // Cluster message protocol version
   inku16 msg_proto_major;
   inku16 msg_proto_minor;
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/cluster/test_I_Cluster.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/test_I_Cluster.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/test_I_Cluster.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/test_I_Cluster.cc Thu May 13 17:43:56 2010
@@ -23,8 +23,8 @@
 
 /*
   This is a bogus test file because it does not need any cluster
-  functions : the actual test file is in the cache directory. 
-  This file is a placeholder because each module is supposed to 
+  functions : the actual test file is in the cache directory.
+  This file is a placeholder because each module is supposed to
   have a test file
   */
 
@@ -77,7 +77,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/cluster/test_P_Cluster.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/cluster/test_P_Cluster.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/cluster/test_P_Cluster.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/cluster/test_P_Cluster.cc Thu May 13 17:43:56 2010
@@ -23,8 +23,8 @@
 
 /*
   This is a bogus test file because it does not need any cluster
-  functions : the actual test file is in the cache directory. 
-  This file is a placeholder because each module is supposed to 
+  functions : the actual test file is in the cache directory.
+  This file is a placeholder because each module is supposed to
   have a test file
   */
 
@@ -77,7 +77,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/dns/DNS.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/dns/DNS.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/dns/DNS.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/dns/DNS.cc Thu May 13 17:43:56 2010
@@ -86,7 +86,7 @@ strnchr(char *s, char c, int len)
 static inline inku16
 ink_get16(const inku8 *src) {
   inku16 dst;
-  
+
   NS_GET16(dst, src);
   return dst;
 }
@@ -442,7 +442,7 @@ DNSHandler::startEvent_sdns(int event, E
   // If this is for the default server, get it
   //
 
-  //added by YTS Team, yamsat 
+  //added by YTS Team, yamsat
   Debug("dns", "DNSHandler::startEvent_sdns: on thread%d\n", e->ethread->id);
 
   if (ip == DEFAULT_DOMAIN_NAME_SERVER) {
@@ -653,7 +653,7 @@ good_rcode(char *buf)
 void
 DNSHandler::recv_dns(int event, Event * e)
 {
-  NetHandler *nh = get_NetHandler(e->ethread);  //added by YTS Team, yamsat 
+  NetHandler *nh = get_NetHandler(e->ethread);  //added by YTS Team, yamsat
   DNSConnection *dnsc = NULL;   //added by YTS Team, yamsat
 
   while ((dnsc = (DNSConnection *) nh->dnsqueue.dequeue())) {
@@ -1322,7 +1322,7 @@ dns_process(DNSHandler * handler, HostEn
       memset(&try_server_names[try_servers][strlen(e->qname)], 0, 1);
     }
 
-    /* added for SRV support [ebalsa] 
+    /* added for SRV support [ebalsa]
        this skips the query section (qdcount)
      */
     unsigned char *here = (unsigned char *) buf->buf + HFIXEDSZ;

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/dns/I_DNSProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/dns/I_DNSProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/dns/I_DNSProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/dns/I_DNSProcessor.h Thu May 13 17:43:56 2010
@@ -101,7 +101,7 @@ struct DNSProcessor:Processor
 
   // Processor API
   //
-  /* currently dns system uses event threads 
+  /* currently dns system uses event threads
    * dont pass any value to the call */
   int start(int no_of_extra_dns_threads = 0);
 

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

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

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

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/dns/P_SplitDNSProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/dns/P_SplitDNSProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/dns/P_SplitDNSProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/dns/P_SplitDNSProcessor.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  *
  * P_SplitDNSProcessor.h - Interface to DNS server selection
  *
- * 
+ *
  ****************************************************************************/
 
 #ifndef _P_SPLIT_DNSProcessor_H_
@@ -78,8 +78,8 @@ struct SplitDNSResult
 
   SplitDNSResult();
 
-  /* ------------ 
-     public 
+  /* ------------
+     public
      ------------ */
 
   DNSResultType r;
@@ -87,8 +87,8 @@ struct SplitDNSResult
   DNSServer *get_dns_record();
   int get_dns_srvr_count();
 
-  /* ------------ 
-     private 
+  /* ------------
+     private
      ------------ */
   int m_line_number;
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/dns/SRV.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/dns/SRV.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/dns/SRV.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/dns/SRV.cc Thu May 13 17:43:56 2010
@@ -21,16 +21,16 @@
   limitations under the License.
  */
 
-/* 
-  
-  indent -ncs -nut -npcs -l 132 -br SRV.cc 
-  
+/*
+
+  indent -ncs -nut -npcs -l 132 -br SRV.cc
+
         Support for SRV records
-        
+
         http://www.faqs.org/rfcs/rfc2782.html
         http://www.nongnu.org/ruli/
         http://libsrv.cvs.sourceforge.net/libsrv/libsrv/src/libsrv.c
-        
+
 */
 
 #include "P_DNS.h"
@@ -39,7 +39,7 @@ struct HostDBRoundRobin;
 
 ClassAllocator<SRV> SRVAllocator("SRVAllocator");
 
-/* 
+/*
 To select a target to be contacted next, arrange all SRV RRs
 (that have not been ordered yet) in any order, except that all
 those with weight 0 are placed at the beginning of the list.
@@ -78,7 +78,7 @@ SRVHosts::getWeightedHost(char *ret_val)
     goto err;
   }
 
-  /* Step 1/2 Sort based on 'priority': handled by operator< 
+  /* Step 1/2 Sort based on 'priority': handled by operator<
    */
 
   hosts.sort();

Modified: trafficserver/traffic/tags/2.1.0/iocore/dns/SplitDNS.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/dns/SplitDNS.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/dns/SplitDNS.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/dns/SplitDNS.cc Thu May 13 17:43:56 2010
@@ -78,7 +78,7 @@ static const char *sdns_def_domain = "pr
 
 /* --------------------------------------------------------------
    used by a lot of protocols. We do not have dest ip in most
-   cases. 
+   cases.
    -------------------------------------------------------------- */
 
 const matcher_tags sdns_dest_tags = {
@@ -505,7 +505,7 @@ SplitDNSRecord::ProcessDNSHosts(char *va
   }
 
   /* ------------------------------------------------
-     Allocate the servers array and Loop through the 
+     Allocate the servers array and Loop through the
      set of servers specified
      ------------------------------------------------ */
 
@@ -522,7 +522,7 @@ SplitDNSRecord::ProcessDNSHosts(char *va
     }
 
     /* ----------------------------------------
-       Make sure that is no garbage beyond the 
+       Make sure that is no garbage beyond the
        server port
        ---------------------------------------- */
     if (tmp) {
@@ -640,7 +640,7 @@ SplitDNSRecord::ProcessDomainSrchList(ch
 /* --------------------------------------------------------------
    SplitDNSRecord::Init()
 
-   matcher_line* line_info - contains parsed label/value pairs 
+   matcher_line* line_info - contains parsed label/value pairs
    of the current split.config line
    -------------------------------------------------------------- */
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/dns/test_I_DNS.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/dns/test_I_DNS.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/dns/test_I_DNS.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/dns/test_I_DNS.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/eventsystem/EventSystem.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/EventSystem.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/EventSystem.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/EventSystem.cc Thu May 13 17:43:56 2010
@@ -23,9 +23,9 @@
 
 /****************************************************************************
 
-   EventSystem.cc -- 
+   EventSystem.cc --
+
 
-   
 ****************************************************************************/
 
 #include "P_EventSystem.h"

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_Action.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_Action.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_Action.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_Action.h Thu May 13 17:43:56 2010
@@ -31,7 +31,7 @@
 
 /**
   Represents an operation initiated on a Processor.
-  
+
   The Action class is an abstract representation of an operation
   being executed by some Processor. A reference to an Action object
   allows you to cancel an ongoing asynchronous operation before it

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_EventProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_EventProcessor.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_EventProcessor.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_EventProcessor.h Thu May 13 17:43:56 2010
@@ -137,7 +137,7 @@ public:
   */
   Event *schedule_imm(Continuation * c,
                       EventType event_type = ET_CALL, int callback_event = EVENT_IMMEDIATE, void *cookie = NULL);
-  /* 
+  /*
     provides the same functionality as schedule_imm and also signals the thread immediately
   */
   Event *schedule_imm_signal(Continuation * c,
@@ -214,7 +214,7 @@ public:
 
 
   ////////////////////////////////////////////
-  // reschedule an already scheduled event. // 
+  // reschedule an already scheduled event. //
   // may be called directly or called by    //
   // schedule_xxx Event member functions.   //
   // The returned value may be different    //

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_IOBuffer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_IOBuffer.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_IOBuffer.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_IOBuffer.h Thu May 13 17:43:56 2010
@@ -48,7 +48,7 @@ class IOBufferReader;
 class VIO;
 
 // Removing this optimization since this is breaking WMT over HTTP
-//#define WRITE_AND_TRANSFER 
+//#define WRITE_AND_TRANSFER
 
 inkcoreapi extern ink64 max_iobuffer_size;
 extern ink64 default_small_iobuffer_size;

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_ProtectedQueue.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_ProtectedQueue.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_ProtectedQueue.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_ProtectedQueue.h Thu May 13 17:43:56 2010
@@ -30,7 +30,7 @@
        amount of time, or until a new element is inserted, whichever
        is earlier
 
-  
+
  ****************************************************************************/
 #ifndef _I_ProtectedQueue_h_
 #define _I_ProtectedQueue_h_

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_SocketManager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_SocketManager.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_SocketManager.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_SocketManager.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   Handle the allocation of the socket descriptor (fd) resource.
 
-  
+
  ****************************************************************************/
 
 #ifndef _I_SocketManager_h_
@@ -91,10 +91,10 @@ struct SocketManager
              const struct timespec *timeout);
 #elif defined(USE_PORT)
   int port_create();
-  int port_associate(int port, int fd, uintptr_t obj, 
+  int port_associate(int port, int fd, uintptr_t obj,
 		     int events, void *user);
   int port_dissociate(int port, int fd, uintptr_t obj);
-  int port_getn(int port, port_event_t *list, uint_t max, 
+  int port_getn(int port, port_event_t *list, uint_t max,
 		uint_t *nget, timespec_t *timeout);
 #endif
   int shutdown(int s, int how);

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_VConnection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_VConnection.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_VConnection.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/I_VConnection.h Thu May 13 17:43:56 2010
@@ -236,7 +236,7 @@ public:
     @param nbytes Number of bytes to write. If unknown, nbytes must
       be set to INK64_MAX.
     @param buf Reader whose data is to be read from.
-    @param owner 
+    @param owner
     @return VIO representing the scheduled IO operation.
 
   */

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Lock.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Lock.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Lock.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Lock.cc Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   Basic Locks for Threads
 
-  
-  
+
+
 **************************************************************************/
 #include "P_EventSystem.h"
 

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_IOBuffer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_IOBuffer.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_IOBuffer.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_IOBuffer.h Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@
 
 //////////////////////////////////////////////////////////////
 //
-// returns 0 for DEFAULT_BUFFER_BASE_SIZE,  
+// returns 0 for DEFAULT_BUFFER_BASE_SIZE,
 // +1 for each power of 2
 //
 //////////////////////////////////////////////////////////////
@@ -865,7 +865,7 @@ MIOBuffer::block_write_avail()
 //
 //  MIOBuffer::append_block()
 //
-//  Appends a block to writer->next and make it the current 
+//  Appends a block to writer->next and make it the current
 //  block.
 //  Note that the block is not appended to the end of the list.
 //  That means that if writer->next was not null before this
@@ -953,7 +953,7 @@ MIOBuffer::get_current_block()
 //
 //  returns the total space available in all blocks.
 //  This function is different than write_avail() because
-//  it will not append a new block if there is no space 
+//  it will not append a new block if there is no space
 //  or below the watermark space available.
 //
 //////////////////////////////////////////////////////////////////

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_ProtectedQueue.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_ProtectedQueue.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_ProtectedQueue.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_ProtectedQueue.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
 
   Protected Queue
 
-  
+
  ****************************************************************************/
 #ifndef _P_ProtectedQueue_h_
 #define _P_ProtectedQueue_h_
@@ -123,19 +123,19 @@ ProtectedQueue::dequeue_local()
 }
 
 #if defined(USE_OLD_EVENTFD)
-TS_INLINE void 
+TS_INLINE void
 ProtectedQueue::setReadFd(int fd)
 {
   read_pipe_fd = fd;
 }
 
-TS_INLINE void 
+TS_INLINE void
 ProtectedQueue::setWriteFd(int fd)
 {
   write_pipe_fd = fd;
 }
 
-TS_INLINE int 
+TS_INLINE int
 ProtectedQueue::getReadFd()
 {
   int pfd[2] = {-1,-1};

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixEThread.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixEThread.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixEThread.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixEThread.h Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
 
   P_UnixEThread.h
 
-  
-  
+
+
 *****************************************************************************/
 #ifndef _P_UnixEThread_h_
 #define _P_UnixEThread_h_
@@ -163,7 +163,7 @@ EThread::free_event(Event * e)
 }
 
 #if defined(USE_OLD_EVENTFD)
-TS_INLINE int 
+TS_INLINE int
 EThread::getEventFd()
 {
   return EventQueueExternal.getReadFd();

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixSocketManager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixSocketManager.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixSocketManager.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/P_UnixSocketManager.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
   Handle the allocation of the socket descriptor (fd) resource.
 
-  
+
 ****************************************************************************/
 #ifndef _P_UnixSocketManager_h_
 #define _P_UnixSocketManager_h_
@@ -416,35 +416,35 @@ SocketManager::kevent(int kq, const stru
 }
 #elif defined(USE_PORT)
 TS_INLINE int
-SocketManager::port_create() 
+SocketManager::port_create()
 {
   return ::port_create();
 }
 
 TS_INLINE int
 SocketManager::port_associate(int port, int source, uintptr_t obj,
-                              int events, void *user) 
+                              int events, void *user)
 {
   int r;
   r =::port_associate(port, source, obj, events, user);
-  if(r < 0) 
+  if(r < 0)
     r = -errno;
   return r;
 }
 
 TS_INLINE int
-SocketManager::port_dissociate(int port, int source, uintptr_t obj) 
+SocketManager::port_dissociate(int port, int source, uintptr_t obj)
 {
   int r;
   r =::port_dissociate(port, source, obj);
-  if(r < 0) 
+  if(r < 0)
     r = -errno;
   return r;
 }
 
 TS_INLINE int
 SocketManager::port_getn(int port, port_event_t *list, uint_t max,
-                         uint_t *nget, timespec_t *timeout) 
+                         uint_t *nget, timespec_t *timeout)
 {
   int r;
   do {

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Processor.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Processor.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Processor.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/Processor.cc Thu May 13 17:43:56 2010
@@ -37,7 +37,7 @@
   or more conveniently, by calling a method service call which synthesizes
   the appropriate request Continuation and places it in the queue.
 
-  
+
  ****************************************************************************/
 
 #include "P_EventSystem.h"

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/ProtectedQueue.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/ProtectedQueue.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/ProtectedQueue.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/ProtectedQueue.cc Thu May 13 17:43:56 2010
@@ -35,10 +35,10 @@
 
 // The protected queue is designed to delay signaling of threads
 // until some amount of work has been completed on the current thread
-// in order to prevent excess context switches. 
+// in order to prevent excess context switches.
 //
 // Defining EAGER_SIGNALLING disables this behavior and causes
-// threads to be made runnable immediately. 
+// threads to be made runnable immediately.
 //
 //#define EAGER_SIGNALLING
 
@@ -59,7 +59,7 @@ ProtectedQueue::enqueue(Event * e , bool
     if (inserting_thread != e_ethread) {
       if (!inserting_thread || !inserting_thread->ethreads_to_be_signalled) {
         signal();
-        if (fast_signal) { 
+        if (fast_signal) {
           if (e_ethread->signal_hook)
             e_ethread->signal_hook(e_ethread);
         }
@@ -70,8 +70,8 @@ ProtectedQueue::enqueue(Event * e , bool
         if (e_ethread->EventQueueExternal.try_signal())
           return;
 #endif
-        
-        if (fast_signal) { 
+
+        if (fast_signal) {
           if (e_ethread->signal_hook)
             e_ethread->signal_hook(e_ethread);
         }
@@ -80,7 +80,7 @@ ProtectedQueue::enqueue(Event * e , bool
         if ((t + 1) >= eventProcessor.n_ethreads) {
           // we have run out of room
           if ((t + 1) == eventProcessor.n_ethreads) {
-            // convert to direct map, put each ethread (sig_e[i]) into 
+            // convert to direct map, put each ethread (sig_e[i]) into
             // the direct map loation: sig_e[sig_e[i]->id]
             for (int i = 0; i < t; i++) {
               EThread *cur = sig_e[i];  // put this ethread

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/UnixEThread.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/UnixEThread.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/UnixEThread.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/UnixEThread.cc Thu May 13 17:43:56 2010
@@ -43,7 +43,7 @@ EThread::EThread()
    ethreads_to_be_signalled(NULL),
    n_ethreads_to_be_signalled(0),
    main_accept_index(-1),
-   id(NO_ETHREAD_ID), event_types(0), 
+   id(NO_ETHREAD_ID), event_types(0),
    signal_hook(0),
    tt(REGULAR), eventsem(NULL)
 {
@@ -79,7 +79,7 @@ EThread::EThread(ThreadType att, int ani
   fcntl(evfd, F_SETFD, FD_CLOEXEC);
   fcntl(evfd, F_SETFL, O_NONBLOCK);
 #else
-  ink_release_assert(pipe(evpipe) >= 0); 
+  ink_release_assert(pipe(evpipe) >= 0);
   fcntl(evpipe[0], F_SETFD, FD_CLOEXEC);
   fcntl(evpipe[0], F_SETFL, O_NONBLOCK);
   fcntl(evpipe[1], F_SETFD, FD_CLOEXEC);
@@ -92,7 +92,7 @@ EThread::EThread(ThreadType att, Event *
    ethreads_to_be_signalled(NULL),
    n_ethreads_to_be_signalled(0),
    main_accept_index(-1),
-   id(NO_ETHREAD_ID), event_types(0), 
+   id(NO_ETHREAD_ID), event_types(0),
    signal_hook(0),
    tt(att), oneevent(e), eventsem(sem)
 {
@@ -235,8 +235,8 @@ EThread::execute() {
                 free_event(e);
               else {
                 // If its a negative event, it must be a result of
-                // a negative event, which has been turned into a 
-                // timed-event (because of a missed lock), executed 
+                // a negative event, which has been turned into a
+                // timed-event (because of a missed lock), executed
                 // before the poll. So, it must
                 // be executed in this round (because you can't have
                 // more than one poll between two executions of a

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

Modified: trafficserver/traffic/tags/2.1.0/iocore/eventsystem/test_Buffer.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/eventsystem/test_Buffer.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/eventsystem/test_Buffer.cc (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/eventsystem/test_Buffer.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)

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/include/IncludeFiles.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/include/IncludeFiles.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/include/IncludeFiles.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/include/IncludeFiles.h Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 
 /*
  * Contains the most common include files.
- * 
+ *
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/include/fastio.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/include/fastio.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/include/fastio.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/include/fastio.h Thu May 13 17:43:56 2010
@@ -24,8 +24,8 @@
 /*
  *
  * fastio.h
- * 
- * 
+ *
+ *
  * Data structures for FastIO
  *
  *
@@ -167,7 +167,7 @@
 #define INKFIO_DEST_VSESSION    0xffffffff
 
 
-/* 
+/*
  * Ioctl CMD's
  */
 #define INKUDP_INIT    0x0

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev.c Thu May 13 17:43:56 2010
@@ -497,7 +497,7 @@ fio_devmap(dev_t dev, devmap_cookie_t dh
 }
 
 /*
- * 
+ *
  * MUNMAP handler
  */
 static void

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev_sol.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev_sol.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev_sol.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_dev_sol.c Thu May 13 17:43:56 2010
@@ -495,7 +495,7 @@ fio_devmap(dev_t dev, devmap_cookie_t dh
 }
 
 /*
- * 
+ *
  * MUNMAP handler
  */
 static void

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_ioctl.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_ioctl.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_ioctl.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_ioctl.c Thu May 13 17:43:56 2010
@@ -181,10 +181,10 @@ fio_dump_mblk(mblk_t * mp)
 
 
 /*
- * Initialize a STREAMS UDP request message body 
+ * Initialize a STREAMS UDP request message body
  *
  *
- *  Magic numbers for Solaris... maybe not 
+ *  Magic numbers for Solaris... maybe not
  *  relevant for other platforms
  */
 inline void
@@ -595,7 +595,7 @@ fio_ioctl_swap(fio_devstate_t * rsp, int
 
 
 /*
- * Handle a metarequest 
+ * Handle a metarequest
  *
  * Metarequests are a list of request block numbers stored in a metarequest block
  * Metarequests increase single-syscall bandwidth by a factor of 750. :)

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_request.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_request.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_request.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkfio/fio_request.c Thu May 13 17:43:56 2010
@@ -147,7 +147,7 @@ fio_vsession_send(fio_devstate_t * rsp, 
 
 
 /*
- * Process a pending request. 
+ * Process a pending request.
  *
  * Return 0 if the request should now be dequeued, otherwise
  * return the time in mS till the next packet should be sent
@@ -171,7 +171,7 @@ fio_process_request(fio_devstate_t * rsp
 
   if (now < rec_hrtime) {
     /* startTime and now are expresed in nanoseconds; return
-     * the time til the request can start in milliseconds 
+     * the time til the request can start in milliseconds
      */
     hrtime_t leftoverTime;
 
@@ -451,7 +451,7 @@ fio_process_queue(void *ptr)
 
 
 /*
- * Queue a partially completed request 
+ * Queue a partially completed request
  *
  */
 void
@@ -482,7 +482,7 @@ fio_queue_request(fio_devstate_t * rsp, 
     req->prev = rsp->pRequests->prev;
     rsp->pRequests->prev = req;
     req->next = rsp->pRequests;
-    /* since existing requests are pending, 
+    /* since existing requests are pending,
      * we don't need to schedule a callback
      *
      * Note: this may result in the next packet of the request being early

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_recv.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_recv.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_recv.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_recv.c Thu May 13 17:43:56 2010
@@ -82,7 +82,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.
    */
@@ -302,7 +302,7 @@ inkudp_flush_split_rule(queue_t * incomi
 
 /*
  *  inkudp_handle_cmsg()
- *  Process a control message.  
+ *  Process a control message.
  *
  *  These messages sometimes contain important data, so we should
  *  make sure they are all ignored.

Modified: trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.c (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.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.
    */
@@ -888,7 +888,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/inkudp_sched.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.h (original)
+++ trafficserver/traffic/tags/2.1.0/iocore/fastio/inkudp/inkudp_sched.h Thu May 13 17:43:56 2010
@@ -87,7 +87,7 @@ struct ink_recv_pktQ_node
   uint32_t m_finish_xmitTime;
   /* the redirect list to which this packet belongs */
   struct ink_redirect_list *m_redir_list;
-  /* 
+  /*
    * The meaning of next depends on where this node is placed: if it is in
    * the q of the incoming packets, then next points to the next packet of
    * the redir list of this packet; if it is in the queue of outgoing