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 [17/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/mgmt2/web2/WebIntrMain.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.cc Thu May 13 17:43:56 2010
@@ -250,22 +250,22 @@ setUpLogging()
   char log_file[PATH_NAME_MAX+1];
 
   if ((err = stat(system_log_dir, &s)) < 0) {
-    ink_assert(RecGetRecordString_Xmalloc("proxy.config.log2.logfile_dir", &log_dir) 
+    ink_assert(RecGetRecordString_Xmalloc("proxy.config.log2.logfile_dir", &log_dir)
 	       == REC_ERR_OKAY);
     if ((err = stat(log_dir, &s)) < 0) {
       // Try 'system_root_dir/var/log/trafficserver' directory
       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);
       }
     } else {
-      ink_strncpy(system_log_dir,log_dir,sizeof(system_log_dir)); 
+      ink_strncpy(system_log_dir,log_dir,sizeof(system_log_dir));
     }
-  } 
+  }
 
   snprintf(log_file, sizeof(log_file), "%s%s%s", system_log_dir, DIR_SEP, "lm.log");
 
@@ -789,7 +789,7 @@ webIntr_main(void *x)
       xfree(autoconfContext.docRoot);
       autoconfContext.docRoot = xstrdup(system_config_directory);
       if ((err = stat(autoconfContext.docRoot, &s)) < 0) {
-        mgmt_elog("[WebIntrMain] unable to stat() directory '%s': %d %d, %s\n", 
+        mgmt_elog("[WebIntrMain] unable to stat() directory '%s': %d %d, %s\n",
                 autoconfContext.docRoot, err, errno, strerror(errno));
         mgmt_elog("[WebIntrMain] please set config path via command line '-path <path>' or 'proxy.config.config_dir' \n");
         mgmt_fatal(stderr, "[WebIntrMain] No Client AutoConf Root\n");
@@ -843,8 +843,8 @@ webIntr_main(void *x)
 
 
   // INKqa09866
-  // fire up interface for ts configuration through API; use absolute path from root to 
-  // set up socket paths; 
+  // fire up interface for ts configuration through API; use absolute path from root to
+  // set up socket paths;
   char api_sock_path[1024];
   char event_sock_path[1024];
 

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebIntrMain.h Thu May 13 17:43:56 2010
@@ -28,8 +28,8 @@
  *
  *  WebIntrMain.h - main loop for the Web Interface
  *
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 struct WebContext;

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.cc Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  *
  *  WebOverview.cc - code to overview page
  *
- * 
+ *
  ****************************************************************************/
 
 #include "ink_config.h"
@@ -169,7 +169,7 @@ overviewRecord::getStatus(char **hostnam
 // void overviewRecord::updateStatus(time_t, ClusterPeerInfo*)
 // updates up/down status based on the cluster peer info record
 //
-//   currentTime is the value of localtime(time()) - sent in as 
+//   currentTime is the value of localtime(time()) - sent in as
 //     a parameter so we do not have to make repetitive system calls.
 //     overviewPage::checkForUpdates can just make one call
 //
@@ -260,7 +260,7 @@ overviewRecord::checkAlarms()
 //  overview::readFloat, overview::readString
 //
 //  Accessor functions for node records.  For remote node,
-//    we get the value in the node_data array we maintain 
+//    we get the value in the node_data array we maintain
 //    in this object.  For the node, we do not maintain any data
 //    and rely on lmgmt->record_data for both the retrieval
 //    code and the records array
@@ -398,9 +398,9 @@ overviewRecord::readString(const char *n
 //  Accessor function for node records.  Looks up varName for
 //    this node and if found, turns it value into a string
 //    and places it in bufVal
-// 
+//
 //  return true if bufVal was succefully set
-//    and false otherwise 
+//    and false otherwise
 //
 //  EVIL ALERT: varStrFromName in WebMgmtUtils.cc is extremely
 //    similar to this function except in how it gets it's
@@ -620,7 +620,7 @@ overviewPage::checkForUpdates()
 }
 
 
-// overrviewPage::sortHosts() 
+// overrviewPage::sortHosts()
 //
 // resorts sortRecords, but always leaves the local node
 //   as the first record
@@ -634,7 +634,7 @@ overviewPage::sortHosts()
   qsort(array + 1, numHosts - 1, sizeof(void *), hostSortFunc);
 }
 
-// overviewPage::addRecord(ClusterPerrInfo* cpi) 
+// overviewPage::addRecord(ClusterPerrInfo* cpi)
 //   Adds a new node record
 //   Assuems that this->accessLock is already held
 //
@@ -886,8 +886,8 @@ overviewPage::generateAlarmsTableCLI(tex
     // Iterate through the list of alarms
     curAlarm = current->nodeAlarms.head;
     while (curAlarm != NULL) {
-      //  
-      //  The resolve input is <alarmId>:<ip addr>  
+      //
+      //  The resolve input is <alarmId>:<ip addr>
       //
       if (curAlarm->ip == NULL)
         snprintf(ipBuf, sizeof(ipBuf), "%s", "local");
@@ -925,7 +925,7 @@ overviewPage::generateAlarmsTableCLI(tex
     }                           // end while(.)
   }                             // end for(.)
 
-  // cleanup 
+  // cleanup
   delete Obuf;
 
   ink_mutex_release(&accessLock);
@@ -995,7 +995,7 @@ overviewPage::generateAlarmsSummary(WebH
 
 }
 
-// generates the table for the overview page 
+// generates the table for the overview page
 //
 //  the entries are   hostname, on/off, alarm
 //
@@ -1616,7 +1616,7 @@ overviewPage::agCachePercentFree()
   ink_assert(varSetFloat("proxy.cluster.cache.percent_free", pFree));
 }
 
-// void overviewPage::agCacheHitRate() 
+// void overviewPage::agCacheHitRate()
 //
 //   Updates OLD proxy.cluster.http.cache_hit_ratio
 //               proxy.cluster.http.cache_total_hits
@@ -1701,7 +1701,7 @@ overviewPage::agCacheHitRate()
       MgmtInt num_nodes;
       varIntFromName("proxy.process.cluster.nodes", &num_nodes);
       if (1 == num_nodes) {
-        // Only one node , so grab local value 
+        // Only one node , so grab local value
         varFloatFromName("proxy.node.cache_hit_ratio_avg_10s", &hitRate);
       }
       // new stat
@@ -1731,7 +1731,7 @@ overviewPage::agCacheHitRate()
   ink_assert(varSetInt("proxy.cluster.cache_total_misses", totalMisses));
 }
 
-// void overviewPage::agHostDBHitRate() 
+// void overviewPage::agHostDBHitRate()
 //
 //   Updates proxy.cluster.hostdb.hit_ratio
 //
@@ -1812,7 +1812,7 @@ overviewPage::agHostdbHitRate()
       MgmtInt num_nodes;
       varIntFromName("proxy.process.cluster.nodes", &num_nodes);
       if (1 == num_nodes) {
-        // Only one node , so grab local value 
+        // Only one node , so grab local value
         varFloatFromName("proxy.node.hostdb.hit_ratio_avg_10s", &hitRate);
       }
       // new stat
@@ -1843,7 +1843,7 @@ overviewPage::agHostdbHitRate()
   ink_assert(varSetFloat("proxy.cluster.hostdb.hit_ratio", hitRate));
 }
 
-// void overviewPage::agBandwidthHitRate() 
+// void overviewPage::agBandwidthHitRate()
 //
 //   Updates proxy.cluster.http.bandwidth_hit_ratio
 //
@@ -1873,7 +1873,7 @@ overviewPage::agBandwidthHitRate()
   // Get total cluster hits first, only calculate bandwith if > 0
   varIntFromName("proxy.cluster.http.cache_total_hits", &totalHits);
 
-  // User Agent 
+  // User Agent
 
   // HTTP
   varIntFromName("proxy.cluster.http.user_agent_total_request_bytes", &bytes);
@@ -1969,7 +1969,7 @@ overviewPage::agBandwidthHitRate()
       MgmtInt num_nodes;
       varIntFromName("proxy.process.cluster.nodes", &num_nodes);
       if (1 == num_nodes) {
-        // Only one node , so grab local value 
+        // Only one node , so grab local value
         varFloatFromName("proxy.node.bandwidth_hit_ratio_avg_10s", &hitRate);
       }
       // new stat
@@ -2379,7 +2379,7 @@ overviewPage::resolvePeerHostname_ml(con
 //   Takes a hash-table returned by processFormSubmission
 //
 //   Note: resolving an alarm is asyncronous with the list of
-//      alarms maintained in overviewRecords.  That list 
+//      alarms maintained in overviewRecords.  That list
 //      is only updates when checkAlarms is called
 //
 void
@@ -2429,7 +2429,7 @@ resolveAlarmCLI(textBuffer * output, con
   const char *ipAddr = NULL;
   alarm_t alarmType;
 
-  // Get ipAddr of host to resolve alarm for 
+  // Get ipAddr of host to resolve alarm for
   // request is in form 'alarmType:ipAddr'
   if (request && colonTok.Initialize(request) == 2) {
     alarmType = atoi(colonTok[0]);
@@ -2476,7 +2476,7 @@ AlarmListable::~AlarmListable()
   }
 }
 
-// int hostSortFunc(const void* arg1, const void* arg2) 
+// int hostSortFunc(const void* arg1, const void* arg2)
 //
 //   A compare function that we can to qsort that sorts
 //    overviewRecord*

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebOverview.h Thu May 13 17:43:56 2010
@@ -42,16 +42,16 @@
  *
  *  WebOverview.h - code to overview page
  *
- * 
+ *
  ****************************************************************************/
 
-// 
+//
 //  There is one instance of the class overviewPage in the LocalManger
 //    process.  The overviewPage instance stores a record of type
 //    overviewRecord for each node that has been seen in the cluster.
 //    The node records contain a list of active alarms on that node.
 //
-//  overviewPage is responsible for the synchronization issues for both 
+//  overviewPage is responsible for the synchronization issues for both
 //    it self and all of its overviewRecords.  Whenever updates are made
 //    to instances of either class, overviewPage's accessLock must be held.
 //
@@ -62,9 +62,9 @@
 //
 //  Additional Notes
 //
-//  These classes have expanded over time.  overviewPage and 
+//  These classes have expanded over time.  overviewPage and
 //    overviewRecord are now clearing houses of cluster information
-//    for the UI.  
+//    for the UI.
 //  To simplify the locking issues, pointer to overviewRecords should
 //    NOT be returned by overviewPage.  overviewRecords are internal
 //    to overviewPage and any data needed from an overviewRecord
@@ -124,7 +124,7 @@ public:
   overviewPage();
   ~overviewPage();
   /*
-     void generateTable(textBuffer* output, 
+     void generateTable(textBuffer* output,
      const char* submission,
      WebContext* pContext);
    */

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.cc Thu May 13 17:43:56 2010
@@ -42,8 +42,8 @@
 /****************************************************************************
  *
  *  WebReconfig.cc - code to handle config vars that can change on the fly
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 // Since we don't want to steal the manager's main thread we get

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebReconfig.h Thu May 13 17:43:56 2010
@@ -27,8 +27,8 @@
 /****************************************************************************
  *
  *  WebReconfig.h - code to handle config vars that can change on the fly
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #include "P_RecCore.h"

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.cc Thu May 13 17:43:56 2010
@@ -34,8 +34,8 @@
  *
  *  WebUtils.cc - Misc Utility Functions for the web server internface
  *
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #ifdef HAVE_LIBSSL
@@ -46,7 +46,7 @@
 
 /* Ugly hack - define HEAP_H and STACK_H to prevent stuff
  *   from the template library from being included which
- *   SUNPRO CC does not not like.  
+ *   SUNPRO CC does not not like.
  */
 #define HEAP_H
 #define STACK_H

Modified: trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/mgmt2/web2/WebUtils.h Thu May 13 17:43:56 2010
@@ -28,8 +28,8 @@
  *
  *  WebUtils.h - Misc Utility Functions for the web server internface
  *
- *  
- * 
+ *
+ *
  ****************************************************************************/
 
 #include "ink_platform.h"
@@ -39,7 +39,7 @@ struct WebContext;
 
 /* Ugly Hack - declare
  *  SSLcon as void* instead of SSL since this prevents  us from
- *  including ssl.h right here which creates a whole bunch of 
+ *  including ssl.h right here which creates a whole bunch of
  *  nasty problem to MD5 conflicts with ink_code.h.
  */
 struct SocketInfo

Modified: trafficserver/traffic/tags/2.1.0/proxy/sac.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/sac.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/sac.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/sac.cc Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
 
  Standalone Collator
 
- 
+
  ***************************************************************************/
 #include "ink_unused.h"
 
@@ -81,7 +81,7 @@ ArgumentDescription argument_description
 int n_argument_descriptions = SIZE(argument_descriptions);
 
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   main
   -------------------------------------------------------------------------*/
 
@@ -91,7 +91,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, "");
 
   // take care of command-line arguments
@@ -102,7 +102,7 @@ main(int argc, char *argv[])
   // Get TS directory
   if (0 == get_ts_directory(ts_path,sizeof(ts_path))) {
     ink_strncpy(system_root_dir, ts_path, sizeof(system_root_dir));
-  } 
+  }
 
   management_directory[0] = 0;
   strncat(management_directory, system_config_directory, 256 - 1);

Modified: trafficserver/traffic/tags/2.1.0/proxy/signals.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/signals.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/signals.cc (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/signals.cc Thu May 13 17:43:56 2010
@@ -318,7 +318,7 @@ signal_handler(int sig, siginfo_t * t, v
 #else
   snprintf(sig_msg, sizeof(sig_msg), "NOTE: Traffic Server received Sig %d: %s\n", sig, strsignal(sig));
   NOWARN_UNUSED_RETURN(write(2, sig_msg, strlen(sig_msg)));
-  //syslog(LOG_ERR, sig_msg); 
+  //syslog(LOG_ERR, sig_msg);
 #endif
 
 #ifdef HAVE_PROFILER
@@ -487,7 +487,7 @@ init_signals(bool do_stackdump)
 //  set_signal(SIGSEGV,(SigActionFunc_t)signal_handler);
 //
 //  There was an an addtional #if 0 w/ a note about SIGABRT
-//   // Do not catch, results in recursive 
+//   // Do not catch, results in recursive
 //   //  SIGABRT loop on solaris assert() failures
 //  set_signal(SIGABRT,(SigActionFunc_t)signal_handler);
 //

Modified: trafficserver/traffic/tags/2.1.0/proxy/signals.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/signals.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/signals.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/signals.h Thu May 13 17:43:56 2010
@@ -35,7 +35,7 @@
 
 extern int exited_children;
 typedef void (*sig_callback_fptr) (int signo);
-/* 
+/*
 *  plugins use this to attach clean up handlers
 *  for SIGSEGV and SIGBUS
 *  Return value: 0 on success, -1 on failure

Modified: trafficserver/traffic/tags/2.1.0/proxy/stats/CoupledStats.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/stats/CoupledStats.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/stats/CoupledStats.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/stats/CoupledStats.h Thu May 13 17:43:56 2010
@@ -145,7 +145,7 @@ CoupledStats::CreateStat(const char *nam
     return NULL;
   }
   //FIXME: old sdk didnt use category, we _should_ but how to config ...
-  //else if (ret = StatDescriptor::CreateDescriptor(m_name, name, init_val)) 
+  //else if (ret = StatDescriptor::CreateDescriptor(m_name, name, init_val))
   else if ((ret = StatDescriptor::CreateDescriptor(name, init_val))) {
     ink_mutex_acquire(&m_mux);
     grow_check(ret);
@@ -165,7 +165,7 @@ CoupledStats::CreateStat(const char *nam
     return NULL;
   }
   //FIXME: old sdk didnt use category, we _should_ but how to config ...
-  //else if (ret = StatDescriptor::CreateDescriptor(m_name, name, init_val)) 
+  //else if (ret = StatDescriptor::CreateDescriptor(m_name, name, init_val))
   else if ((ret = StatDescriptor::CreateDescriptor(name, init_val))) {
     ink_mutex_acquire(&m_mux);
     grow_check(ret);

Modified: trafficserver/traffic/tags/2.1.0/proxy/ts_resource.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/proxy/ts_resource.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/proxy/ts_resource.h (original)
+++ trafficserver/traffic/tags/2.1.0/proxy/ts_resource.h Thu May 13 17:43:56 2010
@@ -28,7 +28,7 @@
 #define IDI_ICON1                       101
 
 // Next default values for new objects
-// 
+//
 #ifdef APSTUDIO_INVOKED
 #ifndef APSTUDIO_READONLY_SYMBOLS
 #define _APS_NEXT_RESOURCE_VALUE        107

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/Config.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/Config.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/Config.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/Config.cc Thu May 13 17:43:56 2010
@@ -285,7 +285,7 @@ Config::Config(long warmup, char *config
       process_line(line_no, line, i, lhs, rhs);
 
 #ifdef _PLUG_IN
-      // target_host, target_port, and document_base 
+      // target_host, target_port, and document_base
       // will be passed to the INKOptionProcess() later, and
       // comments are skipped.
       if ((strcmp(lhs, "target_host") || strcmp(lhs, "target_port") || strcmp(lhs, "document_base")) && strcmp(lhs, "")) {
@@ -525,5 +525,5 @@ Config::Config(long warmup, char *config
     (plug_in->options_process_finish_fcn) ();
   }
 #endif
-  /////////////////////////////    
+  /////////////////////////////
 }

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.cc Thu May 13 17:43:56 2010
@@ -80,10 +80,10 @@ DoTest::initialize_stats()
     target_byterate_generated[i] = 0;
   }
 
-  // number of transactions that had limited target_byterate 
+  // number of transactions that had limited target_byterate
   num_limited_byterate = 0;
 
-  // Total error among all the limited byterate trans 
+  // Total error among all the limited byterate trans
   total_limited_byterate_error = 0;
 
   connections_open = 0;
@@ -283,7 +283,7 @@ DoTest::create_new_connection_and_send_r
 }
 
 
-// User i just finished, update stats 
+// User i just finished, update stats
 void
 DoTest::update_completion_stats(int i)
 {
@@ -858,7 +858,7 @@ DoTest::actual_test(int rr_flag)
             }
             finished_requests += keepalive;
             update_completion_stats(i);
-          } else {              // 200 response            
+          } else {              // 200 response
             fprintf(stderr,
                     "Error: user %d got 200 response:\n%s but got only %ld bytes when %ld bytes were requested;\nRequest sent [%s]\n%ld msec since connection opened; %ld msec since last read\nPOLLIN count = %d;  number of read calls returning data = %d\n\n",
                     i, user_info[i].status_line_info.buffer, user_info[i].bytes_read, user_info[i].bytes_requested,
@@ -931,7 +931,7 @@ DoTest::actual_test(int rr_flag)
 
           }
 
-        } else {                // s > 0 
+        } else {                // s > 0
           /* Transaction is not complete yet. You just read some
              bytes so update stats.. */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/DoTest.h Thu May 13 17:43:56 2010
@@ -155,11 +155,11 @@ struct DoTest
   /* It will report how many latencies were above this cutoff (in msec) */
   long above_round_trip_time_cutoff;    /* Req above latency cutoff */
   long first_byte_latency_cutoff;
-  /* It will report how many first byte latencies were above 
+  /* It will report how many first byte latencies were above
      this cutoff (in msec) */
   long above_first_byte_latency_cutoff; /* Req above first-byte cutoff */
   long connect_time_cutoff;
-  /* It will report how many connect times were above 
+  /* It will report how many connect times were above
      this cutoff (in msec) */
   long above_connect_time_cutoff;       /* Req above connect cutoff */
 
@@ -170,7 +170,7 @@ struct DoTest
   histogram connect_histogram;
 
   long generated_thinktime;     /* Total number of reqs generated */
-  long thinktime_generated[MAX_THINKTIMES];     /* Number of reqs with 
+  long thinktime_generated[MAX_THINKTIMES];     /* Number of reqs with
                                                    each thinktime */
   double total_actual_thinktime;
 
@@ -178,9 +178,9 @@ struct DoTest
   long target_byterate_generated[MAX_TARGET_BYTERATES];
   /* Number of reqs with each target_byterate */
   long num_limited_byterate;
-  // number of transactions that had limited target_byterate 
+  // number of transactions that had limited target_byterate
   double total_limited_byterate_error;
-  // Total error among all the limited byterate trans 
+  // Total error among all the limited byterate trans
   int reporting_interval;
 
   int connections_open;
@@ -198,9 +198,9 @@ struct DoTest
   int num_target_byterates;     /* Number of thinktimes in the distribution */
   long *target_byterates;       /* actual thinktimes */
   double *cumulative_target_byterate_prob;
-  /* Cumulative probability of selecting different 
-     target_byterates 
-     cumulative_target_byterate_prob[num_thinktimes-1] 
+  /* Cumulative probability of selecting different
+     target_byterates
+     cumulative_target_byterate_prob[num_thinktimes-1]
      must be 1.0 */
 
   UserInfo *user_info;
@@ -213,7 +213,7 @@ struct DoTest
   INKPlugin *plug_in;
   long warmup;
   // =0: real test, > 0 : warmup; create only warmup number of
-  // requests 
+  // requests
   int users;
   int poll_timeout;
   int keepalive;
@@ -245,7 +245,7 @@ struct DoTest
 
   long generate_target_byterate();
   long compute_bytes_to_read(int user, struct timeval current_time);
-  // User i just finished, update stats 
+  // User i just finished, update stats
   void update_completion_stats(int i);
   int create_new_connection_and_send_request(int user, struct timeval current_time);
   void initialize_stats();

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.cc Thu May 13 17:43:56 2010
@@ -99,7 +99,7 @@ LoadGenerator::initialize_targets()
 
 // generates strings "size0" to "sizeN" where total number of sizes
 // is N+1. Used only for synthetic documents. Also returns the
-// corresponding expected size 
+// corresponding expected size
 
 void
 LoadGenerator::generate_size_str(char *size_str, long *size_requested_p)
@@ -157,7 +157,7 @@ LoadGenerator::generate_serial_number_st
 }
 
 /* Generate a server str of the form: "server0"..
-"serverN-1", where N is the number of origin servers. 
+"serverN-1", where N is the number of origin servers.
 Only applicable for synthetic load */
 
 void
@@ -233,11 +233,11 @@ LoadGenerator::create_synthetic_request(
     }
     if (!more_request) {
       strcpy(req_string, "");
-      // ready to finish inkbench and print stats      
+      // ready to finish inkbench and print stats
       return;
     } else if (strcmp(dynamic_origin_server_name, "") != 0 &&
                strcmp(dynamic_origin_server_port, "") != 0 && strcmp(req_string, "") != 0) {
-      // generate new sockaddr and origin_server_str based on the 
+      // generate new sockaddr and origin_server_str based on the
       // dynamic_origin_server_name and dynamic_origin_server_port
       if (direct) {
         generate_dynamic_origin_server_target(dynamic_origin_server_name, dynamic_origin_server_port, target);
@@ -318,7 +318,7 @@ LoadGenerator::create_synthetic_request(
       return;
     } else if (strcmp(dynamic_origin_server_name, "") != 0 &&
                strcmp(dynamic_origin_server_port, "") != 0 && strcmp(req_string, "") != 0) {
-      // generate new sockaddr and origin_server_str based on the 
+      // generate new sockaddr and origin_server_str based on the
       // dynamic_origin_server_name and dynamic_origin_server_port
       if (direct) {
         generate_dynamic_origin_server_target(dynamic_origin_server_name, dynamic_origin_server_port, target);

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/LoadGenerator.h Thu May 13 17:43:56 2010
@@ -51,7 +51,7 @@ struct LoadGenerator
   long max_hotset_serial_num;
   long max_docset_serial_num;
 
-  // Config variables 
+  // Config variables
   int debug;
   int ssl;
   int keepalive;                /* how many requests per connection */
@@ -77,7 +77,7 @@ struct LoadGenerator
   int direct;
   INKPlugin *plug_in;
   double *cumulative_size_prob;
-  /* Cumulative probability of selecting different sizes 
+  /* Cumulative probability of selecting different sizes
      cumulative_size_prob[num_sizes-1] must be 1.0 */
 
   // Stats
@@ -127,7 +127,7 @@ struct LoadGenerator
                 int anum_sizes, /* Number of sizes in the docsize distribution */
                 long *asizes,   /* actual sizes */
                 double *acumulative_size_prob,
-                /* Cumulative probability of selecting different sizes 
+                /* Cumulative probability of selecting different sizes
                    cumulative_size_prob[num_sizes-1] must be 1.0 */
                 int adirect, INKPlugin * aplug_in)
   {

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/BlackList.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/BlackList.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/BlackList.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/BlackList.c Thu May 13 17:43:56 2010
@@ -25,18 +25,18 @@
  *
  *
  * Description
- *   - Generate requests to the web servers listed in the files specified 
- *     by allowed_host_file and forbidden_host_file in some forbidden 
- *     ratio specified in the configuration file.  This example is 
- *     targeted to test the performance of proxy server with filtering 
+ *   - Generate requests to the web servers listed in the files specified
+ *     by allowed_host_file and forbidden_host_file in some forbidden
+ *     ratio specified in the configuration file.  This example is
+ *     targeted to test the performance of proxy server with filtering
  *     functionality.
  *
  * Added Options in SDKtest_client.config -
- *   forbidden_ratio     : percentage of blacklisted requests we 
+ *   forbidden_ratio     : percentage of blacklisted requests we
  *                         want to generate
- *   allowed_host_file   : full path of the file that contains the 
+ *   allowed_host_file   : full path of the file that contains the
  *                         allowed sites
- *   forbidden_host_file : full path of the file that contains the 
+ *   forbidden_host_file : full path of the file that contains the
  *                         forbidden sites
  */
 
@@ -213,7 +213,7 @@ INKHeaderProcess(void *req_id, char *hea
     return INK_KEEP_GOING;
   }
 
-  /* we consider the request to the blacklisted 
+  /* we consider the request to the blacklisted
    * sites to be successful documents */
   else if (strstr(header, "403 Forbidden")) {
     my_plugin.forbidden_documents++;

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend-1.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend-1.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend-1.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend-1.c Thu May 13 17:43:56 2010
@@ -33,7 +33,7 @@
  * running.
  * Make sure that append-transform plugin is loaded on the TS-proxy used.
  *
- * Added Options in client/SDKtest_client.config -  
+ * Added Options in client/SDKtest_client.config -
  *   append-file-path : full path of the file containing the appended text
  *              eg. /home/user/file.txt
  *   use_live_url: 1 = use live url 0 = use SDKtest server
@@ -101,7 +101,7 @@ INKPluginInit(int client_id)
   my_plugin.go_direct = 0;
 
   fprintf(stderr, "*** CheckAppend-1 Test for append-transform-plugin v1.0***\n");
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -212,12 +212,12 @@ INKPluginFinish()
   fclose(my_plugin.url_file);
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -263,8 +263,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckAppend.c Thu May 13 17:43:56 2010
@@ -33,7 +33,7 @@
  * running.
  * Make sure that append-transform plugin is loaded on the TS-proxy used.
  *
- * Added Options in client/SDKtest_client.config -  
+ * Added Options in client/SDKtest_client.config -
  *   append-file-path : full path of the file containing the appended text
  *              eg. /home/user/file.txt
  *   use_live_url: 1 = use live url 0 = use SDKtest server
@@ -105,7 +105,7 @@ INKPluginInit(int client_id)
   my_plugin.url_file_present = 0;
 
   fprintf(stderr, "*** CheckAppend Test for append-transform-plugin v1.0***\n");
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -220,12 +220,12 @@ INKPluginFinish()
   }
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -277,8 +277,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckContentClient.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckContentClient.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckContentClient.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/CheckContentClient.c Thu May 13 17:43:56 2010
@@ -26,7 +26,7 @@
  *
  * Description:
  *   - Do sanity check on every byte in the responsed documents
- *     Note: This plugin needs to work with CheckContentServer 
+ *     Note: This plugin needs to work with CheckContentServer
  *           plugin for SDKtest_server
  */
 
@@ -56,7 +56,7 @@ INKPartialBodyProcess(void *req_id, void
 {
   int i, code;
 
-  /* check to see if the content in the 
+  /* check to see if the content in the
    * buffer is what we expect ie. "01234567890123..."
    */
   i = partial_length;

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/RequestList.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/RequestList.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/RequestList.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/RequestList.c Thu May 13 17:43:56 2010
@@ -25,19 +25,19 @@
  *
  *
  * Description
- *   - Generate requests to the web servers listed in the files specified 
- *     in the request lists, specified in the configuration file. 
+ *   - Generate requests to the web servers listed in the files specified
+ *     in the request lists, specified in the configuration file.
  *     Also use the ratio specified with the request lists to generate the
  *     right distribution of requests.
- *     
+ *
  *
  * Added Options in SDKtest_client.config -
- *   request_lists : full path of the file[s] that contain the 
- *                   request lists. Also need to specify the 
- *                   request ratio. Example : 
+ *   request_lists : full path of the file[s] that contain the
+ *                   request lists. Also need to specify the
+ *                   request ratio. Example :
  *                   request_lists=/home/bob/list1:20,/home/bob/list2:80
  *                   Note: comma is the seperator. do not leave space or tabs inbetween
- *                   This will cause 20 % of requests to go from list1 and 
+ *                   This will cause 20 % of requests to go from list1 and
  *                   80 % from list2.
  *                   Note : the ratios MUST add upto 100.
  */

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-0.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-0.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-0.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-0.c Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  *
  *
  * Description:
- *  This plugin adds "Proxy-Authorization" header to the synthetic SDKtest_client 
+ *  This plugin adds "Proxy-Authorization" header to the synthetic SDKtest_client
  *  requests to load test the basic-auth sample plugin.  The credentials are read from
  *  the configuration file
  */
@@ -91,7 +91,7 @@ INKPluginInit(int client_id)
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
 
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -162,12 +162,12 @@ INKPluginFinish()
   }
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -204,8 +204,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
@@ -317,8 +317,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-1.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-1.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-1.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimBasicAuth-1.c Thu May 13 17:43:56 2010
@@ -25,8 +25,8 @@
  *
  *
  * Description:
- *  This SDKtest_client plugin sends live URL requests (from a URL file) w/ the 
- *  "Proxy-Authorization" header to load test the basic-auth plugin.  The url file and 
+ *  This SDKtest_client plugin sends live URL requests (from a URL file) w/ the
+ *  "Proxy-Authorization" header to load test the basic-auth plugin.  The url file and
  *  the credentials are specified in the configuration file.
  */
 
@@ -97,7 +97,7 @@ INKPluginInit(int client_id)
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
 
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -176,12 +176,12 @@ INKPluginFinish()
   fclose(my_plugin.url_file);
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -226,8 +226,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
@@ -240,12 +240,12 @@ INKHeaderProcess(void *req_id, char *hea
  * server or from proxy server
  */
 /*
-INKRequestAction INKPartialBodyProcess(void *req_id, 
+INKRequestAction INKPartialBodyProcess(void *req_id,
 		void *partial_content,
-		int partial_length, 
-		int accum_length) 
+		int partial_length,
+		int accum_length)
 {
-	if (partial_length == 0) { 
+	if (partial_length == 0) {
 		if (accum_length >= ((User *)req_id)->doc_size_requested) {
 			my_plugin.total_bytes_received += (accum_length + ((User *)req_id)->header_bytes);
 			my_plugin.successful_requests++;
@@ -350,8 +350,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBench.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBench.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBench.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBench.c Thu May 13 17:43:56 2010
@@ -293,8 +293,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBenchCache.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBenchCache.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBenchCache.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimInkBenchCache.c Thu May 13 17:43:56 2010
@@ -321,8 +321,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtest.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtest.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtest.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtest.c Thu May 13 17:43:56 2010
@@ -88,7 +88,7 @@ INKPluginInit(int client_id)
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
 
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -155,12 +155,12 @@ INKPluginFinish()
   }
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -194,8 +194,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
@@ -307,8 +307,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtestCache.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtestCache.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtestCache.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SimSDKtestCache.c Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  *
  *
  * Description:
- *   - Simulate the default way of generating requests by the 
+ *   - Simulate the default way of generating requests by the
  *     SDKtest_client with cachability specified in the client
  *     request header in some ratio.
  *
@@ -98,7 +98,7 @@ INKPluginInit(int client_id)
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
 
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -167,12 +167,12 @@ INKPluginFinish()
   }
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -222,8 +222,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
@@ -335,8 +335,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SingleHostFilter.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SingleHostFilter.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SingleHostFilter.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/SingleHostFilter.c Thu May 13 17:43:56 2010
@@ -27,9 +27,9 @@
  *   Added Options in SDKtest_client.config -
  *
  *     forbidden_ratio : percentage of forbidden requests we want to
- *                       generate		       
+ *                       generate
  *
- *     forbidden_host  : the blacklisted host name 
+ *     forbidden_host  : the blacklisted host name
  *                       eg. www.playboy.com
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/header_process.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/header_process.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/header_process.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/header_process.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* header_process.c 
+/* header_process.c
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/hello_world.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/hello_world.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/hello_world.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/hello_world.c Thu May 13 17:43:56 2010
@@ -23,9 +23,9 @@
 
 /* hello_world.c
  *
- * 
+ *
  * Description:
- *   - demonstrate the most basic routine of writing the SDKtest_client 
+ *   - demonstrate the most basic routine of writing the SDKtest_client
  *     plugin
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/CheckAppend.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/CheckAppend.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/CheckAppend.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/CheckAppend.c Thu May 13 17:43:56 2010
@@ -33,7 +33,7 @@
  * running.
  * Make sure that append-transform plugin is loaded on the TS-proxy used.
  *
- * Added Options in client/SDKtest_client.config -  
+ * Added Options in client/SDKtest_client.config -
  *   append-file-path : full path of the file containing the appended text
  *              eg. /home/user/file.txt
  */

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/TestCacheAPI.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/TestCacheAPI.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/TestCacheAPI.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/internal/TestCacheAPI.c Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  *
  *
  * Description:
- *   - Simulate the default way of generating requests by the 
+ *   - Simulate the default way of generating requests by the
  *     SDKtest_client with the foll. added options.
  *     . add CacheTester-Pin: <time> to some ratio of requests specified in SDKtest_client.config
  *     . add CacheTester-HostNameSet: 1 to some ratio of requests specified in SDKtest_client.config
@@ -102,7 +102,7 @@ INKPluginInit(int client_id)
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
 
-  /* register the plugin functions that are called back 
+  /* register the plugin functions that are called back
    * later in the program */
   INKFuncRegister(INK_FID_OPTIONS_PROCESS);
   INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
@@ -173,12 +173,12 @@ INKPluginFinish()
   }
 }
 
-/* generate requests that are understood by the SDKtest_server 
+/* generate requests that are understood by the SDKtest_server
  *   URL Format:
  *     http://hostname:port/serial_number/lengthxxx
  *   Note:
  *     request_buf has to be filled in the complete request header
- *     i.e. GET URL HTTP/1.0 .... 
+ *     i.e. GET URL HTTP/1.0 ....
  */
 int
 INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
@@ -261,8 +261,8 @@ INKRequestCreate(char *origin_server_hos
   return TRUE;
 }
 
-/* process response header returned either from synthetic 
- * server or from proxy server 
+/* process response header returned either from synthetic
+ * server or from proxy server
  */
 INKRequestAction
 INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
@@ -374,8 +374,8 @@ read_docsize_dist()
   }
 }
 
-/* parse the origin_server string in config file. 
- * value is in the form of "host1:port1 host2:port2 ..." 
+/* parse the origin_server string in config file.
+ * value is in the form of "host1:port1 host2:port2 ..."
  */
 void
 parse_origin_server_str(char *value)

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/report.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/report.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/report.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/report.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* report.c 
+/* report.c
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/request_create.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/request_create.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/request_create.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/client/api/request_create.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* request_create.c 
+/* request_create.c
  *
  */
 
@@ -44,7 +44,7 @@ INKRequestCreate(char *origin_server_hos
                  void **req_id /* return */ )
 {
 
-  /* if we do not fill the request_buf, the default 
+  /* if we do not fill the request_buf, the default
    * request generated by SDKtest_client will be used
    */
   return TRUE;

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/CheckContentServer.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/CheckContentServer.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/CheckContentServer.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/CheckContentServer.c Thu May 13 17:43:56 2010
@@ -25,9 +25,9 @@
  *
  *
  * Description:
- *   - Response the client requests in the format of '0123456789012..' 
- *     until it reaches the number of bytes the client requested.  
- *     In that case, the client can check the correctness of the responsed 
+ *   - Response the client requests in the format of '0123456789012..'
+ *     until it reaches the number of bytes the client requested.
+ *     In that case, the client can check the correctness of the responsed
  *     document.
  *     Note: This example needs to work with CheckContentClient plugin
  *           for SDKtest_client.
@@ -139,7 +139,7 @@ INKResponsePut(void **resp_id /* return 
       *resp_bytes += copy;
     }
   }
-  /* return NULL as the resp_id to indicate 
+  /* return NULL as the resp_id to indicate
    * that it is the last INKResponsePut call */
   if (rid->bytes_not_sent <= 0 || rid->status_code != 200) {
     free(rid);

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/LogRequest.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/LogRequest.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/LogRequest.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/LogRequest.c Thu May 13 17:43:56 2010
@@ -21,15 +21,15 @@
   limitations under the License.
  */
 
-/* LogRequest.c 
+/* LogRequest.c
  *
  *
  * Description:
- *   - Log the requests that are received from the clients into a file 
+ *   - Log the requests that are received from the clients into a file
  *     specified in the server configuration file.
  *
- * Added Options in Synth_server.config -  
- *   log_path : full path of the log file 
+ * Added Options in Synth_server.config -
+ *   log_path : full path of the log file
  *              eg. /home/user/file.log
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServer.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServer.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServer.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServer.c Thu May 13 17:43:56 2010
@@ -21,11 +21,11 @@
   limitations under the License.
  */
 
-/* SimSynthServer.c 
+/* SimSynthServer.c
  *
  *
  * Description:
- *   - simulate the default way of responding requests by the 
+ *   - simulate the default way of responding requests by the
  *     SDKtest_server
  */
 
@@ -96,7 +96,7 @@ INKResponsePut(void **resp_id /* return 
     rid->done_sent_header = TRUE;
   }
 
-  /* copy the content into the response buffer and 
+  /* copy the content into the response buffer and
    * the response would be like "XXXXXX......E"
    */
   if (rid->status_code == 200) {
@@ -112,7 +112,7 @@ INKResponsePut(void **resp_id /* return 
 
     }
   }
-  /* return NULL as the resp_id to indicate 
+  /* return NULL as the resp_id to indicate
    * that it is the last INKResponsePut call */
   if (rid->bytes_not_sent <= 0 || rid->status_code != 200) {
     free(rid);

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServerCache.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServerCache.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServerCache.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/SimSynthServerCache.c Thu May 13 17:43:56 2010
@@ -21,15 +21,15 @@
   limitations under the License.
  */
 
-/* SimSynthServerCache.c 
+/* SimSynthServerCache.c
+ *
  *
- * 
  * Description:
  *   - Simulate the default way of responding requests by the SDKtest_server
  *     with cachability specified in the server response header in some
  *     ratio.
  *
- * Added Options in Synth_server.config -    
+ * Added Options in Synth_server.config -
  *     cachability : percentage of cachable response we want to generate
  */
 
@@ -140,7 +140,7 @@ INKResponsePut(void **resp_id /* return 
   }
 
   /* copy the content into the response buffer and
-   * the response would be like "XXXXXX......E" 
+   * the response would be like "XXXXXX......E"
    */
   if (rid->status_code == 200) {
     if (rid->bytes_not_sent + i > resp_buffer_size) {
@@ -155,7 +155,7 @@ INKResponsePut(void **resp_id /* return 
 
     }
   }
-  /* return NULL as the resp_id to indicate 
+  /* return NULL as the resp_id to indicate
    * if it is the last INKResponsePut call */
   if (rid->bytes_not_sent <= 0 || rid->status_code != 200) {
     free(rid);

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/hello_world.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/hello_world.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/hello_world.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/hello_world.c Thu May 13 17:43:56 2010
@@ -25,7 +25,7 @@
  *
  *
  * Description:
- *   - demonstrate the most basic routine of writing the SDKtest_server 
+ *   - demonstrate the most basic routine of writing the SDKtest_server
  *     plugin
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* options_process.c 
+/* options_process.c
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process_finish.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process_finish.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process_finish.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/options_process_finish.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* options_process_finish.c 
+/* options_process_finish.c
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/plugin_finish.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/plugin_finish.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/plugin_finish.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/plugin_finish.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* plugin_finish.c 
+/* plugin_finish.c
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/response_prepare.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/response_prepare.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/response_prepare.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/api/response_prepare.c Thu May 13 17:43:56 2010
@@ -21,7 +21,7 @@
   limitations under the License.
  */
 
-/* response_prepare.c 
+/* response_prepare.c
  *
  */
 

Modified: trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/synth_server.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/synth_server.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/synth_server.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/SDKtest/synth_server/synth_server.c Thu May 13 17:43:56 2010
@@ -92,9 +92,9 @@ int poll_stat_var;
 #endif
 int poll_retval;
 
-/* 
+/*
    initialize the default values for memory allocation. the size of
-   the solaris executable with the default values is around 60MB 
+   the solaris executable with the default values is around 60MB
  */
 long max_output_string = MAX_OUTPUT;
 long max_users = MAX_USERS;
@@ -136,7 +136,7 @@ int num_sizes;
 long sizes[MAX_SIZES];
     /* actual sizes                                        */
 float cumulative_size_prob[MAX_SIZES];
-    /* Cumulative probability of selecting different sizes 
+    /* Cumulative probability of selecting different sizes
      * cumulative_size_prob[num_sizes-1] must be 1.0       */
 
 #define COMM_OK           (0)

Modified: trafficserver/traffic/tags/2.1.0/test/deft/log_sender.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/log_sender.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/log_sender.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/log_sender.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _LOG_SENDER_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 // Avoiding getting the whole libinktomi++ header file since
@@ -3214,7 +3214,7 @@ InstallerHandler::set_read_status(int st
 
   if (watch_proc == NULL) {
 
-    // Process has already exited 
+    // Process has already exited
     if (read_status == 1 && error_seen == false) {
       handle_install_success();
     } else {
@@ -3745,7 +3745,7 @@ finish_startup()
 
   memcpy(&orig_ports_avail, &ports_avail, sizeof(PortsAvail));
 
-  // Start the control port 
+  // Start the control port
   accept_handler = new AcceptHandler();
   accept_handler->start(control_port);
 
@@ -3810,7 +3810,7 @@ redirect_stdout_stderr()
 //
 //    redirect stdout/stderr to a file
 //
-//    fork ourselves 
+//    fork ourselves
 //
 void
 remote_startup()

Modified: trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/proc_manager.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _PROC_MANAGER_H_

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

Modified: trafficserver/traffic/tags/2.1.0/test/deft/raf_cmd.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/raf_cmd.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/raf_cmd.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/raf_cmd.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _RAF_CMD_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/remote_start.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/remote_start.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/remote_start.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/remote_start.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include <unistd.h>

Modified: trafficserver/traffic/tags/2.1.0/test/deft/remote_start.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/remote_start.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/remote_start.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/remote_start.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _REMOTE_START_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.cc Thu May 13 17:43:56 2010
@@ -29,7 +29,7 @@
       A simple single reader io buffer which keeps data continguous
          by copying it
 
-   
+
  ****************************************************************************/
 
 #include <stdlib.h>

Modified: trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/sio_buffer.h Thu May 13 17:43:56 2010
@@ -59,7 +59,7 @@ public:
 
   char *memchr(int c, int len = INT_MAX, int offset = 0);
 
-  // consume data 
+  // consume data
   int read(char *buf, int len);
 
   // does not consume data

Modified: trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 

Modified: trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/sio_loop.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _SIO_LOOP_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include <errno.h>

Modified: trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/sio_raf_server.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _SIO_RAF_SERVER_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_exec.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_exec.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_exec.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_exec.cc Thu May 13 17:43:56 2010
@@ -1443,8 +1443,8 @@ set_var_value(const char *var, const cha
 }
 
 // char* construct_instance_file_path(InstanceRecord* irec, const char* file)
-// 
-//  CALLER FREES return value 
+//
+//  CALLER FREES return value
 static char *
 construct_instance_file_path(InstanceRecord * irec, const char *file)
 {
@@ -1471,8 +1471,8 @@ construct_instance_file_path(InstanceRec
 }
 
 // char* construct_instance_file_path(InstanceRecord* irec, const char* file)
-// 
-//  CALLER FREES return value 
+//
+//  CALLER FREES return value
 static char *
 construct_script_file_path(const char *file)
 {
@@ -1565,7 +1565,7 @@ put_instance_file_raw(const char *instan
 
   Debug("put_file", "sending put_file %s %s %s", full_path, length_buf, mode_buf);
 
-  // Set up 
+  // Set up
   RafCmd request;
   RafCmd response;
   request(0) = irec->host_rec->get_id_str();
@@ -1674,7 +1674,7 @@ put_instance_file_subs(const char *insta
 
   Debug("put_file", "sending put_file %s %s %s", full_path, length_buf, mode_buf);
 
-  // Set up 
+  // Set up
   RafCmd request;
   RafCmd response;
   request(0) = irec->host_rec->get_id_str();
@@ -1852,7 +1852,7 @@ wait_for_server_port(const char *instanc
   //
   //   1) all digits - converted to int
   //   2) %%(var) - deft var substitution done and then converted to int
-  //   3) other string - looked up in port bindings has for instance 
+  //   3) other string - looked up in port bindings has for instance
   //      and then converted to int
   int port = -1;
   if (isdigit(port_str[0])) {

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_exec.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_exec.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_exec.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_exec.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _TEST_EXEC_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_exec_perl.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_exec_perl.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_exec_perl.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_exec_perl.c Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include <EXTERN.h>

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

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

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_interp_glue.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_interp_glue.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_interp_glue.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_interp_glue.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _TEST_INTERP_GLUE_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "test_log_collate.h"
@@ -363,7 +363,7 @@ main(int argc, char **argv)
   SIO::add_exit_handler(new ExitHandler);
   init_output_log();
 
-  // Start the control port 
+  // Start the control port
   accept_handler = new LogAcceptHandler();
   accept_handler->start(collate_port);
 

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_log_collate.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _TEST_LOG_COLLATE_H_

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

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_results.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_results.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_results.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_results.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _TEST_RESULTS_H_

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_utils.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_utils.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_utils.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_utils.cc Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include <strings.h>
@@ -44,7 +44,7 @@
 #include "raf_cmd.h"
 
 // char** build_argv(const char* arg0, const char* rest)
-//    
+//
 //   Uses rafdecode to handle quoting on arg 'rest'
 //
 char **

Modified: trafficserver/traffic/tags/2.1.0/test/deft/test_utils.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/deft/test_utils.h?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/deft/test_utils.h (original)
+++ trafficserver/traffic/tags/2.1.0/test/deft/test_utils.h Thu May 13 17:43:56 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _TEST_UTILS_H_

Modified: trafficserver/traffic/tags/2.1.0/test/plugin/CacheAPITester/CacheAPITester.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/plugin/CacheAPITester/CacheAPITester.c?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/plugin/CacheAPITester/CacheAPITester.c (original)
+++ trafficserver/traffic/tags/2.1.0/test/plugin/CacheAPITester/CacheAPITester.c Thu May 13 17:43:56 2010
@@ -952,7 +952,7 @@ get_client_req(INKHttpTxn txnp, char **p
     /* We'll get a block pointer back even if there is no data
        left to read so check for this condition and break out of
        the loop. A block with no data to read means we've exhausted
-       buffer of data since if there was more data on a later 
+       buffer of data since if there was more data on a later
        block in the chain, this block would have been skipped over */
     if (block_avail == 0) {
       break;

Modified: trafficserver/traffic/tags/2.1.0/test/plugin/INKAction/INKAction.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/tags/2.1.0/test/plugin/INKAction/INKAction.cc?rev=943951&r1=943950&r2=943951&view=diff
==============================================================================
--- trafficserver/traffic/tags/2.1.0/test/plugin/INKAction/INKAction.cc (original)
+++ trafficserver/traffic/tags/2.1.0/test/plugin/INKAction/INKAction.cc Thu May 13 17:43:56 2010
@@ -32,12 +32,12 @@
 #include <stdio.h>
 #include <stdlib.h>
 
-/* INKAction 
- * 
+/* INKAction
+ *
  * TODO send and receive data on the connection
 */
 
-/* cvrt unsigned int address to dotted decimal address  
+/* cvrt unsigned int address to dotted decimal address
  * delete on the otherside, otherwise: don't care
 */
 char *
@@ -66,8 +66,8 @@ typedef struct clientInfo
   int port;
 } clientInfo_t;
 
-/* Assumes that type-o-serve.pl (or some other client accepting 
- * connections) is running on a client machine 
+/* Assumes that type-o-serve.pl (or some other client accepting
+ * connections) is running on a client machine
 */
 static int
 handle_INKAction(INKCont contp, INKEvent event, void *eData)
@@ -84,7 +84,7 @@ handle_INKAction(INKCont contp, INKEvent
 
   switch (event) {
   case INK_EVENT_IMMEDIATE:
-    /* event scheduled at plugIn-init 
+    /* event scheduled at plugIn-init
      */
     clientInfop = (clientInfo_t *) INKContDataGet(contp);
     if (!clientInfop) {
@@ -113,7 +113,7 @@ handle_INKAction(INKCont contp, INKEvent
              clientName, htonl(clientAddr), ntohl(clientInfop->port));
 
     /* We should get NET_CONNECT or NET_CONNECT_FAILED before
-     * this schedule timeout event 
+     * this schedule timeout event
      */
     INKContSchedule(contp, TIMEOUT_VAL);
 
@@ -163,8 +163,8 @@ handle_INKAction(INKCont contp, INKEvent
 
 
 
-/* Usage: 
- * INKAction.so clientName clientPort 
+/* Usage:
+ * INKAction.so clientName clientPort
 */
 void
 INKPluginInit(int argc, const char *argv[])