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 [10/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/ ex...

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.cc Thu May 13 17:43:56 2010
@@ -21,11 +21,11 @@
   limitations under the License.
  */
 
-/*************************************************************************** 
+/***************************************************************************
  LogConfig.cc
 
  This file implements the LogConfig object.
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -45,7 +45,7 @@
 #include <sys/statvfs.h>
 #elif (HOST_OS != freebsd)
 #include <sys/statvfs.h>
-#endif  // linux 
+#endif  // linux
 
 #include "ink_platform.h"
 
@@ -293,13 +293,13 @@ LogConfig::read_configuration_variables(
         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);
-        } 
+        }
 
-      } 
+      }
       logfile_dir = xstrdup(system_log_dir);
     }
   }
@@ -422,7 +422,7 @@ LogConfig::read_configuration_variables(
   // SPLITTING
   // 0 means no splitting
   // 1 means splitting
-  // for icp and mixt 
+  // for icp and mixt
   //   -1 means filter out (do not log and do not create split file)
   val = (int) LOG_ConfigReadInteger("proxy.config.log2.separate_icp_logs");
   if (val == 0 || val == 1 || val == -1) {
@@ -442,7 +442,7 @@ LogConfig::read_configuration_variables(
 
   // COLLATION
   val = (int) LOG_LocalReadInteger("proxy.local.log2.collation_mode");
-  // do not restrict value so that error message is logged if 
+  // do not restrict value so that error message is logged if
   // collation_mode is out of range
   collation_mode = val;
 
@@ -696,7 +696,7 @@ LogConfig::setup_collation(LogConfig * p
          "Log collation disabled", collation_mode, NO_COLLATION, N_COLLATION_MODES - 1);
   } else if (collation_mode == NO_COLLATION) {
     // if the previous configuration had a collation accept, delete it
-    // 
+    //
     if (prev_config && prev_config->m_log_collation_accept) {
       delete prev_config->m_log_collation_accept;
       prev_config->m_log_collation_accept = NULL;
@@ -769,7 +769,7 @@ LogConfig::init(LogConfig * prev_config)
   TextLogObject *old_elog = Log::error_log;
   TextLogObject *new_elog = 0;
 
-  // swap new error log for old error log unless 
+  // swap new error log for old error log unless
   // -there was no error log and we don't want one
   // -there was an error log, and the new one is identical
   //  (the logging directory did not change)
@@ -890,7 +890,7 @@ LogConfig::display(FILE * fd)
 }
 
 //-----------------------------------------------------------------------------
-// setup_pre_defined_info 
+// setup_pre_defined_info
 //
 // This function adds all the pre defined formats to the global_format_list
 // and gathers the information for the active formats in a single place
@@ -1040,7 +1040,7 @@ LogConfig::create_pre_defined_objects_wi
 //-----------------------------------------------------------------------------
 // split_by_protocol
 //
-// This function creates the objects needed to log different protocols on 
+// This function creates the objects needed to log different protocols on
 // their own file if any of the "separate_xxx_logs" config. variable is set.
 //
 // Upon return, the pf_list argument holds the filters that reject the
@@ -1196,7 +1196,7 @@ LogConfig::setup_log_objects()
   setup_pre_defined_info(&pre_def_info_list);
 
   // do protocol splitting
-  // 
+  //
   LogFilter *reject_protocol_filter = split_by_protocol(pre_def_info_list);
 
   // do host splitting
@@ -1473,7 +1473,7 @@ LogConfig::register_config_callbacks()
   LOG_RegisterConfigUpdateFunc("proxy.config.log2.common_log_name", &LogConfig::reconfigure, NULL);
   LOG_RegisterConfigUpdateFunc("proxy.config.log2.common_log_header", &LogConfig::reconfigure, NULL);
 
-  // EXTENDED 
+  // EXTENDED
   LOG_RegisterConfigUpdateFunc("proxy.config.log2.extended_log_enabled", &LogConfig::reconfigure, NULL);
   LOG_RegisterConfigUpdateFunc("proxy.config.log2.extended_log_is_ascii", &LogConfig::reconfigure, NULL);
   LOG_RegisterConfigUpdateFunc("proxy.config.log2.extended_log_name", &LogConfig::reconfigure, NULL);
@@ -1614,7 +1614,7 @@ LogConfig::register_mgmt_callbacks()
 }
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogConfig::space_to_write
 
   This function returns true if there is enough disk space to write the
@@ -1644,7 +1644,7 @@ bool LogConfig::space_to_write(ink64 byt
   return space;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogConfig::update_space_used
 
   Update the m_space_used variable by reading the logging dir and counting
@@ -1832,7 +1832,7 @@ LogConfig::update_space_used()
   }
 
   //
-  // Now that we've updated the m_space_used value, see if we need to 
+  // Now that we've updated the m_space_used value, see if we need to
   // issue any alarms or warnings about space
   //
 
@@ -1943,7 +1943,7 @@ LogConfig::read_old_log_config()
     if (entry_type) {
 
       // format
-      // 
+      //
       if (strcasecmp(entry_type, "format") == 0) {
 
         char *file_name = NULL;
@@ -2045,7 +2045,7 @@ LogConfig::read_old_log_config()
   ::close(fd);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogConfig::read_xml_log_config
 
   This is a new routine for reading the XML-based log config file.
@@ -2227,7 +2227,7 @@ LogConfig::read_xml_log_config(int from_
         } else if (interval.count() > 1) {
           Note("Multiple values for 'Interval' attribute in %s; " "using the first one", xobj->object_name());
         }
-        // interval 
+        // interval
         //
         interval_num = ink_atoui(interval.dequeue());
       } else if (interval.count() > 0) {

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogConfig.h Thu May 13 17:43:56 2010
@@ -87,14 +87,14 @@ struct dirent;
 class LogCollationAccept;
 #endif
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogConfig
 
   This object keeps the state of the logging configuraion variables.  Upon
   construction, the log configuration file is read and the logging
   variables are initialized.
 
-  The "global" LogConfig object is kept as a static pointer in the Log 
+  The "global" LogConfig object is kept as a static pointer in the Log
   class, called "config", and changed whenever the configuration variables
   are changed in the config file, using Log::change_configuration().
 
@@ -103,11 +103,11 @@ class LogCollationAccept;
         The name in records.config should be "proxy.config.log2.xxx".
      2. Create a member variable to store the current value.
         The name of the member variable should be "xxx".
-     3. If the member variable is a string, add a delete for it in the 
+     3. If the member variable is a string, add a delete for it in the
         destructor, LogConfig::~LogConfig.
      4. Initialize the member variable in LogConfig::setup_default_values
      5. Update the member variable from the records.config file
-        in LogConfig::read_configuration_variables() using a call to 
+        in LogConfig::read_configuration_variables() using a call to
         ConfigReadInteger or ConfigReadString.
      6. Add a line in the LogConfig::register_config_callbacks() function
         for this new variable if it is exposed in the GUI
@@ -329,7 +329,7 @@ private:
   LogConfig & operator=(const LogConfig &);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogDeleteCandidate
   -------------------------------------------------------------------------*/
 

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogField.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogField.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogField.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogField.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
  This file implements the LogField object, which is the central
  representation of a logging field.
 
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -370,7 +370,7 @@ LogField::display(FILE * fd)
   fprintf(fd, "    %30s %10s %5s\n", m_name, m_symbol, names[m_type]);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
 void
@@ -384,7 +384,7 @@ LogField::set_aggregate_op(LogField::Agg
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
 void
@@ -420,7 +420,7 @@ LogField::update_aggregate(LOG_INT val)
         "new val = %d, cnt = %d", m_symbol, val, m_agg_val, m_agg_cnt);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
 LogField::Container LogField::valid_container_name(char *name)
@@ -433,7 +433,7 @@ LogField::Container LogField::valid_cont
   return LogField::NO_CONTAINER;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
 LogField::Aggregate LogField::valid_aggregate_name(char *name)
@@ -446,7 +446,7 @@ LogField::Aggregate LogField::valid_aggr
   return LogField::NO_AGGREGATE;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
 bool LogField::fieldlist_contains_aggregates(char *fieldlist)

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

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFieldAliasMap.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFieldAliasMap.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFieldAliasMap.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFieldAliasMap.h Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogFieldAliasMap.h
 
- 
+
  ***************************************************************************/
 
 #ifndef LOG_FIELD_ALIAS_MAP_H
@@ -59,7 +59,7 @@ This method takes an IntType key and wri
 bufer buf of length bufLen. It sets the number of written characters
 numChars (if numChars is not NULL), and returns an error status.
 
-The IntType to string conversion is used when unmarshaling data prior to 
+The IntType to string conversion is used when unmarshaling data prior to
 writing to a log file, and the string to IntType conversion is used when
 building filters (so that the filter value can be specified as a string,
 but the actual field comparison is done between IntTypes).
@@ -68,14 +68,14 @@ Note that LogFieldAliasMap is derived fr
 is constructed a pointer to it can be passed to other objects (e.g.,
 to a LogField object) without the object having to worry about freeing
 any memory the map may have allocated.
- 
+
  *****************************************************************************/
 
 
 class LogFieldAliasMap:public RefCountObj
 {
 public:
-  // the logging system assumes log entries of type sINT are 
+  // the logging system assumes log entries of type sINT are
   // unsigned integers (LOG_INT type) so we define IntType to be unsigned
   typedef unsigned int IntType;
   enum
@@ -217,9 +217,9 @@ public:
 	int retVal;
 	size_t numChars;
 	size_t n = snprintf (buf, bufLen, "%u.%u.%u.%u",
-				 (ip >> 24) & 0xff, 
-				 (ip >> 16) & 0xff, 
-				 (ip >> 8)  & 0xff, 
+				 (ip >> 24) & 0xff,
+				 (ip >> 16) & 0xff,
+				 (ip >> 8)  & 0xff,
 				 ip         & 0xff);
 	if (n < bufLen) {
 	    numChars = n;

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogFile.cc
 
- 
+
  ***************************************************************************/
 
 #include "inktomi++.h"
@@ -57,17 +57,17 @@
 // the FILESIZE_SAFE_THRESHOLD_FACTOR is used to compute the file size
 // limit as follows:
 //
-// size_limit = system_filesize_limit - 
+// size_limit = system_filesize_limit -
 //              FILESIZE_SAFE_THRESHOLD_FACTOR * log_buffer_size
 //
-// where system_filesize_limit is the current filesize limit as returned by 
-// getrlimit(), and log_buffer_size is the config. value for the size of 
+// where system_filesize_limit is the current filesize limit as returned by
+// getrlimit(), and log_buffer_size is the config. value for the size of
 // a LogBuffer.
 //
 // This means that a file reaches its size_limit once it has no room to fit
-// FILESIZE_SAFE_THRESHOLD_FACTOR LogBuffers. 
+// FILESIZE_SAFE_THRESHOLD_FACTOR LogBuffers.
 //
-// A LogBuffer, when converted to ascii, can produce more than 
+// A LogBuffer, when converted to ascii, can produce more than
 // log_buffer_size bytes, depending on the type of the logging fields it
 // stores. String fields don't change size, but integer fields do.
 // A 32 bit integer has a maximum value of 10 digits, which means it
@@ -76,7 +76,7 @@
 // amount of ascii data a LogBuffer can produce is 2.5 times its size, so
 // we should make sure we can always write this amount to a file.
 //
-// However, to be extra safe, we should set the 
+// However, to be extra safe, we should set the
 // FILESIZE_SAFE_THRESHOLD_FACTOR higher than 3
 //
 static const int FILESIZE_SAFE_THRESHOLD_FACTOR = 10;
@@ -155,7 +155,7 @@ bool LogFile::exists(const char *pathnam
   return (::access(pathname, F_OK) == 0);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFile::change_name
   -------------------------------------------------------------------------*/
 
@@ -166,7 +166,7 @@ LogFile::change_name(char *new_name)
   m_name = xstrdup(new_name);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFile::change_header
   -------------------------------------------------------------------------*/
 
@@ -303,7 +303,7 @@ LogFile::close_file()
   m_filesystem_checks_done = false;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFile::rolled_logfile
 
   This function will return true if the given filename corresponds to a
@@ -336,17 +336,17 @@ bool LogFile::rolled_logfile(char *path)
 
   Under normal operating conditions, this LogFile object was in existence
   for all writes to the file.  In this case, the LogFile members m_start_time
-  and m_end_time will have the starting and ending times for the actual 
+  and m_end_time will have the starting and ending times for the actual
   entries written to the file.
 
-  On restart situations, it is possible to re-open an existing logfile, 
-  which means that the m_start_time variable will be later than the actual 
-  entries recorded in the file.  In this case, we'll use the creation time 
-  of the file, which should be recorded in the meta-information located on 
+  On restart situations, it is possible to re-open an existing logfile,
+  which means that the m_start_time variable will be later than the actual
+  entries recorded in the file.  In this case, we'll use the creation time
+  of the file, which should be recorded in the meta-information located on
   disk.
 
-  If we can't use the meta-file, either because it's not there or because 
-  it's not valid, then we'll use timestamp 0 (Jan 1, 1970) as the starting 
+  If we can't use the meta-file, either because it's not there or because
+  it's not valid, then we'll use timestamp 0 (Jan 1, 1970) as the starting
   bound.
 
   Return 1 if file rolled, 0 otherwise
@@ -369,7 +369,7 @@ LogFile::roll(long interval_start, long 
   }
   //
   // Create the new file name, which consists of a timestamp and rolled
-  // extension added to the previous file name.  The timestamp format is 
+  // extension added to the previous file name.  The timestamp format is
   // ".%Y%m%d.%Hh%Mm%Ss-%Y%m%d.%Hh%Mm%Ss", where the two date/time values
   // represent the starting and ending times for entries in the rolled
   // log file.  In addition, we add the hostname.  So, the entire rolled
@@ -708,7 +708,7 @@ LogFile::write_ascii_logbuffer3(LogBuffe
 
     ssize_t bytes_written;
 
-    // try to write any data that may not have been written in a 
+    // try to write any data that may not have been written in a
     // previous attempt
     //
     if (m_overspill_bytes) {
@@ -880,7 +880,7 @@ LogFile::do_filesystem_checks()
 }
 
 /***************************************************************************
- LogFileList IS NOT USED 
+ LogFileList IS NOT USED
 ****************************************************************************/
 
 

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFile.h Thu May 13 17:43:56 2010
@@ -246,7 +246,7 @@ private:
 };
 
 /***************************************************************************
- LogFileList IS NOT USED 
+ LogFileList IS NOT USED
 ****************************************************************************/
 
 #endif

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogFilter.cc
 
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -85,7 +85,7 @@ LogFilter::~LogFilter()
   delete m_field;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFilter::filter_from_specification
 
   Build a LogFilter object from the given logs.config specification.
@@ -123,7 +123,7 @@ LogFilter::filter_from_specification(cha
     return NULL;
   }
 
-  // Next is the name of a format 
+  // Next is the name of a format
   //
   token = strtok(NULL, ":");
   if (token == NULL) {
@@ -139,7 +139,7 @@ LogFilter::filter_from_specification(cha
       return NULL;
     }
   }
-  // Next is the field name 
+  // Next is the field name
   //
   token = strtok(NULL, ":");
   if (token == NULL) {
@@ -406,7 +406,7 @@ bool LogFilterString::toss_this_entry(Lo
   case MATCH:
     // marsh_len is an upper bound on the length of the marshalled string
     // because marsh_len counts padding and the eos. So for a MATCH
-    // operator, we use the DATA_LENGTH_LARGER length condition rather 
+    // operator, we use the DATA_LENGTH_LARGER length condition rather
     // than DATA_LENGTH_EQUAL, which we would use if we had the actual
     // length of the string. It is probably not worth computing the
     // actual length, so we just use the fact that a MATCH is not possible
@@ -643,7 +643,7 @@ bool LogFilterInt::toss_this_entry(LogAc
   value = ntohl(value);
 
   // we don't use m_operator because we consider all operators to be
-  // equivalent to "MATCH" for an integer field 
+  // equivalent to "MATCH" for an integer field
   //
 
   // most common case is single value, speed it up a little bit by unrolling

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFilter.h Thu May 13 17:43:56 2010
@@ -30,7 +30,7 @@
 #include "LogField.h"
 #include "LogFormat.h"
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFilter
 
   This is an abstract base class from which particular filters can be
@@ -119,7 +119,7 @@ private:
   LogFilter & operator=(LogFilter & rhs);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFilterString
 
   Filter for string fields.
@@ -174,7 +174,7 @@ private:
   LogFilterString & operator=(LogFilterString & rhs);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFilterInt
 
   Filter for int fields.
@@ -207,7 +207,7 @@ private:
 
 bool filters_are_equal(LogFilter * filt1, LogFilter * filt2);
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFilterList
   -------------------------------------------------------------------------*/
 
@@ -248,7 +248,7 @@ private:
 
   bool m_does_conjunction;
   // If m_does_conjunction = true
-  // toss_this_entry returns true 
+  // toss_this_entry returns true
   // if ANY filter tosses entry away.
   // If m_does_conjunction = false,
   // toss this entry returns true if
@@ -260,7 +260,7 @@ private:
 };
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   Inline functions
   -------------------------------------------------------------------------*/
 
@@ -272,11 +272,11 @@ private:
   the arguments to the function are:
 
   - a function f of type OperatorFunction that determines if the
-    condition is true for a single filter value. Note that this function 
+    condition is true for a single filter value. Note that this function
     must return 0 if the condition is true.
   - the value of the field from the log record
   - the length of this field
-  - the array of filter values to compare to note that we pass this as an 
+  - the array of filter values to compare to note that we pass this as an
     argument because it can be either m_value or m_value_uppercase
   - a LengthCondition argument that determines if the length of the field value
     must be equal or larger to the length of the filter value (this is to

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogFormat.cc
 
- 
+
  ***************************************************************************/
 
 #include "ink_config.h"
@@ -74,7 +74,7 @@ const char *const
   "%<chi> - %<caun> [%<cqtn>] \"%<cqtx>\" %<pssc> %<pscl> "
   "%<sssc> %<sscl> %<cqbl> %<pqbl> %<cqhl> %<pshl> %<pqhl> " "%<sshl> %<tts> %<phr> %<cfsc> %<pfsc> %<crc>";
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFormat::setup
   -------------------------------------------------------------------------*/
 
@@ -111,7 +111,7 @@ LogFormat::setup(const char *name, const
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFormat::id_from_name
   -------------------------------------------------------------------------*/
 
@@ -137,7 +137,7 @@ ink32 LogFormat::id_from_name(const char
   return id;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFormat::init_variables
   -------------------------------------------------------------------------*/
 
@@ -399,9 +399,9 @@ LogFormat::format_from_specification(cha
   SimpleTokenizer tok(spec, ':');
 
   //
-  // Divide the specification string into tokens using the ':' as a 
-  // field separator.  There are currently eight (8) tokens that comprise 
-  // a format specification.  Verify each of the token values and if 
+  // Divide the specification string into tokens using the ':' as a
+  // field separator.  There are currently eight (8) tokens that comprise
+  // a format specification.  Verify each of the token values and if
   // everything looks ok, then build the LogFormat object.
   //
   // First should be the "format" keyword that says this is a format spec.
@@ -643,7 +643,7 @@ LogFormat::parse_symbol_string(const cha
   return field_count;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogFormat::parse_format_string
 
   This function will parse a custom log format string, which is a

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogFormat.h Thu May 13 17:43:56 2010
@@ -39,7 +39,7 @@
   Ok, as of 3.1, the role of the LogFormat object changes greatly.  Before
   it was the central object in the logging system that defined each "file"
   that would be created, and all other objects hung off of it.
-  
+
   Now, this object will simply store the characteristics of a log format,
   which is defined as a set of fields.
   -------------------------------------------------------------------------*/

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogHost.cc
 
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -94,9 +94,9 @@ LogHost::~LogHost()
   xfree(m_object_filename);
 }
 
-// 
-// There are 3 ways to establish a LogHost: 
-// - by "hostname:port" or IP:port", where IP is a string of the 
+//
+// There are 3 ways to establish a LogHost:
+// - by "hostname:port" or IP:port", where IP is a string of the
 //   form "xxx.xxx.xxx.xxx".
 // - by specifying a hostname and a port (as separate arguments).
 // - by specifying an ip and a port (as separate arguments).

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogHost.h Thu May 13 17:43:56 2010
@@ -123,7 +123,7 @@ private:
   LogHost & operator=(const LogHost &);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogHostList
   -------------------------------------------------------------------------*/
 

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogLimits.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogLimits.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogLimits.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogLimits.h Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  This file contains constants and other limitis used within the logging
  module.
 
- 
+
  ***************************************************************************/
 
 #ifndef LOG_LIMITS_H

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogObject.cc
 
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -113,7 +113,7 @@ LogObject::LogObject(LogFormat * format,
   m_signature = compute_signature(m_format, m_basename, m_flags);
 
 #ifndef TS_MICRO
-  // by default, create a LogFile for this object, if a loghost is 
+  // by default, create a LogFile for this object, if a loghost is
   // later specified, then we will delete the LogFile object
   //
   m_logFile = NEW(new LogFile(m_filename, header, file_format,
@@ -280,7 +280,7 @@ LogObject::add_loghost(LogHost * host, b
 
 // we conpute the object signature from the fieldlist_str and the printf_str
 // of the LogFormat rather than from the format_str because the format_str
-// is not part of a LogBuffer header 
+// is not part of a LogBuffer header
 //
 inku64 LogObject::compute_signature(LogFormat * format, char *filename, unsigned int flags)
 {
@@ -398,7 +398,7 @@ LogObject::_checkout_write(size_t * writ
       //
       new_buffer = NEW(new LogBuffer(this, Log::config->log_buffer_size));
 
-      // swap the new buffer for the old one (only this thread 
+      // swap the new buffer for the old one (only this thread
       // should be doing this, so there should be no problem)
       //
       INK_WRITE_MEMORY_BARRIER;
@@ -591,7 +591,7 @@ LogObject::_setup_rolling(int rolling_en
     if (rolling_enabled == LogConfig::ROLL_ON_TIME_ONLY ||
         rolling_enabled == LogConfig::ROLL_ON_TIME_OR_SIZE || rolling_enabled == LogConfig::ROLL_ON_TIME_AND_SIZE) {
       if (rolling_interval_sec < LogConfig::MIN_ROLLING_INTERVAL_SEC) {
-        // check minimum 
+        // check minimum
         m_rolling_interval_sec = LogConfig::MIN_ROLLING_INTERVAL_SEC;
       } else if (rolling_interval_sec > 86400) {
         // 1 day maximum
@@ -651,19 +651,19 @@ LogObject::roll_files_if_needed(long tim
       // changed underneath us. This could happen during daylight
       // savings time adjustments, or if time is adjusted via NTP.
       //
-      // For this reason we don't cache the number of seconds 
+      // For this reason we don't cache the number of seconds
       // remaining until the next roll, but we calculate this figure
       // every time ...
       //
       int secs_to_next = LogUtils::seconds_to_next_roll(time_now, m_rolling_offset_hr,
                                                         m_rolling_interval_sec);
 
-      // ... likewise, we make sure we compute the absolute value 
+      // ... likewise, we make sure we compute the absolute value
       // of the seconds since the last roll (which would otherwise
       // be negative if time "went back"). We will use this value
       // to make sure we don't roll twice if time goes back shortly
       // after rolling.
-      // 
+      //
       int secs_since_last = (m_last_roll_time < time_now ? time_now - m_last_roll_time : m_last_roll_time - time_now);
 
       // number of seconds we allow for periodic_tasks() not to be
@@ -945,7 +945,7 @@ LogObjectManager::_solve_filename_confli
 
     if (meta_info.file_open_successful()) {
       if (meta_info.pre_panda_metafile()) {
-        // assume no conflicts if pre-panda metafile and 
+        // assume no conflicts if pre-panda metafile and
         // write Panda style metafile with old creation_time and
         // signature of the object requesting filename
         //
@@ -994,7 +994,7 @@ LogObjectManager::_solve_filename_confli
           struct stat s;
           if (stat(filename, &s) < 0) {
             // an error happened while trying to get file info
-            // 
+            //
             const char *msg = "Cannot stat log file %s: %s";
             char *se = strerror(errno);
             Error(msg, filename, se);
@@ -1016,7 +1016,7 @@ LogObjectManager::_solve_filename_confli
           long time_now = LogUtils::timestamp();
           if (logfile.roll(time_now - log_object->get_rolling_interval(), time_now) == 0) {
             // an error happened while trying to roll the file
-            // 
+            //
             const char *msg = "Cannot roll log file %s to fix log " "filename conflicts";
             Error(msg, filename);
             LogUtils::manager_alarm(LogUtils::LOG_ALARM_ERROR, msg, filename);
@@ -1039,9 +1039,9 @@ bool
   for (int i = 0; i < numObjects; i++) {
     LogObject *obj = objects[i];
     if (!obj->is_collation_client()) {
-      // an internal conflict exists if two objects request the 
+      // an internal conflict exists if two objects request the
       // same filename, regardless of the object signatures, since
-      // two objects writing to the same file would produce a 
+      // two objects writing to the same file would produce a
       // log with duplicate entries and non monotonic timestamps
       if (strcmp(obj->get_full_filename(), filename) == 0) {
         return true;
@@ -1093,10 +1093,10 @@ LogObjectManager::_roll_files(long time_
       num_rolled += _objects[i]->roll_files(time_now);
     }
   }
-  // we don't care if we miss an object that may be added to the set of api 
-  // objects just after we have read _numAPIobjects and found it to be zero; 
+  // we don't care if we miss an object that may be added to the set of api
+  // objects just after we have read _numAPIobjects and found it to be zero;
   // we will get a chance to roll this object next time
-  // 
+  //
   if (_numAPIobjects) {
     ACQUIRE_API_MUTEX("A LogObjectManager::roll_files");
     for (i = 0; i < _numAPIobjects; i++) {
@@ -1131,10 +1131,10 @@ LogObjectManager::check_buffer_expiratio
     _objects[i]->check_buffer_expiration(time_now);
   }
 
-  // we don't care if we miss an object that may be added to the set of api 
-  // objects just after we have read _numAPIobjects and found it to be zero; 
-  // we will get a chance to check the buffer expiration next time 
-  // 
+  // we don't care if we miss an object that may be added to the set of api
+  // objects just after we have read _numAPIobjects and found it to be zero;
+  // we will get a chance to check the buffer expiration next time
+  //
   if (_numAPIobjects) {
     ACQUIRE_API_MUTEX("A LogObjectManager::check_buffer_expiration");
     for (i = 0; i < _numAPIobjects; i++) {
@@ -1211,7 +1211,7 @@ LogObjectManager::add_filter_to_all(LogF
 void
 LogObjectManager::open_local_pipes()
 {
-  // for all local objects that write to a pipe, call open_file to force 
+  // for all local objects that write to a pipe, call open_file to force
   // the creation of the pipe so that any potential reader can see it
   //
   for (size_t i = 0; i < _numObjects; i++) {
@@ -1252,7 +1252,7 @@ LogObjectManager::transfer_objects(LogOb
 
     Debug("log2-config-transfer", "examining existing object %s", old_obj->get_base_filename());
 
-    // see if any of the new objects is just a copy of an old one, 
+    // see if any of the new objects is just a copy of an old one,
     // if so, keep the old one and delete the new one
     //
     size_t j = _numObjects;

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogObject.h Thu May 13 17:43:56 2010
@@ -251,9 +251,9 @@ private:
   // the logging directory
   char *m_filename;             // the full path of the file associated
   // with this object
-  char *m_alt_filename;         // the full path of the file used 
+  char *m_alt_filename;         // the full path of the file used
   // instead of m_filename if the latter
-  // could not be used because of 
+  // could not be used because of
   // name conflicts
 
   unsigned int m_flags;         // diverse object flags (see above)
@@ -262,7 +262,7 @@ private:
   int m_rolling_enabled;
   int m_rolling_interval_sec;   // time interval between rolls
   // 0 means no rolling
-  int m_rolling_offset_hr;      // 
+  int m_rolling_offset_hr;      //
   int m_rolling_size_mb;        // size at which the log file rolls
   long m_last_roll_time;        // the last time this object rolled
   // its files
@@ -286,7 +286,7 @@ private:
   LogObject & operator=(const LogObject &);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   TextLog
   -------------------------------------------------------------------------*/
 

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogSock.cc
 
- 
+
  ***************************************************************************/
 #include "ink_unused.h"
 
@@ -81,7 +81,7 @@ LogSock::~LogSock()
   delete[]ct;                   // delete the connection table
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogSock::listen
 
   This routine sets up the LogSock to begin accepting connections on the
@@ -622,7 +622,7 @@ bool LogSock::is_connected(int cid, bool
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
 void
@@ -655,7 +655,7 @@ bool LogSock::authorized_client(int cid,
   //
   // Ok, the client has a pending message, so check to see if it matches
   // the given key.
-  // 
+  //
   char
     buf[1024];
   int

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogSock.h Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@
 #include "inktomi++.h"
 #include "LogLimits.h"
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogSock
 
   This class implements a multiplexed socket class that supports both

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogStandalone.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogStandalone.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogStandalone.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogStandalone.cc Thu May 13 17:43:56 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  LogStandalone.cc
 
- 
+
  ***************************************************************************/
 
 #include "inktomi++.h"
@@ -82,7 +82,7 @@ HttpBodyFactory *body_factory = NULL;
 AppVersionInfo appVersionInfo;
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   max_out_limit
   -------------------------------------------------------------------------*/
 #if (HOST_OS == linux)
@@ -109,7 +109,7 @@ max_out_limit(int which, bool max_it)
   return ret;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   init_system
   -------------------------------------------------------------------------*/
 
@@ -125,7 +125,7 @@ init_system()
   syslog(LOG_NOTICE, "NOTE: SAC Version: %s", appVersionInfo.FullVersionInfoStr);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   initialize_process_manager
   -------------------------------------------------------------------------*/
 
@@ -150,10 +150,10 @@ initialize_process_manager()
 
   if ((err = stat(management_directory, &s)) < 0) {
     // Try 'system_root_dir/etc/trafficserver' directory
-    snprintf(management_directory, sizeof(management_directory), 
+    snprintf(management_directory, sizeof(management_directory),
              "%s%s%s%s%s",system_root_dir, DIR_SEP,"etc",DIR_SEP,"trafficserver");
     if ((err = stat(management_directory, &s)) < 0) {
-      fprintf(stderr,"unable to stat() management path '%s': %d %d, %s\n", 
+      fprintf(stderr,"unable to stat() management path '%s': %d %d, %s\n",
                 management_directory, err, errno, strerror(errno));
       fprintf(stderr,"please set management path via command line '-d <managment directory>'\n");
       _exit(1);
@@ -203,7 +203,7 @@ initialize_process_manager()
 //                         RECP_NULL);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   shutdown_system
   -------------------------------------------------------------------------*/
 
@@ -213,7 +213,7 @@ shutdown_system()
 }
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   check_lockfile
   -------------------------------------------------------------------------*/
 
@@ -228,15 +228,15 @@ check_lockfile(const char *config_dir, c
 
   if ((err = stat(lockdir, &s)) < 0) {
     // Try 'system_root_dir/var/trafficserver' directory
-    snprintf(lockdir, sizeof(lockdir), 
+    snprintf(lockdir, sizeof(lockdir),
              "%s%s%s%s%s",system_root_dir, DIR_SEP,"var",DIR_SEP,"trafficserver");
     if ((err = stat(lockdir, &s)) < 0) {
-      fprintf(stderr,"unable to stat() dir'%s': %d %d, %s\n", 
+      fprintf(stderr,"unable to stat() dir'%s': %d %d, %s\n",
                 lockdir, err, errno, strerror(errno));
       fprintf(stderr," please set correct path in env variable TS_ROOT \n");
       _exit(1);
     }
-  } 
+  }
   int nn = snprintf(lockfile, sizeof(lockfile),"%s%s%s", lockdir,DIR_SEP,SERVER_LOCK);
 
   ink_assert(nn > 0);
@@ -265,7 +265,7 @@ check_lockfile(const char *config_dir, c
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   syslog_thr_init
 
   For the DEC alpha, the syslog call must be made for each thread.
@@ -276,7 +276,7 @@ syslog_thr_init()
 {
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   init_log_standalone
 
   This routine should be called from the main() function of the standalone
@@ -305,7 +305,7 @@ init_log_standalone(const char *pgm_name
   diags_init = 1;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   init_log_standalone_basic
 
   This routine is similar to init_log_standalone, but it is intended for
@@ -364,7 +364,7 @@ get_ts_directory(char *ts_path, size_t t
       if (ts_path[len - 1] == '/') {
         ts_path[len - 1] = '\0';
       }
-      
+
       fclose(fp);
     } else {
       ink_strncpy(ts_path, PREFIX, ts_path_len);
@@ -372,7 +372,7 @@ get_ts_directory(char *ts_path, size_t t
   }
 
   if ((err = stat(ts_path, &s)) < 0) {
-    fprintf(stderr,"unable to stat() TS PATH '%s': %d %d, %s\n", 
+    fprintf(stderr,"unable to stat() TS PATH '%s': %d %d, %s\n",
               ts_path, err, errno, strerror(errno));
     fprintf(stderr," Please set correct path in env variable TS_ROOT \n");
     return -1;

Modified: trafficserver/traffic/tags/2.1.0/proxy/logging/LogUtils.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logging/LogUtils.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logging/LogUtils.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logging/LogUtils.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
  This file contains a set of utility routines that are used throughout the
  logging implementation.
 
- 
+
  ***************************************************************************/
 
 #include "ink_config.h"
@@ -163,7 +163,7 @@ LogUtils::timestamp_to_netscape_str(long
 /*-------------------------------------------------------------------------
   LogUtils::timestamp_to_date_str
 
-  This routine will convert a timestamp (seconds) into a W3C compatible 
+  This routine will convert a timestamp (seconds) into a W3C compatible
   date string.
   -------------------------------------------------------------------------*/
 
@@ -195,7 +195,7 @@ LogUtils::timestamp_to_date_str(long tim
 /*-------------------------------------------------------------------------
   LogUtils::timestamp_to_time_str
 
-  This routine will convert a timestamp (seconds) into a W3C compatible 
+  This routine will convert a timestamp (seconds) into a W3C compatible
   time string.
   -------------------------------------------------------------------------*/
 
@@ -312,7 +312,7 @@ LogUtils::strip_trailing_newline(char *b
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::escapify_url
 
   This routine will escapify a URL to remove spaces (and perhaps other ugly
@@ -325,7 +325,7 @@ char *
 LogUtils::escapify_url(Arena * arena, char *url, int len_in, int *len_out)
 {
   // codes_to_escape is a bitmap encoding the codes that should be escaped.
-  // These are all the codes defined in section 2.4.3 of RFC 2396 
+  // These are all the codes defined in section 2.4.3 of RFC 2396
   // (control, space, delims, and unwise) plus the tilde. In RFC 2396
   // the tilde is an "unreserved" character, but we escape it because
   // historically this is what the traffic_server has done.
@@ -336,9 +336,9 @@ LogUtils::escapify_url(Arena * arena, ch
     0xB4,                       // space " # %
     0x00, 0x00,                 //
     0x0A,                       // < >
-    0x00, 0x00, 0x00,           // 
+    0x00, 0x00, 0x00,           //
     0x1E, 0x80,                 // [ \ ] ^ `
-    0x00, 0x00,                 // 
+    0x00, 0x00,                 //
     0x1F,                       // { | } ~ DEL
     0x00, 0x00, 0x00, 0x00,     // all non-ascii characters unmodified
     0x00, 0x00, 0x00, 0x00,     //               .
@@ -378,7 +378,7 @@ LogUtils::escapify_url(Arena * arena, ch
   // three characters long.  Count this and allocate the string required.
   //
   // make sure we take into account the characters we are substituting
-  // for when we calculate out_len !!! in other words, 
+  // for when we calculate out_len !!! in other words,
   // out_len = len_in + 3*count - count
   //
   int out_len = len_in + 2 * count;
@@ -408,7 +408,7 @@ LogUtils::escapify_url(Arena * arena, ch
   return new_url;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::remove_content_type_attributes
 
   HTTP allows content types to have attributes following the main type and
@@ -432,14 +432,14 @@ LogUtils::remove_content_type_attributes
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::ip_to_hex_str
 
   This routine simply writes the given IP integer [ip] in the equivalent
   hexadecimal string format "xxxxxxxxxx" into the provided buffer [buf] of
-  size [bufLen]. 
+  size [bufLen].
 
-  It returns 1 if the provided buffer is not big enough to hold the 
+  It returns 1 if the provided buffer is not big enough to hold the
   equivalent ip string (and its null terminator), and 0 otherwise.
   If the buffer is not big enough, only the ip "segments" that completely
   fit into it are written, and the buffer is null terminated.
@@ -472,14 +472,14 @@ LogUtils::ip_to_hex_str(unsigned ip, cha
   return retVal;
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::timestamp_to_hex_str
 
   This routine simply writes the given timestamp integer [time_t] in the equivalent
   hexadecimal string format "xxxxxxxxxx" into the provided buffer [buf] of
-  size [bufLen]. 
+  size [bufLen].
 
-  It returns 1 if the provided buffer is not big enough to hold the 
+  It returns 1 if the provided buffer is not big enough to hold the
   equivalent ip string (and its null terminator), and 0 otherwise.
   If the buffer is not big enough, only the ip "segments" that completely
   fit into it are written, and the buffer is null terminated.
@@ -512,23 +512,23 @@ int
 LogUtils::ip_to_str (unsigned ip, char *str, unsigned len)
 {
     int ret = snprintf (str, len, "%u.%u.%u.%u",
-			    (ip >> 24) & 0xff, 
-			    (ip >> 16) & 0xff, 
-			    (ip >> 8)  & 0xff, 
+			    (ip >> 24) & 0xff,
+			    (ip >> 16) & 0xff,
+			    (ip >> 8)  & 0xff,
 			    ip         & 0xff);
 
     return ((ret <= (int)len)? ret : (int)len);
 }
 */
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::ip_to_str
 
   This routine simply writes the given IP integer [ip] in the equivalent
   string format "aaa.bbb.ccc.ddd" into the provided buffer [buf] of size
-  [bufLen]. 
+  [bufLen].
 
-  It returns 1 if the provided buffer is not big enough to hold the 
+  It returns 1 if the provided buffer is not big enough to hold the
   equivalent ip string (and its null terminator), and 0 otherwise.
   If the buffer is not big enough, only the ip "segments" that completely
   fit into it are written, and the buffer is null terminated.
@@ -607,7 +607,7 @@ LogUtils::ip_to_str(unsigned ip, char *b
   return retVal;
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::str_to_ip
 
   This routine converts the string form of an IP address
@@ -627,7 +627,7 @@ LogUtils::str_to_ip(char *ipstr)
   return ip;
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   LogUtils::valid_ipstr_format
 
   This routine checks for a string formated as an ip address.
@@ -692,16 +692,16 @@ LogUtils::seconds_to_next_roll(time_t ti
   return ((tr >= sidl ? (tr - sidl) % rolling_interval : (86400 - (sidl - tr)) % rolling_interval));
 }
 
-// Converts the ink64 val argument to a null terminated string, returning a 
+// Converts the ink64 val argument to a null terminated string, returning a
 // pointer to the beginning of the string.
 //
-// The string is stored in the provided buffer if the buffer is large 
+// The string is stored in the provided buffer if the buffer is large
 // enough, otherwise the buffer is not touched, and the function returns NULL.
 //
 // The argument total_chars returns the number of characters that were
-// converted or that would have been converted if the buffer had been large 
+// converted or that would have been converted if the buffer had been large
 // enough. total_chars includes the null terminator.
-// 
+//
 // The optional arguments req_width and pad_char allow users to
 // specify a requested width of the output string (including the null
 // terminator), and a padding character to use to reach that width. Padding
@@ -814,7 +814,7 @@ LogUtils::ink64_to_str(char *buf, unsign
 // resulting string, then places the string in buf WITHOUT A
 // NULL-TERMINATING CHARACTER, and returns the number of characters written.
 //
-// If the provided buffer is too small, leaves it untouched and 
+// If the provided buffer is too small, leaves it untouched and
 // returns -(required_buffer_size)
 //
 int
@@ -868,8 +868,8 @@ LogUtils::squid_timestamp_to_buf(char *b
 // returns:
 //  0 on success
 // -1 on system error (no permission, etc.)
-//  1 if the file full_filename points to is neither a regular file 
-//    nor a pipe 
+//  1 if the file full_filename points to is neither a regular file
+//    nor a pipe
 //
 int
 LogUtils::file_is_writeable(const char *full_filename,

Modified: trafficserver/traffic/tags/2.1.0/proxy/logstats.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/logstats.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/logstats.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/logstats.cc Thu May 13 17:43:56 2010
@@ -1760,7 +1760,7 @@ main(int argc, char *argv[])
   char ts_path[PATH_NAME_MAX + 1];
 
   // build the application information structure
-  appVersionInfo.setup(PACKAGE_NAME,PROGRAM_NAME, PACKAGE_VERSION, __DATE__, 
+  appVersionInfo.setup(PACKAGE_NAME,PROGRAM_NAME, PACKAGE_VERSION, __DATE__,
                        __TIME__, BUILD_MACHINE, BUILD_PERSON, "");
 
   // Initialize some globals

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AddConfigFilesHere.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AddConfigFilesHere.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AddConfigFilesHere.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AddConfigFilesHere.cc Thu May 13 17:43:56 2010
@@ -33,8 +33,8 @@ static char INK_UNUSED rcsId__AddConfigF
 /****************************************************************************
  *
  *  AddConfigFilesHere.cc - Structs for config files and
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 void
@@ -49,7 +49,7 @@ testcall(char *foo)
 //
 // Code to initialze of registry of objects that represent
 //   Web Editable configuration files
-// 
+//
 // thread-safe: NO!  - Should only be executed once from the main
 //                     web interface thread, before any child
 //                     threads have been spawned

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.cc Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2007-10-05 16:56:44 $
  *
- * 
+ *
  */
 
 #include "inktomi++.h"
@@ -269,7 +269,7 @@ Alarms::signalAlarm(alarm_t a, const cha
 
   /*
    * Exec alarm bin for priority alarms everytime, regardless if they are
-   * potentially duplicates. However, only exec this for you own alarms, 
+   * potentially duplicates. However, only exec this for you own alarms,
    * don't want every node in the cluster reporting the same alarm.
    */
   if (priority == 1 && alarm_bin && alarm_bin_path && !ip) {
@@ -288,7 +288,7 @@ Alarms::signalAlarm(alarm_t a, const cha
     }
     snprintf(buf, sizeof(buf), "%d", a);
     if (ink_hash_table_lookup(local_alarms, buf, &hash_value) != 0) {
-      // INKqa11884: if wireless alarm already active, just 
+      // INKqa11884: if wireless alarm already active, just
       // update desc with new timestamp and skip to actions part
       if (a == MGMT_ALARM_WDA_BILLING_CONNECTION_DIED ||
           a == MGMT_ALARM_WDA_BILLING_CORRUPTED_DATA ||
@@ -309,7 +309,7 @@ Alarms::signalAlarm(alarm_t a, const cha
       atmp = (Alarm *) hash_value;
       atmp->seen = true;
 
-      // INKqa11884: if wireless alarm already active, just 
+      // INKqa11884: if wireless alarm already active, just
       // update desc with new timstamp and skip to actions part
       if (a == MGMT_ALARM_WDA_BILLING_CONNECTION_DIED ||
           a == MGMT_ALARM_WDA_BILLING_CORRUPTED_DATA ||
@@ -697,7 +697,7 @@ Alarms::execAlarmBin(const char *desc)
 // getAlarmText
 //
 // returns the corresponding text for the alarm id
-// 
+//
 const char *
 Alarms::getAlarmText(alarm_t id)
 {

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Alarms.h Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@
  *
  * $Date: 2007-10-05 16:56:44 $
  *
- * 
+ *
  */
 
 #ifndef _ALARMS_H
@@ -84,7 +84,7 @@
 
 #define MGMT_ALARM_SAC_SERVER_DOWN		400
 
-// ACC alarms -- 200-300 -- I tried using just one, but a bunch of 'ACL was dropped' 
+// ACC alarms -- 200-300 -- I tried using just one, but a bunch of 'ACL was dropped'
 // warnings didn't get to the manager UI, that's badness.
 #define MGMT_ALARM_ACC_ALARMS_START              200
 #define MGMT_ALARM_ACC_ALARMS_END                299
@@ -93,8 +93,8 @@ extern const char *alarmText[];
 extern const int alarmTextNum;
 
 
-/* OEM_ALARM: the alarm type is used as a key for hash tables; 
-   need offset and modulo constants which will keep the unique 
+/* OEM_ALARM: the alarm type is used as a key for hash tables;
+   need offset and modulo constants which will keep the unique
    keys for OEM alarms within a specified range */
 const int minOEMkey = 1000;     // used as offset
 const int maxOEMkey = 6000;
@@ -151,7 +151,7 @@ private:
   InkHashTable *local_alarms;
   InkHashTable *remote_alarms;
 
-  /* counter is added in order to provide unique keys for OEM alarms, 
+  /* counter is added in order to provide unique keys for OEM alarms,
      since an OEM_ALARM type can be associated with many different
      alarm descriptions */
   int alarmOEMcount;

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.cc Thu May 13 17:43:56 2010
@@ -35,8 +35,8 @@
 /****************************************************************************
  *
  *  AutoConf.cc - code to generate and delete client autoconf files
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #define FILE_MODE S_IRWXU
@@ -235,7 +235,7 @@ AutoConf::pacErrorResponse(const char *a
 // Added extra argument 'flag' to distinguish between displaying
 // the 'proxy.pac' info in a the frame or a seperate window.  - GV
 void
-AutoConf::handleView(textBuffer * output, int flag      // 0-> displaying in framset, 1-> displaying in seperate window 
+AutoConf::handleView(textBuffer * output, int flag      // 0-> displaying in framset, 1-> displaying in seperate window
   )
 {
   const char a[] =
@@ -289,7 +289,7 @@ AutoConf::handleView(textBuffer * output
       }
     }
   } else {
-    // in frame    
+    // in frame
     output->copyFrom(a, strlen(a));
 
     if (configFiles->getRollbackObj("proxy.pac", &pacRoll) == false) {

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/AutoConf.h Thu May 13 17:43:56 2010
@@ -27,8 +27,8 @@
 /****************************************************************************
  *
  *  AutoConf.h - code to generate and delete client autoconf files
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #include "MultiFile.h"
@@ -53,7 +53,7 @@ public:
   ~AutoConf();
   void processAction(char *submission, textBuffer * output);
   void displayAutoConfPage(textBuffer * output);
-  void handleView(textBuffer * output, int flag);       // Moved from private->public to help handle 
+  void handleView(textBuffer * output, int flag);       // Moved from private->public to help handle
   // Bug INKqa00991 -GV
 private:
     PACresult handleCreate(InkHashTable * params);

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.cc Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2003-06-01 18:37:18 $
  *
- * 
+ *
  */
 
 #include "inktomi++.h"
@@ -78,14 +78,14 @@ BaseManager::~BaseManager()
 /*
  * registerMgmtCallback(...)
  *   Function to register callback's for various management events, such
- * as shutdown, re-init, etc. The following callbacks should be 
+ * as shutdown, re-init, etc. The following callbacks should be
  * registered:
  *                MGMT_EVENT_SHUTDOWN  (graceful shutdown)
  *                MGMT_EVENT_RESTART   (graceful reboot)
  *                ...
  *
  *   Returns:   -1      on error(invalid event id passed in)
- *               or     value 
+ *               or     value
  */
 int
 BaseManager::registerMgmtCallback(int msg_id, MgmtCallback cb, void *opaque_cb_data)

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseManager.h Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2004-02-03 22:12:02 $
  *
- * 
+ *
  */
 
 #ifndef _BASE_MANAGER_H
@@ -41,7 +41,7 @@
 #include "MgmtDefs.h"
 
 
-/******************************************* 
+/*******************************************
  * used by LocalManager and in Proxy Main. *
  */
 #define MAX_OPTION_SIZE        2048

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.cc Thu May 13 17:43:56 2010
@@ -1360,7 +1360,7 @@ BaseRecords::readString(const char *name
 
 
 /*
- * Special purpose read functions for reading records of a name from a 
+ * Special purpose read functions for reading records of a name from a
  * copy of the BaseRecords records array.
  */
 MgmtIntCounter
@@ -2356,7 +2356,7 @@ BaseRecords::registerUpdateLockFunc(Upda
 }                               /* End BaseRecords::registerUpdateLockFunc */
 
 /*
- * Special interface that does not take out the lock(assumes caller has) 
+ * Special interface that does not take out the lock(assumes caller has)
  */
 MgmtIntCounter
 BaseRecords::rl_readCounter(int id, RecordType type, bool * found)

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/BaseRecords.h Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  * by other Record classes, who implmenet update methods dependent on
  * whether they are a supplier or consumer of the data.
  *
- * 
+ *
  */
 
 #ifndef _BASE_RECORDS_H
@@ -52,7 +52,7 @@ typedef enum
 } UpdateLockAction;
 typedef void *(*UpdateLockFunc) (UpdateLockAction action);
 
-/* 
+/*
  * RecordType
  *   A list of the types of records currently used.
  */
@@ -160,8 +160,8 @@ public:
   MgmtFloat readFloat(const char *name, bool * found = NULL);
   MgmtString readString(const char *name, bool * found = NULL);
 
-  /* 
-   * Special interface, requires lock(rl_). Use with care! 
+  /*
+   * Special interface, requires lock(rl_). Use with care!
    *    Created for use during change callbacks, in case you need to know the
    *    "current" value of another record in order to perform a reconfig.
    */

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.cc Thu May 13 17:43:56 2010
@@ -35,8 +35,8 @@
 /****************************************************************************
  *
  *  FileManager.cc - Code for class to manage configuration updates
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 static const char snapDir[] = "snapshots";
@@ -82,9 +82,9 @@ FileManager::FileManager()
                "[FileManager::FileManager] Unable to find configuration directory from proxy.config.config_dir\n");
   }
   if ((err = stat(configTmp, &statBuf)) < 0) {
-    ink_strncpy(configTmp, system_config_directory,sizeof(configTmp)); 
+    ink_strncpy(configTmp, system_config_directory,sizeof(configTmp));
     if ((err = stat(configTmp, &statBuf)) < 0) {
-        mgmt_elog("[FileManager::FileManager] unable to stat() directory '%s': %d %d, %s\n", 
+        mgmt_elog("[FileManager::FileManager] unable to stat() directory '%s': %d %d, %s\n",
                 mgmt_path, err, errno, strerror(errno));
         mgmt_elog("[FileManager::FileManager] please set config path via command line '-path <path>' or 'proxy.config.config_dir' \n");
         _exit(1);
@@ -155,10 +155,10 @@ FileManager::~FileManager()
 }
 
 
-// void FileManager::registerCallback(FileCallbackFunc func) 
+// void FileManager::registerCallback(FileCallbackFunc func)
 //
 //  Adds a new callback function
-//    callbacks are made whenever a configuration file has 
+//    callbacks are made whenever a configuration file has
 //    changed
 //
 //  The callback function is responsible for free'ing
@@ -202,7 +202,7 @@ FileManager::addFile(const char *baseFil
 // bool FileManager::getRollbackObj(char* baseFileName, Rollback** rbPtr)
 //
 //  Sets rbPtr to the rollback object associated
-//    with the passed in baseFileName. 
+//    with the passed in baseFileName.
 //
 //  If there is no binding, falseis returned
 //
@@ -253,7 +253,7 @@ FileManager::fileChanged(const char *bas
   ink_mutex_release(&cbListLock);
 }
 
-// textBuffer* FileManager::filesManaged() 
+// textBuffer* FileManager::filesManaged()
 //
 //  Returns a comma separated list of all files currently being
 //    managed by this object
@@ -289,7 +289,7 @@ FileManager::filesManaged()
   return result;
 }
 
-// void FileManager::doRollbackLocks(lockAction_t action) 
+// void FileManager::doRollbackLocks(lockAction_t action)
 //
 //  Iterates through the Rollback objects we are managing
 //    and performs the parameter specified action on each lock
@@ -324,7 +324,7 @@ FileManager::doRollbackLocks(lockAction_
 }
 
 
-// void FileManager::abortRestore(const char* abortTo) 
+// void FileManager::abortRestore(const char* abortTo)
 //
 //  Iterates through the hash table of managed files
 //    and Rollsback one version until we get to the file
@@ -441,9 +441,9 @@ FileManager::restoreSnap(const char *sna
 
 
 
-// SnapResult FileManager::removeSnap(const char* snapName) 
+// SnapResult FileManager::removeSnap(const char* snapName)
+//
 //
-//  
 SnapResult
 FileManager::removeSnap(const char *snapName, const char *snapDir)
 {
@@ -673,7 +673,7 @@ FileManager::readFile(const char *filePa
   return SNAP_OK;
 }
 
-//  SnapResult FileManager::copyFile(Rollback* rb, const char* snapPath) 
+//  SnapResult FileManager::copyFile(Rollback* rb, const char* snapPath)
 //
 //  Copies a file (represented by Rollback* rb) into a snapshot
 //    directory (snapPath)
@@ -730,7 +730,7 @@ FileManager::copyFile(Rollback * rb, con
 
 
 
-// SnapResult FileManager::WalkSnaps(ExpandingArray* snapList) 
+// SnapResult FileManager::WalkSnaps(ExpandingArray* snapList)
 //
 //   Iterates through the snapshot directory and adds every snapshot
 //     into the parameter snapList
@@ -823,7 +823,7 @@ FileManager::rereadConfig()
   }
 }
 
-// void FileManager::displaySnapPage(textBuffer* output, httpResponse& answerHdr) 
+// void FileManager::displaySnapPage(textBuffer* output, httpResponse& answerHdr)
 //
 //  Generates an HTML page with the add form and the list
 //    of current snapshots
@@ -878,7 +878,7 @@ FileManager::createSelect(char *action, 
 }
 
 
-// bool checkValidName(const char* name) 
+// bool checkValidName(const char* name)
 //
 // if the string is invalid, ie. all white spaces or contains "irregular" chars,
 // returns 0 ; returns 1 if valid string
@@ -899,12 +899,12 @@ FileManager::checkValidName(const char *
 }
 
 
-//  int snapEntryCmpFunc(void* e1, void* e2) 
-//  
+//  int snapEntryCmpFunc(void* e1, void* e2)
+//
 //  a cmp function for snapshot structs that can
 //     used with qsort
 //
-//  compares c_time 
+//  compares c_time
 //
 int
 snapEntryCmpFunc(const void *e1, const void *e2)

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/FileManager.h Thu May 13 17:43:56 2010
@@ -27,8 +27,8 @@
 /****************************************************************************
  *
  *  FileManager.h - Interface for class to manage configuration updates
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #include <stdio.h>
@@ -75,7 +75,7 @@ class ExpandingArray;
 //
 //  addFile(char*, configFileInfo*) - adds a new config file to be
 //       managed.  A rollback object is created for the file.
-//       if the file_info ptr is not NULL, a WebFileEdit object 
+//       if the file_info ptr is not NULL, a WebFileEdit object
 //       is also created
 //
 //  getRollbckObj(char* , RollbackPtr**) - sets *rbPtr to Rollback
@@ -88,7 +88,7 @@ class ExpandingArray;
 //
 //  registerCallback(FileCallbackFunc) - registers a callback function
 //       which will get called everytime a managed file changes.  The
-//       callback function should NOT use the calling thread to 
+//       callback function should NOT use the calling thread to
 //       access any Rollback objects or block for a long time
 //
 //  fileChanged(const char* baseFileName) - called by Rollback objects

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.cc Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@
  *
  * $Date: 2008-05-20 17:26:20 $
  *
- * 
+ *
  */
 
 #include "ink_config.h"

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LMRecords.h Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2006-03-08 19:40:19 $
  *
- * 
+ *
  */
 
 #ifndef _LM_RECORDS_H

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.cc Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* 
+/*
  *
  * LocalManager.cc
  * - The Local Manager process of the management system.
@@ -84,7 +84,7 @@ LocalManager::mgmtShutdown(int status, b
     if (processRunning()) {
       waitpid(watched_process_pid, &status, 0);
 #if (HOST_OS == linux)
-      /* Avert race condition, wait for the thread to complete, 
+      /* Avert race condition, wait for the thread to complete,
          before getting one more restart process */
       /* Workaround for bugid INKqa10060 */
       mgmt_sleep_msec(1);
@@ -363,7 +363,7 @@ BaseManager(), run_proxy(proxy_on), reco
     xfree(config_path);
     config_path = xstrdup(system_config_directory);
     if ((err = stat(config_path, &s)) < 0) {
-        mgmt_elog("[LocalManager::LocalManager] unable to stat() directory '%s': %d %d, %s\n", 
+        mgmt_elog("[LocalManager::LocalManager] unable to stat() directory '%s': %d %d, %s\n",
                 config_path, err, errno, strerror(errno));
         mgmt_fatal("[LocalManager::LocalManager] please set config path via command line '-path <path>' or 'proxy.config.config_dir' \n");
     }
@@ -386,7 +386,7 @@ BaseManager(), run_proxy(proxy_on), reco
     snprintf(absolute_proxy_binary, absolute_proxy_binary_size, "%s%s%s%s", system_root_dir,bin_path, DIR_SEP, proxy_binary);
     // coverity[fs_check_call]
     if ((err = stat(absolute_proxy_binary, &s)) < 0) {
-        mgmt_elog("[LocalManager::LocalManager] Unable to find '%s': %d %d, %s\n", 
+        mgmt_elog("[LocalManager::LocalManager] Unable to find '%s': %d %d, %s\n",
                 absolute_proxy_binary, err, errno, strerror(errno));
         mgmt_fatal("[LocalManager::LocalManager] please set bin path 'proxy.config.bin_path' \n");
     }
@@ -912,7 +912,7 @@ LocalManager::sendMgmtMsgToProcesses(Mgm
 
       // In case of Linux, sometimes when the TS dies, the connection between TS and TM
       // is not closed properly. the socket does not receive an EOF. So, the TM does
-      // not detect that the connection and hence TS has gone down. Hence it still 
+      // not detect that the connection and hence TS has gone down. Hence it still
       // tries to send a message to TS, but encounters an error and enters here
       // Also, ensure that this whole thing is done only once because there will be a
       // deluge of message in the traffic.log otherwise
@@ -1084,7 +1084,7 @@ LocalManager::convert_filters()
     char *absolute_convert_binary = (char *) alloca(absolute_convert_binary_size);
     snprintf(absolute_convert_binary, absolute_convert_binary_size, "%s%s%s", bin_path, DIR_SEP, convert_bin);
 
-    // check that the binary exists 
+    // check that the binary exists
     struct stat fileInfo;
     if (stat(absolute_convert_binary, &fileInfo) < 0) {
       mgmt_elog(stderr,

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/LocalManager.h Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* 
+/*
  *
  * LocalManager.h
  *   Definitions for the LocalManager class.

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.cc Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* 
+/*
  *
  * Main.cc
  * - Entry point to the traffic manager.
@@ -313,10 +313,10 @@ init_dirs(bool use_librecords = true)
       REC_ReadConfigString(mgmt_path, "proxy.config.config_dir", PATH_NAME_MAX);
     if ((err = stat(mgmt_path, &s)) < 0) {
       // Try 'system_root_dir/etc/trafficserver' directory
-      snprintf(mgmt_path, sizeof(mgmt_path), 
+      snprintf(mgmt_path, sizeof(mgmt_path),
                "%s%s%s%s%s",system_root_dir, DIR_SEP,"etc",DIR_SEP,"trafficserver");
       if ((err = stat(mgmt_path, &s)) < 0) {
-        mgmt_elog("unable to stat() mgmt path '%s': %d %d, %s\n", 
+        mgmt_elog("unable to stat() mgmt path '%s': %d %d, %s\n",
                 mgmt_path, err, errno, strerror(errno));
         mgmt_elog("please set config path via command line '-path <path>' or 'proxy.config.config_dir' \n");
         _exit(1);
@@ -325,16 +325,16 @@ init_dirs(bool use_librecords = true)
   }
 
   if ((err = stat(system_config_directory, &s)) < 0) {
-    ink_strncpy(system_config_directory,mgmt_path,sizeof(system_config_directory)); 
+    ink_strncpy(system_config_directory,mgmt_path,sizeof(system_config_directory));
     if ((err = stat(system_config_directory, &s)) < 0) {
       if (use_librecords)
         REC_ReadConfigString(system_config_directory, "proxy.config.config_dir", PATH_NAME_MAX);
       if ((err = stat(system_config_directory, &s)) < 0) {
         // Try 'system_root_dir/etc/trafficserver' directory
-        snprintf(system_config_directory, sizeof(system_config_directory), 
+        snprintf(system_config_directory, sizeof(system_config_directory),
                  "%s%s%s%s%s",system_root_dir, DIR_SEP,"etc",DIR_SEP,"trafficserver");
         if ((err = stat(system_config_directory, &s)) < 0) {
-          mgmt_elog("unable to stat() config dir '%s': %d %d, %s\n", 
+          mgmt_elog("unable to stat() config dir '%s': %d %d, %s\n",
                     system_config_directory, err, errno, strerror(errno));
           mgmt_elog("please set config path via command line '-path <path>' or 'proxy.config.config_dir' \n");
           _exit(1);
@@ -348,10 +348,10 @@ init_dirs(bool use_librecords = true)
       REC_ReadConfigString(system_local_state_dir, "proxy.config.local_state_dir", PATH_NAME_MAX);
     if ((err = stat(system_local_state_dir, &s)) < 0) {
       // Try 'system_root_dir/var/trafficserver' directory
-      snprintf(system_local_state_dir, sizeof(system_local_state_dir), 
+      snprintf(system_local_state_dir, sizeof(system_local_state_dir),
                "%s%s%s%s%s",system_root_dir, DIR_SEP,"var",DIR_SEP,"trafficserver");
       if ((err = stat(system_local_state_dir, &s)) < 0) {
-        mgmt_elog("unable to stat() local state dir '%s': %d %d, %s\n", 
+        mgmt_elog("unable to stat() local state dir '%s': %d %d, %s\n",
                 system_local_state_dir, err, errno, strerror(errno));
         mgmt_elog("please set 'proxy.config.local_state_dir'\n");
         _exit(1);
@@ -367,7 +367,7 @@ init_dirs(bool use_librecords = true)
       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) {
-        mgmt_elog("unable to stat() log dir'%s': %d %d, %s\n", 
+        mgmt_elog("unable to stat() log dir'%s': %d %d, %s\n",
                 system_log_dir, err, errno, strerror(errno));
         mgmt_elog("please set 'proxy.config.log2.logfile_dir'\n");
         _exit(1);
@@ -514,7 +514,7 @@ main(int argc, char **argv)
   }
 
   // Set up the application version info
-  appVersionInfo.setup(PACKAGE_NAME,"traffic_manager", PACKAGE_VERSION, 
+  appVersionInfo.setup(PACKAGE_NAME,"traffic_manager", PACKAGE_VERSION,
                        __DATE__, __TIME__, BUILD_MACHINE, BUILD_PERSON, "");
   initSignalHandlers();
 
@@ -696,7 +696,7 @@ main(int argc, char **argv)
 
   check_lockfile();
 
-  snprintf(config_internal_dir, sizeof(config_internal_dir), 
+  snprintf(config_internal_dir, sizeof(config_internal_dir),
                "%s%sinternal", mgmt_path, DIR_SEP);
   url_init(config_internal_dir);
   mime_init(config_internal_dir);

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/Main.h Thu May 13 17:43:56 2010
@@ -54,7 +54,7 @@ extern FileManager *configFiles;
 extern overviewPage *overviewGenerator;
 extern AppVersionInfo appVersionInfo;
 
-// Global strings 
+// Global strings
 extern char mgmt_path[];
 extern const char *recs_conf;
 //extern char *lm_conf;

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.cc Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2003-06-01 18:37:18 $
  *
- * 
+ *
  */
 
 #include "ink_config.h"

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/MgmtDBM.h Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
  *
  * $Date: 2003-06-01 18:37:18 $
  *
- * 
+ *
  */
 
 #ifndef _MGMT_DBM_H