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

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

Modified: trafficserver/traffic/trunk/libinktomi++/SimpleTokenizer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/SimpleTokenizer.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/SimpleTokenizer.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/SimpleTokenizer.h Thu May 13 07:09:39 2010
@@ -32,7 +32,7 @@
 /*-----------------------------------------------------------------------------
   SimpleTokenizer
 
-  
+
 
   This class provides easy token parsing from an input string. It supports:
 
@@ -43,18 +43,18 @@
 
   The class has two constructors, one that defines the input string,
   and another one that does not. If the latter is used, then the
-  setString method should be used to set the data string. 
+  setString method should be used to set the data string.
 
   Both constructors set the delimiter, the operation mode (which
-  defines bullets 1-3 above), and the escape character. 
+  defines bullets 1-3 above), and the escape character.
 
-  The available methods are: 
+  The available methods are:
 
   void setString(char *s)
   sets the data string to s. The mode specified upon construction of the
   tokenizer determines whether s is copied or not.
 
-  char *getNext() 
+  char *getNext()
   returns the next token, or NULL if there are no more tokens. This method
   uses the delimiter specified upon object construction.
 
@@ -67,7 +67,7 @@
   between).
 
   char *getNext(char delimiter, int count)
-  this is similar to getNext(int count) but allows user to specify the 
+  this is similar to getNext(int count) but allows user to specify the
   delimiter.
 
   IMPORTANT: the char pointers returned by the SimpleTokenizer are valid
@@ -80,13 +80,13 @@
 
   char *peekAtRestOfString()
   returns the rest of the input string, but DOES NOT advance pointer so a
-  subsequent call to getNext does return the next token (if there is still 
+  subsequent call to getNext does return the next token (if there is still
   one).
 
   size_t getNumTokensRemaining()
   returns the number of tokens remaining in the string (using the delimiter
   specified upon object construction).
-  
+
   size_t getNumTokensRemaining(char delimiter)
   similar to the above, but allows the user to change the delimiter (just for
   this call).
@@ -96,7 +96,7 @@
   examples:
 
   SimpleTokenizer tok("one    two\\ and\\ three four:   five : six");
-  tok.getNumTokensRemaining() --> 5     note calculation is done assuming 
+  tok.getNumTokensRemaining() --> 5     note calculation is done assuming
                                         space is the delimiter
   tok.getNext() -> "one"
   tok.getNext() -> "two and three"
@@ -104,12 +104,12 @@
   tok.peekAtRestOfString() -> "   five  : six"
   tok.getNext(':') -> "five"
 
-  SimpleTokenizer tok(",  with null fields ,,,", ',', 
+  SimpleTokenizer tok(",  with null fields ,,,", ',',
                       CONSIDER_NULL_FIELDS | KEEP_WHITESPACE);
   tok.getNext() -> ""
   tok.getNext() -> "  with null fields "
   tok.getNumTokensRemaining() -> 3
-  
+
   ---------------------------------------------------------------------------*/
 
 class SimpleTokenizer
@@ -241,7 +241,7 @@ private:
         _start = end + 1;
 
         // there can be delimiters at the end if the number of tokens
-        // requested is larger than 1, remove them if the 
+        // requested is larger than 1, remove them if the
         // CONSIDER_NULL_FIELDS flag is not set
         //
         if (!(_mode & CONSIDER_NULL_FIELDS)) {
@@ -257,7 +257,7 @@ private:
         if (!countOnly) {
           _data[end] = 0;
 
-          // remove escape characters only if the number of 
+          // remove escape characters only if the number of
           // delimiters is one
           //
           if (hasEsc && delimCount == 1) {

Modified: trafficserver/traffic/trunk/libinktomi++/TestHttpHeader.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/TestHttpHeader.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/TestHttpHeader.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/TestHttpHeader.cc Thu May 13 07:09:39 2010
@@ -26,7 +26,7 @@
    TestHeaderTokenizer.cc --
    Created On      : Mon Jan 20 11:48:10 1997
 
-   
+
  ****************************************************************************/
 #include "HttpHeaderTokenizer.h"
 #include "ink_assert.h"

Modified: trafficserver/traffic/trunk/libinktomi++/TextBuffer.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/TextBuffer.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/TextBuffer.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/TextBuffer.cc Thu May 13 07:09:39 2010
@@ -29,9 +29,9 @@
 /****************************************************************************
  *
  *  TextBuffer.cc - A self-expanding buffer, primarly meant for strings
- *                     
- *  
- * 
+ *
+ *
+ *
  ****************************************************************************/
 
 textBuffer::textBuffer(int size)
@@ -63,7 +63,7 @@ textBuffer::~textBuffer()
 
 // void textBuffer::reUse()
 //
-//   Sets the text buffer for reuse by repositioning the 
+//   Sets the text buffer for reuse by repositioning the
 //     ptrs to beginning of buffer.  The buffer space is
 //     reused
 void
@@ -82,7 +82,7 @@ textBuffer::reUse()
 //  Copy N bytes (determined by num_bytes) on to the
 //  end of the buffer.
 //
-//  Returns the number of bytes copies or 
+//  Returns the number of bytes copies or
 //  -1 if there was insufficient memory
 int
 textBuffer::copyFrom(const void *source, int num_bytes)
@@ -104,9 +104,9 @@ textBuffer::copyFrom(const void *source,
   return num_bytes;
 }
 
-//  textBuffer::enlargeBuffer(int n) 
+//  textBuffer::enlargeBuffer(int n)
 //
-//  Enlarge the buffer so at least at N 
+//  Enlarge the buffer so at least at N
 //    bytes are free in the buffer.
 //
 //  Always enlarges by a power of two.
@@ -145,7 +145,7 @@ textBuffer::enlargeBuffer(int N)
 // int textBuffer::rawReadFromFile
 //
 // - Issues a single read command on the file descriptor or handle
-//   passed in and reads in raw data (not assumed to be text, no 
+//   passed in and reads in raw data (not assumed to be text, no
 //   string terminators added).
 // - Cannot read from file descriptor on win32 because the win32
 //   read() function replaces CR-LF with LF if the file is not
@@ -181,7 +181,7 @@ textBuffer::rawReadFromFile(int fd)
 //
 // Issues a single read command on the file
 // descritor passed in.  Attempts to read a minimum of
-// 512 bytes from file descriptor passed.  
+// 512 bytes from file descriptor passed.
 int
 textBuffer::readFromFD(int fd)
 {

Modified: trafficserver/traffic/trunk/libinktomi++/TextBuffer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/TextBuffer.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/TextBuffer.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/TextBuffer.h Thu May 13 07:09:39 2010
@@ -28,8 +28,8 @@
  *
  *  TextBuffer.h - A self-expanding buffer, primarly meant for strings
  *
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #include "ink_platform.h"

Modified: trafficserver/traffic/trunk/libinktomi++/Tokenizer.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/Tokenizer.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/Tokenizer.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/Tokenizer.cc Thu May 13 07:09:39 2010
@@ -32,9 +32,9 @@
 /****************************************************************************
  *
  *  Tokenizer.cc - A string tokenzier
- *                     
- *  
- * 
+ *
+ *
+ *
  ****************************************************************************/        /* MAGIC_EDITING_TAG */
 
 Tokenizer::Tokenizer(const char *StrOfDelimiters)
@@ -203,7 +203,7 @@ Tokenizer::Initialize(char *str, int opt
       // First, skip the delimiters
       for (; *str != '\0' && isDelimiter(*str); str++);
 
-      // If there are only delimiters remaining, bail and set 
+      // If there are only delimiters remaining, bail and set
       //   so that we do not add the empty token
       if (*str == '\0') {
         priorCharWasDelimit = 1;

Modified: trafficserver/traffic/trunk/libinktomi++/Tokenizer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/Tokenizer.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/Tokenizer.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/Tokenizer.h Thu May 13 07:09:39 2010
@@ -29,9 +29,9 @@
 /****************************************************************************
  *
  *  Tokenizer.h - A string tokenzier
- *                     
- *  
- * 
+ *
+ *
+ *
  ****************************************************************************/
 
 /**********************************************************
@@ -44,7 +44,7 @@
  *
  *  There are three memory options.
  *     SHARE_TOKS - this modifies the original string passed in
- *          through Intialize() and shares its space.   NULLs 
+ *          through Intialize() and shares its space.   NULLs
  *          are inserted into string after each token.  Choosing
  *          this option means the user is reponsible for not
  *          deallocating the string storage before deallocating
@@ -73,17 +73,17 @@
  *  operator[index] - returns a pointer to the number token given
  *     by index.  If index > numTokens-1, NULL is returned.
  *     Because of way tokens are stored, this is O(n) operation
- *     It is very fast though for the first 16 tokens and 
+ *     It is very fast though for the first 16 tokens and
  *     is intended to be used on a small number of tokens
  *
  *  iterFirst(tok_iter_state* state) - Returns the first
  *     token and intializes state argument for subsequent
- *     calls to iterNext.  If no tokens exist, NULL is 
+ *     calls to iterNext.  If no tokens exist, NULL is
  *     returned
  *
  *  iterNext(tok_iter_state* state) - Returns the next token after
  *     what arg state returned next last time.   Returns NULL if no
- *     more tokens exists.  
+ *     more tokens exists.
  *
  *  Note: To iterate through a list using operator[] takes O(n^2) time
  *      Using iterFirst, iterNext the running time is O(n), so use
@@ -91,15 +91,15 @@
  *
  *  getNumber() - returns the number of tokens
  *
- *  setMaxTokens() - sets the maximum number of tokens.  Once maxTokens 
- *                     is reached, delimiters are ignored and the 
+ *  setMaxTokens() - sets the maximum number of tokens.  Once maxTokens
+ *                     is reached, delimiters are ignored and the
  *                     last token is rest of the string.  Negative numbers
  *                     mean no limit on the number of tokens
  *
  *  getMaxTokens() - returns maxTokens.  Negative number mean no limit
  *
  *  Print() - Debugging method to print out the tokens
- *     
+ *
  *******************************************************************/
 
 #include "ink_apidefs.h"

Modified: trafficserver/traffic/trunk/libinktomi++/Version.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/Version.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/Version.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/Version.cc Thu May 13 07:09:39 2010
@@ -78,7 +78,7 @@ AppVersionInfo::setup(const char *pkg_na
   snprintf(BldPersonStr, sizeof(BldPersonStr), "%s", build_person);
   snprintf(BldCompileFlagsStr, sizeof(BldCompileFlagsStr), "%s", build_cflags);
 
-  snprintf(FullVersionInfoStr, sizeof(FullVersionInfoStr), 
+  snprintf(FullVersionInfoStr, sizeof(FullVersionInfoStr),
            "%s - %s - %s - (build # %d%d%d on %s at %s)",
            PkgStr, AppStr, VersionStr, month, day, hour, build_date, build_time);
 

Modified: trafficserver/traffic/trunk/libinktomi++/fastlz.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/fastlz.c?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/fastlz.c (original)
+++ trafficserver/traffic/trunk/libinktomi++/fastlz.c Thu May 13 07:09:39 2010
@@ -1,4 +1,4 @@
-/*  
+/*
   FastLZ - lightning-fast lossless compression library
 
   Copyright (C) 2007 Ariya Hidayat (ariya@kde.org)
@@ -50,7 +50,7 @@
 #define FASTLZ_INLINE inline
 #elif defined(__BORLANDC__) || defined(_MSC_VER) || defined(__LCC__)
 #define FASTLZ_INLINE __inline
-#else 
+#else
 #define FASTLZ_INLINE
 #endif
 
@@ -91,7 +91,7 @@ int fastlz_decompress(const void* input,
 #define MAX_DISTANCE 8192
 
 #if !defined(FASTLZ_STRICT_ALIGN)
-#define FASTLZ_READU16(p) *((const flzuint16*)(p)) 
+#define FASTLZ_READU16(p) *((const flzuint16*)(p))
 #else
 #define FASTLZ_READU16(p) ((p)[0] | (p)[1]<<8)
 #endif
@@ -237,7 +237,7 @@ static FASTLZ_INLINE int FASTLZ_COMPRESS
     *hslot = anchor;
 
     /* is this a match? check the first 3 bytes */
-    if(distance==0 || 
+    if(distance==0 ||
 #if FASTLZ_LEVEL==1
     (distance >= MAX_DISTANCE) ||
 #else
@@ -250,11 +250,11 @@ static FASTLZ_INLINE int FASTLZ_COMPRESS
     /* far, needs at least 5-byte match */
     if(distance >= MAX_DISTANCE)
     {
-      if(*ip++ != *ref++ || *ip++!= *ref++) 
+      if(*ip++ != *ref++ || *ip++!= *ref++)
         goto literal;
       len += 2;
     }
-    
+
     match:
 #endif
 
@@ -350,7 +350,7 @@ static FASTLZ_INLINE int FASTLZ_COMPRESS
       while(len > MAX_LEN-2)
       {
         *op++ = (7 << 5) + (distance >> 8);
-        *op++ = MAX_LEN - 2 - 7 -2; 
+        *op++ = MAX_LEN - 2 - 7 -2;
         *op++ = (distance & 255);
         len -= MAX_LEN-2;
       }
@@ -461,7 +461,7 @@ static FASTLZ_INLINE int FASTLZ_DECOMPRE
         ref = op - ofs - MAX_DISTANCE;
       }
 #endif
-      
+
 #ifdef FASTLZ_SAFE
       if (FASTLZ_UNEXPECT_CONDITIONAL(op + len + 3 > op_limit))
         return 0;
@@ -534,7 +534,7 @@ static FASTLZ_INLINE int FASTLZ_DECOMPRE
         return 0;
 #endif
 
-      *op++ = *ip++; 
+      *op++ = *ip++;
       for(--ctrl; ctrl; ctrl--)
         *op++ = *ip++;
 

Modified: trafficserver/traffic/trunk/libinktomi++/fastlz.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/fastlz.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/fastlz.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/fastlz.h Thu May 13 07:09:39 2010
@@ -1,4 +1,4 @@
-/*  
+/*
   FastLZ - lightning-fast lossless compression library
 
   Copyright (C) 2007 Ariya Hidayat (ariya@kde.org)
@@ -40,11 +40,11 @@ extern "C" {
 #endif
 
 /**
-  Compress a block of data in the input buffer and returns the size of 
-  compressed block. The size of input buffer is specified by length. The 
+  Compress a block of data in the input buffer and returns the size of
+  compressed block. The size of input buffer is specified by length. The
   minimum input buffer size is 16.
 
-  The output buffer must be at least 5% larger than the input buffer  
+  The output buffer must be at least 5% larger than the input buffer
   and can not be smaller than 66 bytes.
 
   If the input is not compressible, the return value might be larger than
@@ -56,9 +56,9 @@ extern "C" {
 int fastlz_compress(const void* input, int length, void* output);
 
 /**
-  Decompress a block of compressed data and returns the size of the 
-  decompressed block. If error occurs, e.g. the compressed data is 
-  corrupted or the output buffer is not large enough, then 0 (zero) 
+  Decompress a block of compressed data and returns the size of the
+  decompressed block. If error occurs, e.g. the compressed data is
+  corrupted or the output buffer is not large enough, then 0 (zero)
   will be returned instead.
 
   The input buffer and the output buffer can not overlap.
@@ -67,14 +67,14 @@ int fastlz_compress(const void* input, i
   more than what is specified in maxout.
  */
 
-int fastlz_decompress(const void* input, int length, void* output, int maxout); 
+int fastlz_decompress(const void* input, int length, void* output, int maxout);
 
 /**
-  Compress a block of data in the input buffer and returns the size of 
-  compressed block. The size of input buffer is specified by length. The 
+  Compress a block of data in the input buffer and returns the size of
+  compressed block. The size of input buffer is specified by length. The
   minimum input buffer size is 16.
 
-  The output buffer must be at least 5% larger than the input buffer  
+  The output buffer must be at least 5% larger than the input buffer
   and can not be smaller than 66 bytes.
 
   If the input is not compressible, the return value might be larger than
@@ -82,14 +82,14 @@ int fastlz_decompress(const void* input,
 
   The input buffer and the output buffer can not overlap.
 
-  Compression level can be specified in parameter level. At the moment, 
+  Compression level can be specified in parameter level. At the moment,
   only level 1 and level 2 are supported.
   Level 1 is the fastest compression and generally useful for short data.
   Level 2 is slightly slower but it gives better compression ratio.
 
   Note that the compressed data, regardless of the level, can always be
   decompressed using the function fastlz_decompress above.
-*/  
+*/
 
 int fastlz_compress_level(int level, const void* input, int length, void* output);
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_aiocb.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_aiocb.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_aiocb.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_aiocb.h Thu May 13 07:09:39 2010
@@ -25,8 +25,8 @@
 
   Async Struct definition.
 
-  
-  
+
+
  ****************************************************************************/
 
 #ifndef _ink_aiocb_h_
@@ -49,7 +49,7 @@ typedef struct ink_aiocb
 #endif
   size_t aio_nbytes;            /* length of transfer */
 
-  // TODO change to off_t 
+  // TODO change to off_t
   ink_off_t aio_offset;         /* file offset */
 
   int aio_reqprio;              /* request priority offset */

Modified: trafficserver/traffic/trunk/libinktomi++/ink_args.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_args.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_args.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_args.h Thu May 13 07:09:39 2010
@@ -40,7 +40,7 @@ struct ArgumentDescription
 {
   const char *name;
   char key;
-  /* 
+  /*
      "I" = integer
      "L" = ink64
      "D" = double (floating point)

Modified: trafficserver/traffic/trunk/libinktomi++/ink_assert.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_assert.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_assert.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_assert.h Thu May 13 07:09:39 2010
@@ -64,11 +64,11 @@ extern "C"
 
 #endif /*_INK_ASSERT_H*/
 
-/* workaround a bug in the  stupid Sun preprocessor 
+/* workaround a bug in the  stupid Sun preprocessor
 
 #undef assert
 #define assert __DONT_USE_BARE_assert_USE_ink_assert__
-#define _ASSERT_H 
-#undef __ASSERT_H__ 
-#define __ASSERT_H__ 
+#define _ASSERT_H
+#undef __ASSERT_H__
+#define __ASSERT_H__
 */

Modified: trafficserver/traffic/trunk/libinktomi++/ink_atomic.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_atomic.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_atomic.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_atomic.h Thu May 13 07:09:39 2010
@@ -31,7 +31,7 @@
   the argument "-Wa,-xarch=v8plus" to get the assembler to emit V9
   instructions.
 
-  
+
  ****************************************************************************/
 
 #ifndef _ink_atomic_h_
@@ -111,7 +111,7 @@ extern "C"
 /*===========================================================================*
 
      Atomic Memory Operations
-  
+
  *===========================================================================*/
 
 /* atomic swap 32-bit value */

Modified: trafficserver/traffic/trunk/libinktomi++/ink_bool.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_bool.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_bool.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_bool.h Thu May 13 07:09:39 2010
@@ -28,12 +28,12 @@
    Last Modified By: Ivry Semel
    Last Modified On: Tue Dec 17 14:27:41 1996
    Update Count    : 3
-   Status          : 
+   Status          :
 
    Description:
    define type bool for the compilers that don't define it.
 
-   
+
  ****************************************************************************/
 #if !defined (_ink_bool_h_)
 #define _ink_bool_h_

Modified: trafficserver/traffic/trunk/libinktomi++/ink_config.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_config.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_config.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_config.h Thu May 13 07:09:39 2010
@@ -28,4 +28,4 @@
 // which matters e.g. when the manager specifically undef's HTTP_CACHE
 #include "config.h"
 
-#endif 
+#endif

Modified: trafficserver/traffic/trunk/libinktomi++/ink_exception.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_exception.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_exception.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_exception.h Thu May 13 07:09:39 2010
@@ -25,9 +25,9 @@
  *  ink_exception.h
  *
  *  Contains some global exception classes.
- *  
+ *
  *  $Date: 2003-06-01 18:36:43 $
- *  
+ *
  *
  */
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_hrtime.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_hrtime.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_hrtime.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_hrtime.h Thu May 13 07:09:39 2010
@@ -254,7 +254,7 @@ ink_hrtime_to_timeval2(ink_hrtime t, str
 }
 
 
-/* 
+/*
    using Jan 1 1970 as the base year, instead of Jan 1 1601,
    which translates to (365 + 0.25)369*24*60*60 seconds   */
 #define NT_TIMEBASE_DIFFERENCE_100NSECS 116444736000000000i64

Modified: trafficserver/traffic/trunk/libinktomi++/ink_inet.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_inet.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_inet.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_inet.cc Thu May 13 07:09:39 2010
@@ -44,7 +44,7 @@ ink_gethostbyname_r(char *hostname, ink_
 
 #else //RENTRENT_GETHOSTBYNAME
 #ifdef GETHOSTBYNAME_R_GLIBC2
-  
+
   struct hostent *addrp = NULL;
   int res = gethostbyname_r(hostname, &data->ent, data->buf,
                             INK_GETHOSTBYNAME_R_DATA_SIZE, &addrp,

Modified: trafficserver/traffic/trunk/libinktomi++/ink_inout.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_inout.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_inout.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_inout.h Thu May 13 07:09:39 2010
@@ -23,7 +23,7 @@
 
 /**************************************************************************
   I/O Marshalling
- 
+
 **************************************************************************/
 
 #ifndef _INOUT_H

Modified: trafficserver/traffic/trunk/libinktomi++/ink_lockfile.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_lockfile.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_lockfile.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_lockfile.h Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2006-03-31 04:25:35 $
  *
- * 
+ *
  */
 
 #ifndef __INK_LOCKFILE_H__

Modified: trafficserver/traffic/trunk/libinktomi++/ink_memory.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_memory.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_memory.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_memory.cc Thu May 13 07:09:39 2010
@@ -22,11 +22,11 @@
  */
 
 /****************************************************************************
- 
+
   ink_memory.c
- 
+
   Memory allocation routines for libinktomi.a.
- 
+
  ****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/trunk/libinktomi++/ink_mutex.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_mutex.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_mutex.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_mutex.h Thu May 13 07:09:39 2010
@@ -30,7 +30,7 @@
 
     Uses atomic memory operations to minimize blocking.
 
-    
+
 ***********************************************************************/
 #include <stdio.h>
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_queue.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_queue.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_queue.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_queue.cc Thu May 13 07:09:39 2010
@@ -22,18 +22,18 @@
  */
 
 /*****************************************************************************
-  ink_queue.cc (This used to be ink_queue.c) 
- 
+  ink_queue.cc (This used to be ink_queue.c)
+
   This implements an atomic push/pop queue, and the freelist memory
   pools that are built from it.
- 
-  The change from ink_queue.cc to ink_queue.c resulted in some changes 
+
+  The change from ink_queue.cc to ink_queue.c resulted in some changes
   in access and store of 64 bit values. This is standardized by using
   the INK_QUEUE_LD64 macro which loads the version before the pointer
   (independent of endianness of native architecture) on 32 bit platforms
   or loads the 64 bit quantity directory on the DECs.
- 
-  
+
+
   ****************************************************************************/
 
 #include "ink_config.h"
@@ -405,7 +405,7 @@ ink_freelist_free(InkFreeList * f, void 
 
     // search for DEADBEEF anywhere after a pointer offset in the item
     char *position = (char *) item + sizeof(void *);    // start
-    char *end = (char *) item + f->type_size;   // end 
+    char *end = (char *) item + f->type_size;   // end
 
     int i, j;
     for (i = sizeof(void *) & 0x3, j = 0; position < end; ++position) {

Modified: trafficserver/traffic/trunk/libinktomi++/ink_queue.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_queue.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_queue.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_queue.h Thu May 13 07:09:39 2010
@@ -31,7 +31,7 @@
     Uses atomic memory operations to avoid blocking.
     Intended as a replacement for llqueue.
 
-    
+
 ***********************************************************************/
 
 #include "ink_port.h"
@@ -86,7 +86,7 @@ extern "C"
  * Think of a list like this -> A -> C -> D
  * and you are popping from the list
  * Between the time you take the ptr(A) and swap the head pointer
- * the list could start looking like this 
+ * the list could start looking like this
  * -> A -> B -> C -> D
  * If the version check is not there, the list will look like
  * -> C -> D after the pop, which will result in the loss of "B"

Modified: trafficserver/traffic/trunk/libinktomi++/ink_queue_utils.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_queue_utils.c?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_queue_utils.c (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_queue_utils.c Thu May 13 07:09:39 2010
@@ -31,38 +31,38 @@
 /*
  * This file was added during the debugging of Bug 50475.
  * It was found that a race condition was introduced on the sparc architecture
- * when the ink_queue.c file was moved over to ink_queue.cc. Debugging this 
- * problem resulted in the discovery that gcc was spitting out the 
+ * when the ink_queue.c file was moved over to ink_queue.cc. Debugging this
+ * problem resulted in the discovery that gcc was spitting out the
  * "ldd" (load double) instruction for loading of the 64 bit field "data"
  * while CC was spitting out two "ld" (load) instructions. The old code
  * was calling item.data = head.data on sparcs and not putting any restriction
  * on the order of loading of the fields.
  *
  * This is a problem on the sparcs because the "pointer" field was being loaded
- * before the "version" field. This can result in a very subtle race condition 
+ * before the "version" field. This can result in a very subtle race condition
  * which subverts the addition of the "version" field.
- * 
+ *
  * Take this scenario
- * item.ptr = head.ptr 
- * (call to ink_freelist_new ) 
+ * item.ptr = head.ptr
+ * (call to ink_freelist_new )
  * next.ptr = *(item.ptr) <---- Error
- * (call to ink_freelist_free ) 
+ * (call to ink_freelist_free )
  * item.version = head.version
  * next.version = item.version ++;
  * cas64(head, item, next)
 
  * Note, that the cas64 call will be succesful and the next.ptr will probably
  * be a pointer into the vtable entry. The next alloc will result in a write into
- * the vtable area. 
+ * the vtable area.
  *
  * The fix for this problem is to read the version before reading the pointer
- * on 32 bit architectures (currently everything other than alphas). This is 
+ * on 32 bit architectures (currently everything other than alphas). This is
  * done using the following function. This file only contains one function
  * to make looking at the assembly code simple.
  *
- * If you ever change the compiler or the compiler options to this file, make 
+ * If you ever change the compiler or the compiler options to this file, make
  * sure you look at the assembly generated to see if the version is read first.
- * Also, make sure that you run the test_freelist microbenchmark for at least 
+ * Also, make sure that you run the test_freelist microbenchmark for at least
  * 24 hours on a dual processor box.
  */
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_res_init.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc Thu May 13 07:09:39 2010
@@ -115,7 +115,7 @@ static void
 ink_res_nclose(ink_res_state statp) {
   int ns;
 
-  if (statp->_vcsock >= 0) { 
+  if (statp->_vcsock >= 0) {
     (void) close(statp->_vcsock);
     statp->_vcsock = -1;
     statp->_flags &= ~(INK_RES_F_VC | INK_RES_F_CONN);
@@ -185,7 +185,7 @@ ink_res_setservers(ink_res_state statp, 
     set++;
   }
   statp->nscount = nserv;
-	
+
 }
 
 int
@@ -197,7 +197,7 @@ ink_res_getservers(ink_res_state statp, 
   for (i = 0; i < statp->nscount && i < cnt; i++) {
     if (statp->_u._ext.ext)
       family = statp->_u._ext.ext->nsaddrs[i].sin.sin_family;
-    else 
+    else
       family = statp->nsaddr_list[i].sin_family;
 
     switch (family) {
@@ -411,7 +411,7 @@ ink_res_get_nibblesuffix2(ink_res_state 
  * since it was noted that INADDR_ANY actually meant ``the first interface
  * you "ifconfig"'d at boot time'' and if this was a SLIP or PPP interface,
  * it had to be "up" in order for you to reach your own name server.  It
- * was later decided that since the recommended practice is to always 
+ * was later decided that since the recommended practice is to always
  * install local static routes through 127.0.0.1 for all your network
  * interfaces, that we could solve this problem without a code change.
  *
@@ -567,7 +567,7 @@ ink_res_init(ink_res_state statp, unsign
     *cp = '\0';
     *pp++ = 0;
   }
-        
+
   /* ---------------------------------------------
      Default domain name and doamin Search list:
 
@@ -760,11 +760,11 @@ ink_res_init(ink_res_state statp, unsign
               if (inet_aton(net, &a)) {
                 statp->sort_list[nsort].mask = a.s_addr;
               } else {
-                statp->sort_list[nsort].mask = 
+                statp->sort_list[nsort].mask =
                   net_mask(statp->sort_list[nsort].addr);
               }
             } else {
-              statp->sort_list[nsort].mask = 
+              statp->sort_list[nsort].mask =
                 net_mask(statp->sort_list[nsort].addr);
             }
             nsort++;
@@ -779,7 +779,7 @@ ink_res_init(ink_res_state statp, unsign
         continue;
       }
     }
-    if (nserv > 0) 
+    if (nserv > 0)
       statp->nscount = nserv;
 #ifdef RESOLVSORT
     statp->nsort = nsort;

Modified: trafficserver/traffic/trunk/libinktomi++/ink_res_mkquery.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_res_mkquery.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_res_mkquery.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_res_mkquery.cc Thu May 13 07:09:39 2010
@@ -1,7 +1,7 @@
 /*
  * Copyright (c) 1985, 1993
  *    The Regents of the University of California.  All rights reserved.
- * 
+ *
  * Redistribution and use in source and binary forms, with or without
  * modification, are permitted provided that the following conditions
  * are met:
@@ -13,7 +13,7 @@
  * 3. Neither the name of the University nor the names of its contributors
  *    may be used to endorse or promote products derived from this software
  *    without specific prior written permission.
- * 
+ *
  * THIS SOFTWARE IS PROVIDED BY THE REGENTS AND CONTRIBUTORS ``AS IS'' AND
  * ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE
  * IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE
@@ -29,14 +29,14 @@
 
 /*
  * Portions Copyright (c) 1993 by Digital Equipment Corporation.
- * 
+ *
  * Permission to use, copy, modify, and distribute this software for any
  * purpose with or without fee is hereby granted, provided that the above
  * copyright notice and this permission notice appear in all copies, and that
  * the name of Digital Equipment Corporation not be used in advertising or
  * publicity pertaining to distribution of the document or software without
  * specific, written prior permission.
- * 
+ *
  * THE SOFTWARE IS PROVIDED "AS IS" AND DIGITAL EQUIPMENT CORP. DISCLAIMS ALL
  * WARRANTIES WITH REGARD TO THIS SOFTWARE, INCLUDING ALL IMPLIED WARRANTIES
  * OF MERCHANTABILITY AND FITNESS.   IN NO EVENT SHALL DIGITAL EQUIPMENT
@@ -254,7 +254,7 @@ decode_bitstring(const unsigned char **c
 	} else if (b > 0) {
 		tc = *cp++;
 		i = SPRINTF((dn, "%1x",
-			       ((tc >> 4) & 0x0f) & (0x0f << (4 - b)))); 
+			       ((tc >> 4) & 0x0f) & (0x0f << (4 - b))));
 		if (i < 0)
 			return (-1);
 		dn += i;
@@ -350,7 +350,7 @@ ink_ns_name_ntop(const u_char *src, char
 				errno = EMSGSIZE;
 				return(-1);
 			}
-			dn += m; 
+			dn += m;
 			continue;
 		}
 		for ((void)NULL; l > 0; l--) {
@@ -452,7 +452,7 @@ ns_name_ntop(const u_char *src, char *ds
 				errno = EMSGSIZE;
 				return(-1);
 			}
-			dn += m; 
+			dn += m;
 			continue;
 		}
 		for ((void)NULL; l > 0; l--) {

Modified: trafficserver/traffic/trunk/libinktomi++/ink_sock.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_sock.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_sock.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_sock.cc Thu May 13 07:09:39 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
   Socket operations
 
-  
+
 
 ***************************************************************************/
 #include "inktomi++.h"
@@ -33,7 +33,7 @@
 
 //
 // Compilation options
-// 
+//
 
 // #define CHECK_PLAUSIBILITY_OF_SOCKADDR
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_sock.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_sock.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_sock.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_sock.h Thu May 13 07:09:39 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
   Socket operations
 
-  
+
 
 ***************************************************************************/
 #if !defined (_ink_sock_h_)

Modified: trafficserver/traffic/trunk/libinktomi++/ink_sprintf.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_sprintf.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_sprintf.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_sprintf.cc Thu May 13 07:09:39 2010
@@ -22,13 +22,13 @@
  */
 
 /*****************************************************************************
-  
+
   ink_sprintf.cc
 
   This file implements some Inktomi variants of sprintf, to do bounds
   checking and length counting.
 
-  
+
   ****************************************************************************/
 
 #include "ink_sprintf.h"

Modified: trafficserver/traffic/trunk/libinktomi++/ink_sprintf.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_sprintf.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_sprintf.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_sprintf.h Thu May 13 07:09:39 2010
@@ -22,13 +22,13 @@
  */
 
 /*****************************************************************************
-  
+
   ink_sprintf.h
 
   This file implements some Inktomi variants of sprintf, to do bounds
   checking and length counting.
 
-  
+
   ****************************************************************************/
 
 #ifndef _ink_sprintf_h_

Modified: trafficserver/traffic/trunk/libinktomi++/ink_string++.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_string%2B%2B.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_string++.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_string++.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   C++ support for string manipulation.
 
-  
+
  ****************************************************************************/
 
 #include "inktomi++.h"

Modified: trafficserver/traffic/trunk/libinktomi++/ink_string++.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_string%2B%2B.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_string++.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_string++.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   C++ support for string manipulation.
 
-  
+
  ****************************************************************************/
 
 #if !defined (_ink_string_pp_h_)

Modified: trafficserver/traffic/trunk/libinktomi++/ink_string.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_string.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_string.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_string.cc Thu May 13 07:09:39 2010
@@ -22,11 +22,11 @@
  */
 
 /****************************************************************************
- 
+
   ink_string.c
- 
+
   String and text processing routines for libinktomi.a.
- 
+
  ****************************************************************************/
 
 #include "inktomi++.h"   /* MAGIC_EDITING_TAG */
@@ -40,14 +40,14 @@
 #define INK_MAX_STRING_ARRAY_SIZE 128
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_strncpy(char *dest, char *src, int n)
- 
+
   This routine is a safer version of strncpy which always NUL terminates
   the destination string.  Note that this routine has the SAME semantics
   as strncpy, such as copying exactly n bytes, padding dest with NULs
   is necessary.  Use ink_string_copy for a non-padding version.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -65,13 +65,13 @@ ink_strncpy(char *dest, const char *src,
 
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_string_concatenate_strings(char *dest, ...)
- 
+
   This routine concatenates a variable number of strings into the buffer
   <dest>, returning the pointer to <dest>.  The sequence of strings must end
   with NULL.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -99,14 +99,14 @@ ink_string_concatenate_strings(char *des
 
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_string_concatenate_strings_n(char *dest, int n, ...)
- 
+
   This routine concatenates a variable number of strings into the buffer
   <dest>, returning the pointer to <dest>.  The sequence of strings must end
   with NULL.  A NUL will always be placed after <dest>, and no more than
   <n> - 1 characters will ever be written to <dest>.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -136,13 +136,13 @@ ink_string_concatenate_strings_n(char *d
 
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_string_append(char *dest, char *src, int n)
- 
+
   This routine appends <src> to the end of <dest>, but it insures the
   string pointed to by <dest> never grows beyond <n> characters, including
   the terminating NUL.  A NUL is always written if n > 0.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -188,12 +188,12 @@ ink_string_append(char *dest, char *src,
 
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_string_duplicate(char *ptr)
- 
+
   This routine allocates memory for the string <ptr>, and copies the string
   into the new buffer.  The pointer to the new buffer is returned.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -211,14 +211,14 @@ ink_string_duplicate(char *ptr)
 
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_string_find_dotted_extension(char *str, char *ext, int max_ext_len)
- 
+
   This routine takes a string <str>, copies the period-separated extension to
   <ext> (up to <max_ext_len - 1> characters) NUL terminates <ext>, and
   returns a pointer into the string <str> where the '.' of the extension
   begins, or NULL if there is no extension.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -243,18 +243,18 @@ ink_string_find_dotted_extension(char *s
 }                               /* End ink_string_find_dotted_extension */
 
 /*---------------------------------------------------------------------------*
- 
-  char *ink_string_mpath(int nstrings, char *str1, bool free1, 
+
+  char *ink_string_mpath(int nstrings, char *str1, bool free1,
     char *str2, bool free2, ...);
- 
-  This routine joins multiple path components together to make 
+
+  This routine joins multiple path components together to make
   a new path.  Each component can optionally start with a / in which
   case all the preceeding components are ignored.
- 
+
   Each component can optionally be free()d.
- 
+
   Space is malloc()d to hold the resulting path.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -317,11 +317,11 @@ ink_string_mpath(int nstrings, ...)
 }
 
 /*---------------------------------------------------------------------------*
- 
+
   char *ink_string_mcopy(char *source);
- 
+
   This simply makes a copy of a string into freshly malloc()ed space.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -338,15 +338,15 @@ ink_string_mcopy(char *source)
 }
 
 /*---------------------------------------------------------------------------*
- 
-  char *ink_string_mjoin(int nstrings, char *str1, bool free1, 
+
+  char *ink_string_mjoin(int nstrings, char *str1, bool free1,
     char *str2, bool free2, ...);
- 
-  This routine joins multiple strings components together to make 
+
+  This routine joins multiple strings components together to make
   a new string.  Each component can optionally be free()d.
- 
+
   Space is malloc()d to hold the resulting path.
- 
+
  *---------------------------------------------------------------------------*/
 
 char *
@@ -443,9 +443,9 @@ ink_utf8_to_latin1(const char *in, int i
   inbytesleft = inlen;
   outbytesleft = *outlen;
 #if (HOST_OS == freebsd) || (HOST_OS == solaris)
-  if (iconv(ic, &in, &inbytesleft, &out, &outbytesleft) == (size_t) - 1) 
+  if (iconv(ic, &in, &inbytesleft, &out, &outbytesleft) == (size_t) - 1)
 #else
-  if (iconv(ic, (char **) &in, &inbytesleft, &out, &outbytesleft) == (size_t) - 1) 
+  if (iconv(ic, (char **) &in, &inbytesleft, &out, &outbytesleft) == (size_t) - 1)
 #endif
     {
       iconv_close(ic);

Modified: trafficserver/traffic/trunk/libinktomi++/ink_string.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_string.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_string.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_string.h Thu May 13 07:09:39 2010
@@ -58,8 +58,8 @@ inkcoreapi char *ink_string_find_dotted_
 
 /* these are supposed to make your life easier */
 
-/* 
- * the results of all of these are put in freshly malloc()ed memory 
+/*
+ * the results of all of these are put in freshly malloc()ed memory
  */
 
         /*
@@ -70,7 +70,7 @@ char *ink_string_mpath(int nstrings, ...
          * s = ink_string_mcopy(old);
          */
 char *ink_string_mcopy(char *source);
-        /* 
+        /*
          *  s = ink_string_mjoin(2, "/foo", false, "/bar", false);
          */
 char *ink_string_mjoin(int nstrings, ...);
@@ -649,7 +649,7 @@ ptr_len_cmp(const char *p1, int l1, cons
 }
 
 // char* ptr_len_pbrk(const char* p1, int l1, const char* str)
-// 
+//
 //   strpbrk() like functionality for ptr & len pair strings
 //
 inline char *

Modified: trafficserver/traffic/trunk/libinktomi++/ink_syslog.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_syslog.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_syslog.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_syslog.cc Thu May 13 07:09:39 2010
@@ -25,8 +25,8 @@
 /****************************************************************************
  *
  *  ink_syslog.cc
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_syslog.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_syslog.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_syslog.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_syslog.h Thu May 13 07:09:39 2010
@@ -25,8 +25,8 @@
 /****************************************************************************
  *
  *  ink_syslog.h
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #ifndef _INK_SYSLOG_H_

Modified: trafficserver/traffic/trunk/libinktomi++/ink_thread.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_thread.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_thread.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_thread.cc Thu May 13 07:09:39 2010
@@ -22,9 +22,9 @@
  */
 
 /**************************************************************************
- 
+
   ink_thread.cc
- 
+
   Generic threads interface.
 **************************************************************************/
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_thread.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_thread.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_thread.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_thread.h Thu May 13 07:09:39 2010
@@ -226,7 +226,7 @@ ink_sem_destroy(ink_sem * sp)
 }
 
 #if (HOST_OS == darwin)
-static inline ink_sem * 
+static inline ink_sem *
 ink_sem_open(const char *name , int oflag, mode_t mode, unsigned int value)
 {
   ink_sem *sptr;

Modified: trafficserver/traffic/trunk/libinktomi++/ink_time.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_time.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_time.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_time.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   Timing routines for libinktomi.a.
 
-  
+
 
  ****************************************************************************/
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_time.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_time.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_time.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_time.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   Timing routines for libinktomi.a.
 
-  
+
 
  ****************************************************************************/
 

Modified: trafficserver/traffic/trunk/libinktomi++/little_endian.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/little_endian.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/little_endian.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/little_endian.h Thu May 13 07:09:39 2010
@@ -39,14 +39,14 @@
   little_endian.h
 
   Contains implementation of inkuXX_to_le to functions that convert's known host order
-  to little endian order. If you don't know the "endianness" of your host, you may 
+  to little endian order. If you don't know the "endianness" of your host, you may
   want to use the LittleEndianBuffer class defined below.
 
   Contains implementation of class LittleEndianBuffer, which implements storing/loading
-  primitive types like char,int,short to/from a buffer stored in little indian order. 
-  That means variables in host order are converted to little indian before storing it on 
-  the buffer and variables from the buffer are converted to host order when loading. An 
-  example of its use (and a test to check that it works) is at the bottom of the file. 
+  primitive types like char,int,short to/from a buffer stored in little indian order.
+  That means variables in host order are converted to little indian before storing it on
+  the buffer and variables from the buffer are converted to host order when loading. An
+  example of its use (and a test to check that it works) is at the bottom of the file.
 
  ****************************************************************************/
 
@@ -286,7 +286,7 @@ LittleEndianBuffer::store(int i, inku32 
      inku32 intuY = intuX;
 
      int i;
-     
+
      i =0;
      i = Buff.store(i,shortX);
      i = Buff.store(i,intX);
@@ -312,10 +312,10 @@ LittleEndianBuffer::store(int i, inku32 
        printf("You are hosed, shortu!\n");
      i+=sizeof(inku16);
      Buff.load(i,intuX);
-     if (intuY != intuX) 
+     if (intuY != intuX)
        printf("You are hosed, intu!\n");
 
-     if (shortY != shortX || shortuY != shortuX || intY != intX || intuY != intuX) 
+     if (shortY != shortX || shortuY != shortuX || intY != intX || intuY != intuX)
        printf("You are hosed!\n");
      else
        printf("You may be still be hosed, but I have no proof\n");

Modified: trafficserver/traffic/trunk/libinktomi++/llqueue.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/llqueue.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/llqueue.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/llqueue.cc Thu May 13 07:09:39 2010
@@ -184,23 +184,23 @@ queue_highwater(LLQ * Q)
 
 
 
-/* 
+/*
  *---------------------------------------------------------------------------
  *
  * queue_is_empty
- *  
+ *
  *  Is the queue empty?
- *  
+ *
  * Results:
  *  nonzero if empty, zero else.
- *  
+ *
  * Side Effects:
  *  none.
- *  
+ *
  * Reentrancy:     n/a.
  * Thread Safety:  safe.
  * Mem Management: n/a.
- *  
+ *
  *---------------------------------------------------------------------------
  */
 int

Modified: trafficserver/traffic/trunk/libinktomi++/load_http_hdr.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/load_http_hdr.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/load_http_hdr.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/load_http_hdr.cc Thu May 13 07:09:39 2010
@@ -29,7 +29,7 @@
 
    Opens a file with a dbx dump of an http hdr and prints it out
 
-   
+
  ****************************************************************************/
 
 #include "Marshal.h"

Modified: trafficserver/traffic/trunk/libinktomi++/ptrdef.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ptrdef.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ptrdef.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ptrdef.h Thu May 13 07:09:39 2010
@@ -21,15 +21,15 @@
   limitations under the License.
  */
 
-/* ------------------------------------------------------------------------- */  
-/* -                             PTRDEF.H                                  - */ 
-/* ------------------------------------------------------------------------- */ 
- 
-  
+/* ------------------------------------------------------------------------- */
+/* -                             PTRDEF.H                                  - */
+/* ------------------------------------------------------------------------- */
+
+
 #ifndef H_PTRDEF_H
 #define H_PTRDEF_H
-  
-/* lv: special typedef for pointer to integer conversion in order to avoid incorrect cast in 64 bit case. */ 
+
+/* lv: special typedef for pointer to integer conversion in order to avoid incorrect cast in 64 bit case. */
 #ifdef __WORDSIZE
 #if (__WORDSIZE == 64) || (__WORDSIZE == 32)
 #if (__WORDSIZE == 64)
@@ -53,5 +53,5 @@ typedef unsigned  __PTRDIFF_TYPE__ int_p
 #endif /* __PTRDIFF_TYPE__ */
 #endif /* _LP64 */
 #endif  /* #ifdef __WORDSIZE  */
-  
+
 #endif  /* #ifndef H_PTRDEF_H */

Modified: trafficserver/traffic/trunk/libinktomi++/test_List.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/test_List.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/test_List.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/test_List.cc Thu May 13 07:09:39 2010
@@ -28,22 +28,22 @@ class Foo { public:
   int x;
 
   virtual void foo() {}
-  
+
   SLINK(Foo, slink);
   LINK(Foo, dlink);
-  
+
   Foo(int i = 0): x(i) {}
 };
 
 int main() {
-   SList(Foo,slink) s; 
-   DList(Foo,dlink) d; 
-   Que(Foo,dlink) q; 
+   SList(Foo,slink) s;
+   DList(Foo,dlink) d;
+   Que(Foo,dlink) q;
    Foo *f = new Foo;
    f->x = 7;
    s.push(f);
    d.push(s.pop());
-   q.enqueue(d.pop()); 
+   q.enqueue(d.pop());
    for (int i = 0; i < 100; i++)
      q.enqueue(new Foo(i));
    int tot = 0;

Modified: trafficserver/traffic/trunk/libinktomi++/test_arena.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/test_arena.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/test_arena.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/test_arena.cc Thu May 13 07:09:39 2010
@@ -30,7 +30,7 @@
    A short test program intended to be used with Purify to detect problems
    with the arnea code
 
-   
+
  ****************************************************************************/
 
 #include "Arena.h"

Modified: trafficserver/traffic/trunk/libinktomi++/test_atomic.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/test_atomic.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/test_atomic.cc (original)
+++ trafficserver/traffic/trunk/libinktomi++/test_atomic.cc Thu May 13 07:09:39 2010
@@ -25,14 +25,14 @@
 
 ////////////////////////////////////////////////////////////////////////////
 // NT Build Notes:
-//   1) Enable the following #include. 
+//   1) Enable the following #include.
 //      Visual C++ does not allow this under #ifdef
 // #include "stdafx.h"
 //
 //   2) Create a new project within the existing TS project
-//      which is a "WIN32 Console Application"    
+//      which is a "WIN32 Console Application"
 //      with the "Simple Application" option.
-//   3) Replace C/C++ Preprocessor definitions with traffic_server 
+//   3) Replace C/C++ Preprocessor definitions with traffic_server
 //      definitions.
 //   4) Replace C/C++ Additional includes with traffic server
 //      definitions.  Prepend "..\proxy" to directories in proxy.

Modified: trafficserver/traffic/trunk/librecords/I_RecCore.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/I_RecCore.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/I_RecCore.h (original)
+++ trafficserver/traffic/trunk/librecords/I_RecCore.h Thu May 13 07:09:39 2010
@@ -247,7 +247,7 @@ int RecResetStatRecord(char *name);
 int RecResetStatRecord(RecT type = RECT_NULL);
 
 //------------------------------------------------------------------------
-// Set RecRecord attributes 
+// Set RecRecord attributes
 //------------------------------------------------------------------------
 int RecSetSyncRequired(char *name, bool lock = true);
 

Modified: trafficserver/traffic/trunk/librecords/I_RecDefs.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/I_RecDefs.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/I_RecDefs.h (original)
+++ trafficserver/traffic/trunk/librecords/I_RecDefs.h Thu May 13 07:09:39 2010
@@ -92,7 +92,7 @@ enum RecPersistT
 enum RecUpdateT
 {
   RECU_NULL,                    // default: don't know the behavior
-  RECU_DYNAMIC,                 // config can be updated dynamically w/ traffic_line -x 
+  RECU_DYNAMIC,                 // config can be updated dynamically w/ traffic_line -x
   RECU_RESTART_TS,              // config requires TS to be restarted to take effect
   RECU_RESTART_TM,              // config requires TM/TS to be restarted to take effect
   RECU_RESTART_TC               // config requires TC/TM/TS to be restarted to take effect

Modified: trafficserver/traffic/trunk/librecords/P_RecDefs.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/P_RecDefs.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/P_RecDefs.h (original)
+++ trafficserver/traffic/trunk/librecords/P_RecDefs.h Thu May 13 07:09:39 2010
@@ -155,7 +155,7 @@ struct RecMessageHdr
   int o_write;
   int o_end;
   int entries;
-  int alignment;                //needs to be 8 byte aligned 
+  int alignment;                //needs to be 8 byte aligned
 };
 
 struct RecMessageEleHdr

Modified: trafficserver/traffic/trunk/librecords/RecCore.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/RecCore.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/RecCore.cc (original)
+++ trafficserver/traffic/trunk/librecords/RecCore.cc Thu May 13 07:09:39 2010
@@ -212,7 +212,7 @@ RecCoreInit(RecModeT mode_type, Diags *_
     g_stats_snap_fpath = REC_RAW_STATS_DIR REC_RAW_STATS_FILE;
     RecReadStatsFile();
   }
-  // read configs  
+  // read configs
   if ((mode_type == RECM_SERVER) || (mode_type == RECM_STAND_ALONE)) {
     ink_mutex_init(&g_rec_config_lock, NULL);
     g_rec_config_contents_llq = create_queue();

Modified: trafficserver/traffic/trunk/librecords/RecMessage.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/RecMessage.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/RecMessage.cc (original)
+++ trafficserver/traffic/trunk/librecords/RecMessage.cc Thu May 13 07:09:39 2010
@@ -568,7 +568,7 @@ RecMessageWriteToDisk(RecMessage *msg, c
 
 //
 // [hack for tsunami, bevans] -- I need this exported to the ACC module somehow,
-// the acc module can't include stuff out put proxy/ or mgmt2/ 
+// the acc module can't include stuff out put proxy/ or mgmt2/
 //
 int
 RecAlarmSignal(int code, const char *msg, int msg_size)

Modified: trafficserver/traffic/trunk/librecords/RecProcess.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/RecProcess.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/RecProcess.cc (original)
+++ trafficserver/traffic/trunk/librecords/RecProcess.cc Thu May 13 07:09:39 2010
@@ -319,7 +319,7 @@ RecProcessInit(RecModeT mode_type, Diags
    ink_mutex_init(&g_force_req_mutex, NULL);
    if (mode_type == RECM_CLIENT) {
    send_pull_message(RECG_PULL_REQ);
-   ink_cond_wait(&g_force_req_cond, &g_force_req_mutex); 
+   ink_cond_wait(&g_force_req_cond, &g_force_req_mutex);
    ink_mutex_release(&g_force_req_mutex);
    }
    */

Modified: trafficserver/traffic/trunk/librecords/RecTree.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/RecTree.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/RecTree.cc (original)
+++ trafficserver/traffic/trunk/librecords/RecTree.cc Thu May 13 07:09:39 2010
@@ -87,7 +87,7 @@ RecTree::RecTree(RecTreeNode * n)
 
 
 /*************************************************************************
- *									  
+ *
  *************************************************************************/
 void
 RecTree::rec_tree_insert(const char *var_name, const char *var_name_ptr)
@@ -155,7 +155,7 @@ RecTree::rec_tree_insert(const char *var
 
 
 /*************************************************************************
- *									  
+ *
  *************************************************************************/
 void
 RecTree::print()
@@ -167,7 +167,7 @@ RecTree::print()
 
 
 /*************************************************************************
- *									  
+ *
  *************************************************************************/
 RecTree *
 RecTree::rec_tree_get(char *path_name)
@@ -219,7 +219,7 @@ RecTree::rec_tree_get(char *path_name)
 
 /*************************************************************************
  * rec_tree_get_list
- *     
+ *
  *************************************************************************/
 void
 RecTree::rec_tree_get_list(char *path_name, char ***buf, int *count)

Modified: trafficserver/traffic/trunk/librecords/test_I_RecLocal.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/librecords/test_I_RecLocal.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/librecords/test_I_RecLocal.cc (original)
+++ trafficserver/traffic/trunk/librecords/test_I_RecLocal.cc Thu May 13 07:09:39 2010
@@ -34,7 +34,7 @@ void RecDumpRecordsHt(RecT rec_type);
 //-------------------------------------------------------------------------
 // Test01: Callback Test
 //
-// The following test verifies that the callbacks are executed. 
+// The following test verifies that the callbacks are executed.
 //-------------------------------------------------------------------------
 int g_config_update_result = 0;
 

Modified: trafficserver/traffic/trunk/proxy/AbstractBuffer.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/AbstractBuffer.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/AbstractBuffer.cc (original)
+++ trafficserver/traffic/trunk/proxy/AbstractBuffer.cc Thu May 13 07:09:39 2010
@@ -245,8 +245,8 @@ AbstractBuffer::flush_complete()
   VolatileState old_vs;
   VolatileState new_vs;
 
-  /* INKqa06826 - Race Condition. Must make sure that setting the new state is 
-     atomic. If there is a context switch in the middle of setting the state to 
+  /* INKqa06826 - Race Condition. Must make sure that setting the new state is
+     atomic. If there is a context switch in the middle of setting the state to
      AB_STATE_FLUSH_COMPLETE, the checkin_read would be lost, the reader_count
      will never go to 0, resulting in memory leak */
 

Modified: trafficserver/traffic/trunk/proxy/CacheControl.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/CacheControl.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/CacheControl.h (original)
+++ trafficserver/traffic/trunk/proxy/CacheControl.h Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
  *
  *  CacheControl.h - Interface to Cache Control systtem
  *
- * 
+ *
  ****************************************************************************/
 
 #ifndef _CACHE_CONTROL_H_
@@ -63,7 +63,7 @@ public:
   void Print();
 
   // Data for external use
-  // 
+  //
   //   Describes the cache-control for a specific URL
   //
   int revalidate_after;

Modified: trafficserver/traffic/trunk/proxy/CacheInspectorAllow.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/CacheInspectorAllow.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/CacheInspectorAllow.h (original)
+++ trafficserver/traffic/trunk/proxy/CacheInspectorAllow.h Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
  *
  *  CacheInspectorAllow.h - Interface to IP Access Control systtem
  *
- * 
+ *
  ****************************************************************************/
 
 #ifndef _CACHE_INSPECTOR_ALLOW_H_

Modified: trafficserver/traffic/trunk/proxy/CheckStats.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/CheckStats.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/CheckStats.cc (original)
+++ trafficserver/traffic/trunk/proxy/CheckStats.cc Thu May 13 07:09:39 2010
@@ -29,12 +29,12 @@
  than it does now. This is because the completely ayshronous nature of
  the execution model forbids most of these asserts from being of use.
 
- This is also partly as a consequence of the fact that this function 
+ This is also partly as a consequence of the fact that this function
  is called from within the SnapShotsContinuation function, which may
  execute at any time. So since the asserts may fire between consecutive
  stat updates, the asserts may not hold.
 
- 
+
  ***************************************************************************/
 #include "ink_unused.h"      /* MAGIC_EDITING_TAG */
 #include "Error.h"
@@ -163,11 +163,11 @@ check_stats()
     syslog(LOG_WARNING, "Http Engine: COUNT(cache_connection_start) < COUNT(cache_connections_current_count)");
 
   /* http - transactions count */
-//   debug_tag_assert("checkstats", STATCOUNT(http_stats_user_agent_transactions_start) >= 
+//   debug_tag_assert("checkstats", STATCOUNT(http_stats_user_agent_transactions_start) >=
 //           STATCOUNT(http_stats_user_agent_connection_start));
-//   debug_tag_assert("checkstats", STATCOUNT(http_stats_origin_server_transactions_start) >= 
+//   debug_tag_assert("checkstats", STATCOUNT(http_stats_origin_server_transactions_start) >=
 //           STATCOUNT(http_stats_origin_server_connection_start));
-//   debug_tag_assert("checkstats", STATCOUNT(http_stats_parent_proxy_transactions_start) >= 
+//   debug_tag_assert("checkstats", STATCOUNT(http_stats_parent_proxy_transactions_start) >=
 //           STATCOUNT(http_stats_parent_proxy_connection_start));
   if (!(STATCOUNT(http_stats_user_agent_transactions_current_count) >= 0))
     syslog(LOG_WARNING, "Http Transactions: user_agent_transactions_current_count < 0");

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

Modified: trafficserver/traffic/trunk/proxy/ClusterHashStandalone.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ClusterHashStandalone.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ClusterHashStandalone.h (original)
+++ trafficserver/traffic/trunk/proxy/ClusterHashStandalone.h Thu May 13 07:09:39 2010
@@ -25,12 +25,12 @@
 
   ClusterHashStandalone.h
 
-  
+
  ****************************************************************************/
 
 /*
   Takes: escapified URL: http://www.foo.com/lookup?some+thing+to+find
-  Returns: the machine IP address or -1 (0xFFFFFFFF) on error 
+  Returns: the machine IP address or -1 (0xFFFFFFFF) on error
   */
 unsigned int standalone_machine_hash(char *url);
 

Modified: trafficserver/traffic/trunk/proxy/ConfigParse.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ConfigParse.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ConfigParse.h (original)
+++ trafficserver/traffic/trunk/proxy/ConfigParse.h Thu May 13 07:09:39 2010
@@ -27,8 +27,8 @@
 /****************************************************************************
  *
  *  ConfigParse.h -  Prototype for parsing functions in libpreparse.a
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 char *parseStorageFile(FILE * fp);

Modified: trafficserver/traffic/trunk/proxy/ControlBase.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ControlBase.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ControlBase.cc (original)
+++ trafficserver/traffic/trunk/proxy/ControlBase.cc Thu May 13 07:09:39 2010
@@ -438,7 +438,7 @@ error:
 //
 //   Wrapper to Parse out the src ip range
 //
-//   On success, sets *opaque_ptr to a malloc allocated ipMod 
+//   On success, sets *opaque_ptr to a malloc allocated ipMod
 //      structure and returns NULL
 //   On failure, returns a static error string
 //
@@ -465,7 +465,7 @@ ControlBase::ProcessSrcIp(char *val, voi
 //
 //   On success, sets *seconds to number of seconds since midnight
 //      represented by time_str and returns NULL
-//      
+//
 //   On failure, returns a static error string
 //
 const char *
@@ -507,7 +507,7 @@ TODtoSeconds(const char *time_str, time_
 //
 //   Parse out a time of day range.
 //
-//   On success, sets *opaque_ptr to a malloc allocated timeMod 
+//   On success, sets *opaque_ptr to a malloc allocated timeMod
 //      structure and returns NULL
 //   On failure, returns a static error string
 //

Modified: trafficserver/traffic/trunk/proxy/CoreUtils.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/CoreUtils.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/CoreUtils.h (original)
+++ trafficserver/traffic/trunk/proxy/CoreUtils.h Thu May 13 07:09:39 2010
@@ -133,10 +133,10 @@ class CoreUtils
 public:
 
   /**********************************************************************
-  * purpose: finds the index of the virtual address or finds what the 
+  * purpose: finds the index of the virtual address or finds what the
   *          index should be if the virtual address is not there
   * inputs: int vaddr, int upper, int lower
-  * outputs: returns the index of the vaddr or the index after where it 
+  * outputs: returns the index of the vaddr or the index after where it
   *          should be
   * notes: upper and lower stands for the lowest and highest indices
   *        the function should search between
@@ -192,7 +192,7 @@ public:
 #endif
 
   /**********************************************************************
-  * purpose: returns the base core_stack_state for the given thread id 
+  * purpose: returns the base core_stack_state for the given thread id
   * inputs: int threadId, core_stack_state* coress
   * outputs: returns the base core_stack_state for the given thread id
   **********************************************************************/
@@ -265,7 +265,7 @@ public:
 #endif
 
   /**********************************************************************
-  * purpose: fills in the given HTTPHdr * live_hdr with live information 
+  * purpose: fills in the given HTTPHdr * live_hdr with live information
   *          take from core_hdr the core file
   * inputs: HTTPHdr* core_hdr, HTTPHdr* live_hdr
   * outputs: -1 on failure or total bytes in the header heaps

Modified: trafficserver/traffic/trunk/proxy/DiagsConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/DiagsConfig.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/DiagsConfig.cc (original)
+++ trafficserver/traffic/trunk/proxy/DiagsConfig.cc Thu May 13 07:09:39 2010
@@ -328,7 +328,7 @@ DiagsConfig::DiagsConfig(char *bdt, char
         snprintf(system_log_dir, sizeof(system_log_dir), "%s%s%s%s%s%s%s",
                  system_root_dir, DIR_SEP,"var",DIR_SEP,"log",DIR_SEP,"trafficserver");
         if ((err = stat(system_log_dir, &s)) < 0) {
-          fprintf(stderr,"unable to stat() log dir'%s': %d %d, %s\n", 
+          fprintf(stderr,"unable to stat() log dir'%s': %d %d, %s\n",
                   system_log_dir, err, errno, strerror(errno));
           fprintf(stderr,"please set 'proxy.config.log2.logfile_dir'\n");
           _exit(1);

Modified: trafficserver/traffic/trunk/proxy/Error.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Error.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Error.cc (original)
+++ trafficserver/traffic/trunk/proxy/Error.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   This file contains code to manipulate Error
 
-  
+
  ****************************************************************************/
 
 #include "ink_unused.h"    /* MAGIC_EDITING_TAG */

Modified: trafficserver/traffic/trunk/proxy/Error.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Error.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Error.h (original)
+++ trafficserver/traffic/trunk/proxy/Error.h Thu May 13 07:09:39 2010
@@ -25,10 +25,10 @@
 
   Error.h
 
-  The objective of the error system is to enable graceful recovery 
+  The objective of the error system is to enable graceful recovery
   from all errors.
-  
-  
+
+
  ****************************************************************************/
 
 #if !defined _Error_h_
@@ -40,7 +40,7 @@
 //////////////////////////////////////////////////////////////////////////////
 //
 // Base Error class (abstract)
-// 
+//
 //////////////////////////////////////////////////////////////////////////////
 
 struct ErrorClass

Modified: trafficserver/traffic/trunk/proxy/EventName.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/EventName.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/EventName.cc (original)
+++ trafficserver/traffic/trunk/proxy/EventName.cc Thu May 13 07:09:39 2010
@@ -35,7 +35,7 @@
 #include "BaseManager.h"
 #include "P_MultiCache.h"
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   event_int_to_string
 
   This routine will translate an integer event number to a string

Modified: trafficserver/traffic/trunk/proxy/FetchSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/FetchSM.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/FetchSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/FetchSM.cc Thu May 13 07:09:39 2010
@@ -60,8 +60,8 @@ char* FetchSM::resp_get(int *length) {
 *length = client_bytes;
 return client_response;
 }
- 
-int FetchSM::InvokePlugin(int event, void *data) 
+
+int FetchSM::InvokePlugin(int event, void *data)
 {
   Continuation *cont = (Continuation*) contp;
   EThread *mythread = this_ethread();
@@ -70,7 +70,7 @@ int FetchSM::InvokePlugin(int event, voi
   MUTEX_UNTAKE_LOCK(cont->mutex,mythread);
   return ret;
 }
-void 
+void
 FetchSM::get_info_from_buffer(INKIOBufferReader the_reader)
 {
   char *info;

Modified: trafficserver/traffic/trunk/proxy/FetchSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/FetchSM.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/FetchSM.h (original)
+++ trafficserver/traffic/trunk/proxy/FetchSM.h Thu May 13 07:09:39 2010
@@ -23,9 +23,9 @@
 
 /***************************************************************************
  *
- *  FetchSM.h header file for Fetch Page 
+ *  FetchSM.h header file for Fetch Page
+ *
  *
- * 
  ****************************************************************************/
 
 #ifndef _FETCH_SM_H
@@ -62,7 +62,7 @@ public:
     mutex = new_ProxyMutex();
     callback_events = events;
     callback_options = options;
-    _ip = ip; 
+    _ip = ip;
     _port = port;
     writeRequest(headers,length);
     SET_HANDLER(&FetchSM::fetch_handler);
@@ -87,7 +87,7 @@ private:
   {
     return req_reader->read_avail();
   }
-  
+
   INKVConn http_vc;
   VIO *read_vio;
   VIO *write_vio;

Modified: trafficserver/traffic/trunk/proxy/Freer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Freer.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Freer.h (original)
+++ trafficserver/traffic/trunk/proxy/Freer.h Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
 
   Freer.h
 
-  
+
  ****************************************************************************/
 
 #if !defined(_Freer_h_)

Modified: trafficserver/traffic/trunk/proxy/ICP.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ICP.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ICP.cc (original)
+++ trafficserver/traffic/trunk/proxy/ICP.cc Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
 
   ICP.cc
 
-  
+
 ****************************************************************************/
 
 #include "inktomi++.h"
@@ -123,8 +123,8 @@ HTTPHdr gclient_request;
 //      ICPHandlerCont : PeriodicCont -- Periodic which monitors incoming
 //                 ICP sockets and starts processing of the incoming ICP data.
 //
-//    ICPPeerReadCont -- Implements the incoming data state machine.  
-//                 Processes remote ICP query requests and passes query 
+//    ICPPeerReadCont -- Implements the incoming data state machine.
+//                 Processes remote ICP query requests and passes query
 //                 responses to ICPRequestCont via a callout.
 //    ICPlog -- Logging object which encapsulates ICP query info required
 //              by the new logging subsystem to produce squid access log
@@ -234,7 +234,7 @@ ICPHandlerCont::PeriodicEvent(int event,
       ink_release_assert(!"unexpected event");
       break;
     }
-  }                             // End of switch  
+  }                             // End of switch
   return EVENT_CONT;
 }
 
@@ -458,7 +458,7 @@ ICPPeerReadCont::ICPPeerQueryEvent(int e
       break;
     }
   }
-  // Process result 
+  // Process result
   _state->_queryResult = event;
   SET_HANDLER((ICPPeerReadContHandler) & ICPPeerReadCont::ICPPeerReadEvent);
   return handleEvent(event, e);
@@ -488,7 +488,7 @@ ICPPeerReadCont::ICPPeerQueryCont(int ev
     _start_time = ink_get_hrtime();
     if (pluginFreshnessCalcFunc && _ICPpr->GetConfig()->globalConfig()->ICPStaleLookup()) {
       //////////////////////////////////////////////////////////////
-      // Note: _cache_lookup_local is ignored in this case, since 
+      // Note: _cache_lookup_local is ignored in this case, since
       //       cache clustering is not used with stale lookup.
       //////////////////////////////////////////////////////////////
       a = cacheProcessor.open_read(this, &_state->_cachelookupURL,
@@ -688,7 +688,7 @@ ICPPeerReadCont::PeerReadStateMachine(Pe
             break;              // move to next_state
           }
         }
-        // Validate receiver and convert the received sockaddr 
+        // Validate receiver and convert the received sockaddr
         //   to internal sockaddr format.
         struct sockaddr_in from;
         if (!s->_peer->ExtToIntRecvSockAddr(&s->_peer->fromaddr, &from)) {
@@ -764,7 +764,7 @@ ICPPeerReadCont::PeerReadStateMachine(Pe
             break;              // move to next_state
           }
         }
-        // we hand off the decoded buffer from the Peer to the PeerReadData 
+        // we hand off the decoded buffer from the Peer to the PeerReadData
         s->_sender = from;
         s->_rICPmsg_len = s->_bytesReceived;
         ink_assert(s->_buf == NULL);
@@ -1156,7 +1156,7 @@ ICPRequestCont::remove_all_pendingAction
 int
 ICPRequestCont::ICPRequestEvent(int event, Event * e)
 {
-  // Note: Passed parameter 'e' is not an Event * 
+  // Note: Passed parameter 'e' is not an Event *
   //       if event == ICP_RESPONSE_MESSAGE
 
   ink_assert(event == NET_EVENT_DATAGRAM_WRITE_COMPLETE ||
@@ -2032,7 +2032,7 @@ ICPProcessor::BuildPeerList()
   //
   // From the working copy of the ICP configuration data, build the
   // internal Peer data structures for ICP processing.
-  // First, establish the Local Peer descriptor before processing 
+  // First, establish the Local Peer descriptor before processing
   // parents and siblings.
   //
   Pcfg = _ICPConfig->indexToPeerConfigData(0);
@@ -2071,7 +2071,7 @@ ICPProcessor::BuildPeerList()
     //
     // Ignore parent and sibling entries corresponding to "localhost".
     // This is possible in a cluster configuration where parents and
-    // siblings are cluster members.  Note that in a cluster 
+    // siblings are cluster members.  Note that in a cluster
     // configuration, "icp.config" is shared by all nodes.
     //
     if (Pcfg->GetIP()->s_addr == _LocalPeer->GetIP()->s_addr)
@@ -2430,7 +2430,7 @@ ICPProcessor::CancelPendingReads()
 {
   int status;
 
-  // Cancel pending ICP read by sending a bogus message to 
+  // Cancel pending ICP read by sending a bogus message to
   //  the local ICP port.
 
   ICPRequestCont *r = new(ICPRequestCont_allocator.alloc())