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

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

Modified: trafficserver/traffic/trunk/proxy/ICP.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ICP.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ICP.h (original)
+++ trafficserver/traffic/trunk/proxy/ICP.h Thu May 13 07:09:39 2010
@@ -26,7 +26,7 @@
 
   ICP.h
 
-  
+
 ****************************************************************************/
 
 #ifndef _ICP_H_
@@ -103,7 +103,7 @@ typedef enum
 #define ICP_OP_LAST		(ICP_OP_END_OF_OPS - 1)
 
 //-----------------------
-// version definitions 
+// version definitions
 //-----------------------
 #define ICP_VERSION_1		1
 #define ICP_VERSION_2		2
@@ -117,7 +117,7 @@ typedef enum
 #define ICP_FLAG_SRC_RTT 	0x40000000ul
 
 //-----------------
-// ICP Constants 
+// ICP Constants
 //-----------------
 #define MAX_ICP_MSGSIZE		   (16 * 1024)
 #define MAX_ICP_MSG_PAYLOAD_SIZE   (MAX_ICP_MSGSIZE - sizeof(ICPmsgHdr_t))
@@ -130,11 +130,11 @@ typedef enum
 //------------
 typedef struct ICPData
 {
-  ink8 *URL;                    // null terminated 
+  ink8 *URL;                    // null terminated
 } ICPData_t;
 
 //-------------
-// ICP Query 
+// ICP Query
 //-------------
 typedef struct ICPQuery
 {
@@ -147,7 +147,7 @@ typedef struct ICPQuery
 //------------
 typedef struct ICPHit
 {
-  ink8 *URL;                    // null terminated 
+  ink8 *URL;                    // null terminated
 } ICPHit_t;
 
 //------------
@@ -155,11 +155,11 @@ typedef struct ICPHit
 //------------
 typedef struct ICPMiss
 {
-  ink8 *URL;                    // null terminated 
+  ink8 *URL;                    // null terminated
 } ICPMiss_t;
 
 //------------------
-// ICP Hit Object 
+// ICP Hit Object
 //------------------
 typedef struct ICPHitObj
 {
@@ -474,7 +474,7 @@ private:
   // All ICP operation is based on "icp_data" and "peer_cdata".
   // The "icp_data_current" and "peer_cdata_current" reflect the
   // current state of the configuration.  "icp_data_current" is
-  // updated via configuration callouts.  "peer_cdata_current" 
+  // updated via configuration callouts.  "peer_cdata_current"
   // is updated by the periodic ICP processor event (ICPPeriodicCont),
   // when configuration management signals us with a callout on "icp.config".
   // We merge current to working only after disabling ICP operation and
@@ -700,16 +700,16 @@ private:
   Connection _send_chan;
   Connection _recv_chan;
   //---------------------------
-  // Multicast specific data 
+  // Multicast specific data
   //---------------------------
   struct sockaddr_in _mc_addr;
   int _mc_ttl;
   struct multicast_data
   {
-    double avg_members;         // running avg of multicast responders 
+    double avg_members;         // running avg of multicast responders
     int defined_members;        // as specified in icp.config
     int n_count_events;         // responder count events
-    int count_event_reqno;      // reqno associated with count event 
+    int count_event_reqno;      // reqno associated with count event
     int expected_replies;       // current expected responders on multicast
   } _mc;
 };
@@ -1140,7 +1140,7 @@ public:
   { ICP_REQUEST_HASH_SIZE = 1024 };
 
   //***********************************************************************
-  // ICPPeerReadCont::PeerReadStateMachine() to 
+  // ICPPeerReadCont::PeerReadStateMachine() to
   // ICPRequestCont::ICPStateMachine() calling sequence definition.
   //
   //     ICPRequestEvent(ICP_RESPONSE_MESSAGE, ICPRequestEventArgs_t *)

Modified: trafficserver/traffic/trunk/proxy/ICPConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ICPConfig.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ICPConfig.cc (original)
+++ trafficserver/traffic/trunk/proxy/ICPConfig.cc Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
 
   ICPConfig.cc
 
-  
+
 ****************************************************************************/
 
 #include "inktomi++.h"
@@ -472,9 +472,9 @@ ICPConfiguration::UpdatePeerConfig()
 {
   // Note: Entry zero reserved for "localhost"
   for (int i = 1; i <= MAX_DEFINED_PEERS; ++i) {
-    // 
+    //
     // Broken on DEC and Solaris x86
-    // *_peer_cdata[i] = *_peer_cdata_current[i];   
+    // *_peer_cdata[i] = *_peer_cdata_current[i];
     //
     memcpy(_peer_cdata[i], _peer_cdata_current[i], sizeof(*_peer_cdata[i]));
     // Setup IP address

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

Modified: trafficserver/traffic/trunk/proxy/ICPProcessor.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ICPProcessor.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ICPProcessor.h (original)
+++ trafficserver/traffic/trunk/proxy/ICPProcessor.h Thu May 13 07:09:39 2010
@@ -26,7 +26,7 @@
 
   ICPProcessor.h
 
-  
+
 ****************************************************************************/
 
 #ifndef _ICPProcessor_h_
@@ -46,7 +46,7 @@ extern void initialize_thread_for_icp(ET
 class ICPProcessor;
 
 //***************************************************************************
-// External Interface to ICP 
+// External Interface to ICP
 //   Calling Sequence:
 //   =================
 //      void     icpProcessor.start()

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

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

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

Modified: trafficserver/traffic/trunk/proxy/Initialize.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Initialize.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Initialize.cc (original)
+++ trafficserver/traffic/trunk/proxy/Initialize.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
    Created On      : Fri Feb  5 18:22:05 1999
 
    Description:
-   
+
 
  ****************************************************************************/
 #include "inktomi++.h"
@@ -104,10 +104,10 @@ init_system_dirs(void)
 
   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) {
-      fprintf(stderr,"unable to stat() config dir '%s': %d %d, %s\n", 
+      fprintf(stderr,"unable to stat() config dir '%s': %d %d, %s\n",
               system_config_directory, err, errno, strerror(errno));
       fprintf(stderr, "please set config path via 'proxy.config.config_dir' \n");
       _exit(1);
@@ -116,10 +116,10 @@ init_system_dirs(void)
 
   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) {
-      fprintf(stderr,"unable to stat() local state dir '%s': %d %d, %s\n", 
+      fprintf(stderr,"unable to stat() local state dir '%s': %d %d, %s\n",
               system_local_state_dir, err, errno, strerror(errno));
       fprintf(stderr,"please set 'proxy.config.local_state_dir'\n");
       _exit(1);
@@ -131,7 +131,7 @@ init_system_dirs(void)
     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);
@@ -248,7 +248,7 @@ init_system_logging()
 }
 */
 
-void 
+void
 init_system_adjust_num_of_net_threads(void)
 {
   float autoconfig_scale = 1.0;
@@ -331,7 +331,7 @@ init_system_reconfigure_diags(void)
   diags->deactivate_all(DiagsTagType_Action);
 
   //////////////////////////////////////////////////////////////////////
-  //                     add new tag tables 
+  //                     add new tag tables
   //////////////////////////////////////////////////////////////////////
   if (diags->base_debug_tags)
     diags->activate_taglist(diags->base_debug_tags, DiagsTagType_Debug);
@@ -419,9 +419,9 @@ initialize_standalone()
   // Local process manager
   initialize_process_manager();
 
-  diagsConfig = NEW(new DiagsConfig(error_tags, action_tags)); 
-  diags = diagsConfig->diags; 
-  diags_init = 1; 
+  diagsConfig = NEW(new DiagsConfig(error_tags, action_tags));
+  diags = diagsConfig->diags;
+  diags_init = 1;
   eventProcessor.start(num_of_net_threads);
 
   // Set up IO Buffers
@@ -435,9 +435,9 @@ initialize_standalone()
   if (default_large_iobuffer_size > max_iobuffer_size)
     default_large_iobuffer_size = max_iobuffer_size;
 
-  init_buffer_allocators(); 
+  init_buffer_allocators();
 
-  netProcessor.start(); 
+  netProcessor.start();
 
   return;
 }
@@ -465,10 +465,10 @@ void 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);
@@ -514,6 +514,6 @@ void initialize_process_manager()
   //             RECP_NULL);
 }
 
-#endif 
+#endif
 
 

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

Modified: trafficserver/traffic/trunk/proxy/InkAPI.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/InkAPI.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/InkAPI.cc (original)
+++ trafficserver/traffic/trunk/proxy/InkAPI.cc Thu May 13 07:09:39 2010
@@ -1895,7 +1895,7 @@ INKPluginRegister(INKSDKVersion sdk_vers
 
 ////////////////////////////////////////////////////////////////////
 //
-// Plugin info registration - coded in 2.0, but not documented 
+// Plugin info registration - coded in 2.0, but not documented
 //
 ////////////////////////////////////////////////////////////////////
 
@@ -4950,11 +4950,11 @@ INKAction INKHttpSchedule(INKCont contp 
   HttpSM *sm = (HttpSM*)txnp;
   sm->set_http_schedule(cont);
 
-  if (timeout == 0) { 
+  if (timeout == 0) {
     action = eventProcessor.schedule_imm (sm, ET_NET);
   } else {
     action = eventProcessor.schedule_in (sm, HRTIME_MSECONDS (timeout), ET_NET);
-  }    
+  }
 
   action = (INKAction) ((paddr_t) action | 0x1);
 
@@ -8971,7 +8971,7 @@ INKFetchPageRespGet (INKHttpTxn txnp, IN
     HTTPHdr *hptr = (HTTPHdr*) txnp;
 
     if (hptr->valid()) {
-        *bufp = hptr; 
+        *bufp = hptr;
         *obj = hptr->m_http;
         sdk_sanity_check_mbuffer(*bufp);
 
@@ -8982,7 +8982,7 @@ INKFetchPageRespGet (INKHttpTxn txnp, IN
 }
 
 extern ClassAllocator<FetchSM> FetchSMAllocator;
-INKReturnCode INKFetchPages(INKFetchUrlParams_t * params) 
+INKReturnCode INKFetchPages(INKFetchUrlParams_t * params)
 {
    INKFetchUrlParams_t *myparams = params;
    while(myparams!=NULL) {
@@ -8994,7 +8994,7 @@ INKReturnCode INKFetchPages(INKFetchUrlP
   }
   return INK_SUCCESS;
 }
-INKReturnCode  INKFetchUrl(const char* headers, int request_len, unsigned int ip, int port , INKCont contp, INKFetchWakeUpOptions callback_options,INKFetchEvent events) 
+INKReturnCode  INKFetchUrl(const char* headers, int request_len, unsigned int ip, int port , INKCont contp, INKFetchWakeUpOptions callback_options,INKFetchEvent events)
 {
 //  printf("calling INKFetchUrl\n");
    FetchSM *fetch_sm =  FetchSMAllocator.alloc();

Modified: trafficserver/traffic/trunk/proxy/InkAPITest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/InkAPITest.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/InkAPITest.cc (original)
+++ trafficserver/traffic/trunk/proxy/InkAPITest.cc Thu May 13 07:09:39 2010
@@ -351,7 +351,7 @@ REGRESSION_TEST(SDK_API_INKNetVConn) (Re
 //////////////////////////////////////////////
 
 // INKVConnAbort can't be tested
-// Fix me: test INKVConnShutdown, INKCacheKeyDataTypeSet, 
+// Fix me: test INKVConnShutdown, INKCacheKeyDataTypeSet,
 //         INKCacheKeyHostNameSet, INKCacheKeyPinnedSet
 
 // Logic of the test:
@@ -410,7 +410,7 @@ cache_handler(INKCont contp, INKEvent ev
     cache_vconn->out_bufp = INKIOBufferCreate();
     cache_vconn->out_readerp = INKIOBufferReaderAlloc(cache_vconn->out_bufp);
 
-    // Write content into upstream IOBuffer         
+    // Write content into upstream IOBuffer
     ntodo = OBJECT_SIZE;
     ndone = 0;
     while (ntodo > 0) {
@@ -796,7 +796,7 @@ REGRESSION_TEST(SDK_API_INKCache) (Regre
 //                    INKfwrite
 //////////////////////////////////////////////
 
-// Used to create tmp file 
+// Used to create tmp file
 //#define TMP_DIR "/var/tmp"
 #define	PFX	"plugin.config"
 
@@ -805,9 +805,9 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
 
   char write_file_name[256];
 
-  INKFile source_read_file;     // existing file 
-  INKFile write_file;           // to be created 
-  INKFile cmp_read_file;        // read & compare 
+  INKFile source_read_file;     // existing file
+  INKFile write_file;           // to be created
+  INKFile cmp_read_file;        // read & compare
 
   char input_buffer[BUFSIZ];
   char cmp_buffer[BUFSIZ];
@@ -873,7 +873,7 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
 
   memset(input_buffer, '\0', BUFSIZ);
 
-  // source_read_file and input_file_full_path are the same file 
+  // source_read_file and input_file_full_path are the same file
   if (stat(input_file_full_path, &stat_buffer_input) != 0) {
     SDK_RPRINT(test, "stat", "std func", TC_FAIL, "source file and input file messed up");
     error_counter++;
@@ -950,7 +950,7 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
     return;
   }
 
-  INKfflush(write_file);        // write_file should point to write_file_name 
+  INKfflush(write_file);        // write_file should point to write_file_name
 
   if (stat(write_file_name, &stat_buffer_post) != 0) {
     SDK_RPRINT(test, "stat", "std func", TC_FAIL, "INKfflush error");
@@ -980,8 +980,8 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
     return;
   }
 
-  // INKfread    
-  // open again for reading 
+  // INKfread
+  // open again for reading
   cmp_read_file = INKfopen(write_file_name, "r");
   if (cmp_read_file == NULL) {
     SDK_RPRINT(test, "INKfopen", "TestCase3", TC_FAIL, "can't open file for reading");
@@ -998,7 +998,7 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
 
   read_amount = (stat_buffer_input.st_size <= (off_t)sizeof(cmp_buffer)) ? (stat_buffer_input.st_size) : (sizeof(cmp_buffer));
 
-  // INKfread on read file 
+  // INKfread on read file
   read = INKfread(cmp_read_file, cmp_buffer, read_amount);
   if (read != read_amount) {
     SDK_RPRINT(test, "INKfread", "TestCase1", TC_FAIL, "can't reading");
@@ -1016,7 +1016,7 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
   } else
     SDK_RPRINT(test, "INKfread", "TestCase1", TC_PASS, "ok");
 
-  // compare input_buffer and cmp_buffer buffers 
+  // compare input_buffer and cmp_buffer buffers
   if (memcmp(input_buffer, cmp_buffer, read_amount) != 0) {
     SDK_RPRINT(test, "INKfread", "TestCase2", TC_FAIL, "reading error");
     error_counter++;
@@ -1033,7 +1033,7 @@ REGRESSION_TEST(SDK_API_INKfopen) (Regre
   } else
     SDK_RPRINT(test, "INKfread", "TestCase2", TC_PASS, "ok");
 
-  // remove the tmp file 
+  // remove the tmp file
   if (unlink(write_file_name) != 0) {
     SDK_RPRINT(test, "unlink", "std func", TC_FAIL, "can't remove temp file");
   }
@@ -1091,10 +1091,10 @@ thread_create_handler(void *arg)
   return NULL;
 }
 
-// Fix me: Solaris threads/Win2K threads tests 
+// Fix me: Solaris threads/Win2K threads tests
 
-// Argument data passed to thread init functions 
-//  cannot be allocated on the stack. 
+// Argument data passed to thread init functions
+//  cannot be allocated on the stack.
 
 REGRESSION_TEST(SDK_API_INKThread) (RegressionTest * test, int atype, int *pstatus) {
 
@@ -1153,7 +1153,7 @@ pthread_start_func(void *arg)
   } else
     SDK_RPRINT(SDK_ThreadInit_test, "INKThreadInit", "TestCase2", TC_PASS, "ok");
 
-  // Clean up this thread 
+  // Clean up this thread
   if (temp_thread)
     INKThreadDestroy(temp_thread);
 
@@ -1333,7 +1333,7 @@ cont_data_handler(INKCont contp, INKEven
 
     *SDK_ContData_pstatus = REGRESSION_TEST_PASSED;
   } else {
-    // If we get bad data, it's a failure 
+    // If we get bad data, it's a failure
     SDK_RPRINT(SDK_ContData_test, "INKContDataSet", "TestCase1", TC_FAIL, "bad data");
     SDK_RPRINT(SDK_ContData_test, "INKContDataGet", "TestCase1", TC_FAIL, "bad data");
 
@@ -1426,7 +1426,7 @@ cont_schedule_handler(INKCont contp, INK
     SDK_RPRINT(SDK_ContSchedule_test, "INKContSchedule", "TestCase2", TC_PASS, "ok");
     tc2_count++;
   } else {
-    // If we receive a bad event, it's a failure 
+    // If we receive a bad event, it's a failure
     SDK_RPRINT(SDK_ContSchedule_test, "INKContSchedule", "TestCase1|2",
                TC_FAIL, "received unexpected event number %d", event);
     *SDK_ContSchedule_pstatus = REGRESSION_TEST_FAILED;
@@ -1448,8 +1448,8 @@ cont_schedule_handler(INKCont contp, INK
 
 /* Mutex */
 
-/* 
-   Fix me: test for grabbing the mutex from two 
+/*
+   Fix me: test for grabbing the mutex from two
    different threads.
    */
 
@@ -2722,7 +2722,7 @@ test_url_print(INKMBuffer bufp, INKMLoc 
     /* 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;
@@ -3579,7 +3579,7 @@ REGRESSION_TEST(SDK_API_INKHttpHdr) (Reg
     SDK_RPRINT(test, "INKHttpHdrReasonLookup", "TestCase4", TC_PASS, "ok");
   }
 
-  // Copy 
+  // Copy
   if (test_passed_Http_Hdr_Create == true) {
     if (INKHttpHdrCopy(bufp3, hdr_loc3, bufp1, hdr_loc1) == INK_ERROR) {
       SDK_RPRINT(test, "INKHttpHdrCopy", "TestCase1", TC_FAIL, "INKHttpHdrCopy returns INK_ERROR");
@@ -3769,7 +3769,7 @@ REGRESSION_TEST(SDK_API_INKHttpHdr) (Reg
     SDK_RPRINT(test, "INKHttpHdrCopy", "All Test Cases", TC_PASS, "Cannot run test as INKHttpHdrCreate has failed");
   }
 
-  // Clone 
+  // Clone
   if (test_passed_Http_Hdr_Create == true) {
     if ((hdr_loc4 = INKHttpHdrClone(bufp4, bufp1, hdr_loc1)) == INK_ERROR_PTR) {
       SDK_RPRINT(test, "INKHttpHdrClone", "TestCase1", TC_FAIL, "INKHttpHdrClone returns INK_ERROR_PTR");
@@ -5217,7 +5217,7 @@ convert_http_hdr_to_string(INKMBuffer bu
     /* 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;
@@ -5410,19 +5410,19 @@ REGRESSION_TEST(SDK_API_INKHttpHdrParse)
 //////////////////////////////////////////////
 //       SDK_API_INKMimeHdrParse
 //
-// Unit Test for API: INKMimeHdrCopy 
+// Unit Test for API: INKMimeHdrCopy
 //                    INKMimeHdrClone
-//                    INKMimeHdrFieldCopy 
-//                    INKMimeHdrFieldClone 
-//                    INKMimeHdrFieldCopyValues 
-//                    INKMimeHdrFieldNextDup 
-//                    INKMimeHdrFieldRemove 
-//                    INKMimeHdrLengthGet 
-//                    INKMimeHdrParse 
-//                    INKMimeHdrPrint 
-//                    INKMimeParserClear 
-//                    INKMimeParserCreate 
-//                    INKMimeParserDestroy 
+//                    INKMimeHdrFieldCopy
+//                    INKMimeHdrFieldClone
+//                    INKMimeHdrFieldCopyValues
+//                    INKMimeHdrFieldNextDup
+//                    INKMimeHdrFieldRemove
+//                    INKMimeHdrLengthGet
+//                    INKMimeHdrParse
+//                    INKMimeHdrPrint
+//                    INKMimeParserClear
+//                    INKMimeParserCreate
+//                    INKMimeParserDestroy
 //                    INKHandleMLocRelease
 //                    INKHandleStringRelease
 //////////////////////////////////////////////
@@ -5475,7 +5475,7 @@ convert_mime_hdr_to_string(INKMBuffer bu
     /* 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;
@@ -6948,7 +6948,7 @@ ssn_handler(INKCont contp, INKEvent even
 
       // transaction is over. clean up.
       synclient_txn_delete(data->browser);
-      /* Don't need it as didn't initialize the server 
+      /* Don't need it as didn't initialize the server
          synserver_delete(data->os);
        */
       data->magic = MAGIC_DEAD;
@@ -7339,8 +7339,8 @@ handle_transform(INKCont contp)
     data->output_buffer = INKIOBufferCreate();
     data->output_reader = INKIOBufferReaderAlloc(data->output_buffer);
     data->output_vio = INKVConnWrite(output_conn, contp, data->output_reader, towrite);
-    // Don't need this as the structure is encapsulated in another structure 
-    // which is set to be Continuation's Data. 
+    // Don't need this as the structure is encapsulated in another structure
+    // which is set to be Continuation's Data.
     // INKContDataSet (contp, data);
   }
 
@@ -7708,7 +7708,7 @@ transform_hook_handler(INKCont contp, IN
       // for squid log: if this is the last (or only) test in your
       // regression run you will not see any log entries in squid
       // (because logging is buffered and not flushed before
-      // termination when running regressions) 
+      // termination when running regressions)
       // sleep(10);
       break;
     default:
@@ -8092,7 +8092,7 @@ EXCLUSIVE_REGRESSION_TEST(SDK_API_HttpAl
 // 2 Test cases.
 //
 // Same test strategy:
-//  - create a synthetic server listening on port A 
+//  - create a synthetic server listening on port A
 //  - use HttpConnect to send a request to TS for an url on a remote host H, port B
 //  - use TxnIntercept or TxnServerIntercept to forward the request
 //    to the synthetic server on local host, port A

Modified: trafficserver/traffic/trunk/proxy/InkIOCoreAPI.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/InkIOCoreAPI.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/InkIOCoreAPI.cc (original)
+++ trafficserver/traffic/trunk/proxy/InkIOCoreAPI.cc Thu May 13 07:09:39 2010
@@ -23,7 +23,7 @@
 
 /*
  * This file contains all the functions exported by the IOCore to the SDK.
- * Any IOCore symbol accessed by a plugin directly should be called in this 
+ * Any IOCore symbol accessed by a plugin directly should be called in this
  * file to ensure that it gets exported as a global symbol in TS
  */
 
@@ -199,7 +199,7 @@ INKMutexCreate()
 }
 
 /* The following two APIs are for Into work, actually, APIs of Mutex
-   should allow plugins to manually increase or decrease the refcount 
+   should allow plugins to manually increase or decrease the refcount
    of the mutex pointer, plugins may want more control of the creation
    and destroy of the mutex.*/
 
@@ -421,7 +421,7 @@ INKUDPSendTo(INKCont contp, INKUDPConn u
 
   packet->append_block((IOBufferBlock *) blockp);
   /* (Jinsheng 11/27/00) set connection twice which causes:
-     FATAL: ../../../proxy/iocore/UDPPacket.h:136: 
+     FATAL: ../../../proxy/iocore/UDPPacket.h:136:
      failed assert `!m_conn` */
 
   /* packet->setConnection ((UDPConnection *)udp); */

Modified: trafficserver/traffic/trunk/proxy/InkXml.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/InkXml.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/InkXml.cc (original)
+++ trafficserver/traffic/trunk/proxy/InkXml.cc Thu May 13 07:09:39 2010
@@ -24,7 +24,7 @@
 /***************************************************************************
  InkXml.cc
 
- 
+
  ***************************************************************************/
 #include "inktomi++.h"
 
@@ -38,7 +38,7 @@
 #define ink_isspace isspace
 ---*/
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlAttr
   -------------------------------------------------------------------------*/
 
@@ -60,7 +60,7 @@ InkXmlAttr::display(FILE * fd)
   fprintf(fd, "    <%s,%s>\n", m_tag, m_value);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlObject
   -------------------------------------------------------------------------*/
 
@@ -134,7 +134,7 @@ InkXmlObject::display(FILE * fd)
   }
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlConfigFile
   -------------------------------------------------------------------------*/
 
@@ -242,7 +242,7 @@ InkXmlConfigFile::add_object(InkXmlObjec
   m_objects.enqueue(object);
 }
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlConfigFile::get_next_xml_object()
 
   This routine (and its friends) does the real work of parsing the given

Modified: trafficserver/traffic/trunk/proxy/InkXml.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/InkXml.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/InkXml.h (original)
+++ trafficserver/traffic/trunk/proxy/InkXml.h Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
 
 #include "List.h"
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXml.h
 
   This file defines the interface for parsing XML-style config files.  Such
@@ -37,7 +37,7 @@
   queried later to extract the desired information.
   -------------------------------------------------------------------------*/
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlAttr
   -------------------------------------------------------------------------*/
 
@@ -71,7 +71,7 @@ private:
   InkXmlAttr & operator=(InkXmlAttr &);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlObject
 
   An XmlObject has a name and a set of <tag,value> attributes.
@@ -120,7 +120,7 @@ private:
   InkXmlObject & operator=(InkXmlObject &);
 };
 
-/*------------------------------------------------------------------------- 
+/*-------------------------------------------------------------------------
   InkXmlConfigFile
 
   This object is used to parse an XML-style config file and create a

Modified: trafficserver/traffic/trunk/proxy/Main.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Main.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Main.cc (original)
+++ trafficserver/traffic/trunk/proxy/Main.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   This is the primary source file for the proxy cache system.
 
-  
+
  ****************************************************************************/
 
 #include "inktomi++.h"
@@ -385,15 +385,15 @@ check_lockfile()
 #ifndef _DLL_FOR_HNS
   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);
     }
-  } 
+  }
   snprintf(lockfile, sizeof(lockfile),"%s%s%s", lockdir,DIR_SEP,SERVER_LOCK);
 #else
 #define MAX_ENVVAR_LENGTH 128
@@ -434,15 +434,15 @@ init_dirs(void)
 
 
   if ((err = stat(system_config_directory, &s)) < 0) {
-    ink_strncpy(system_config_directory,management_directory,sizeof(system_config_directory)); 
+    ink_strncpy(system_config_directory,management_directory,sizeof(system_config_directory));
     if ((err = stat(system_config_directory, &s)) < 0) {
       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) {
-          fprintf(stderr,"unable to stat() config dir '%s': %d %d, %s\n", 
+          fprintf(stderr,"unable to stat() config dir '%s': %d %d, %s\n",
                     system_config_directory, err, errno, strerror(errno));
           fprintf(stderr, "please set config path via 'proxy.config.config_dir' \n");
           _exit(1);
@@ -455,10 +455,10 @@ init_dirs(void)
     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) {
-        fprintf(stderr,"unable to stat() local state dir '%s': %d %d, %s\n", 
+        fprintf(stderr,"unable to stat() local state dir '%s': %d %d, %s\n",
                 system_local_state_dir, err, errno, strerror(errno));
         fprintf(stderr,"please set 'proxy.config.local_state_dir'\n");
         _exit(1);
@@ -473,7 +473,7 @@ init_dirs(void)
       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);
@@ -507,10 +507,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);

Modified: trafficserver/traffic/trunk/proxy/Main.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Main.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Main.h (original)
+++ trafficserver/traffic/trunk/proxy/Main.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
   This is the primary include file for the proxy cache system.
 
-  
+
  ****************************************************************************/
 
 #ifndef _Main_h_
@@ -60,7 +60,7 @@
 extern int use_accept_thread;
 extern int accept_till_done;
 //extern int ssl_accept_port_number;
-//extern int ssl_enabled;       
+//extern int ssl_enabled;
 extern int http_accept_port_number;
 extern int http_accept_file_descriptor;
 extern int command_flag;

Modified: trafficserver/traffic/trunk/proxy/MuxVC.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/MuxVC.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/MuxVC.cc (original)
+++ trafficserver/traffic/trunk/proxy/MuxVC.cc Thu May 13 07:09:39 2010
@@ -25,9 +25,9 @@
 
     MuxVC.cc
 
-    Description: 
+    Description:
+
 
-    
   ****************************************************************************/
 
 #include "MuxVC.h"
@@ -640,7 +640,7 @@ MuxClientVC::setup_retry_event(int ms)
 // void MuxClientVC::process_retry_event()
 //
 //   We've gotten this event because we missed a lock or needed to do something
-//     on a different callstack.  We need to figure out our state and act 
+//     on a different callstack.  We need to figure out our state and act
 //     appropriately
 //
 void
@@ -814,7 +814,7 @@ MuxClientVC::process_write()
     //
     //   But by not limiting it, we allow one transaction
     //     to starve others
-    //    
+    //
     // act_on = MIN(act_on, MUX_MAX_BYTES_SLOT);
 
     ink_debug_assert(act_on >= 0);
@@ -873,7 +873,7 @@ MuxClientVC::process_write()
 
 // void MuxClientVC::process_channel_close_for_read()
 //
-//    Handles sending EOS to the read side of the client 
+//    Handles sending EOS to the read side of the client
 //      when the the remote side closes the channel
 //
 //    CALLER is responsible for handling reentrant closes
@@ -899,7 +899,7 @@ MuxClientVC::process_channel_close_for_r
 
 // void MuxClientVC::process_channel_close_for_write()
 //
-//    Handles sending ERROR to the write side of the client 
+//    Handles sending ERROR to the write side of the client
 //      when the the remote side closes the channel
 //
 //    CALLER is responsible for handling reentrant closes
@@ -1202,7 +1202,7 @@ MuxVC::state_send_init_response(int even
 
       // We doing lazy reentrancy counting.  Only doing
       //   where we know there are issues.  So if the count
-      //   is zero no one is blocking us from deallocating 
+      //   is zero no one is blocking us from deallocating
       //   ourselves
       if (reentrancy_count == 0) {
         kill();
@@ -1291,7 +1291,7 @@ MuxVC::kill()
     process_event = NULL;
   }
   // If we are on the mux processor list, we must remove ourself
-  //    before we can dealloc ourself 
+  //    before we can dealloc ourself
   if (on_mux_list) {
     if (try_processor_list_remove() == 0) {
       SET_HANDLER(MuxVC::state_remove_from_list);
@@ -2103,7 +2103,7 @@ MuxVC::state_idle(int event, void *data)
         // We don't want to hear from the read side anymore
         //
         //  FIX ME - Is there a race between new sessions
-        //     being opened from the remote and the 
+        //     being opened from the remote and the
         //     shutdown being issues?
         net_vc->do_io_shutdown(IO_SHUTDOWN_READ);
         read_vio = NULL;

Modified: trafficserver/traffic/trunk/proxy/MuxVC.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/MuxVC.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/MuxVC.h (original)
+++ trafficserver/traffic/trunk/proxy/MuxVC.h Thu May 13 07:09:39 2010
@@ -25,9 +25,9 @@
 
    MuxVC.h
 
-   Description: 
+   Description:
+
 
-   
  ****************************************************************************/
 
 #ifndef _MUX_VC_H_

Modified: trafficserver/traffic/trunk/proxy/NTDefs.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/NTDefs.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/NTDefs.h (original)
+++ trafficserver/traffic/trunk/proxy/NTDefs.h Thu May 13 07:09:39 2010
@@ -49,7 +49,7 @@
 #define OPTIMAL_TCP_TIMED_WAIT_DELAY 0xb4
 
 
-// If this location is changed, then perfdll/TrafficServer.reg or the 
+// If this location is changed, then perfdll/TrafficServer.reg or the
 // install shield editor needs to be changed as well.
 #define TS_PERFMON_SVC_REG_KEY "SYSTEM\\CurrentControlSet\\Services\\TrafficServer\\Performance"
 #define TS_EVENT_LOG_SRC_KEY "SYSTEM\\CurrentControlSet\\Services\\EventLog\\Application\\TrafficServer"
@@ -76,13 +76,13 @@
 #define TS_MGR_SERVICE_DISPLAY_NAME "Inktomi Traffic Manager"
 
 // These are the attributes for creating the manager service.
-// 
-// LPCTSTR lpServiceName = TS_MGR_SERVICE_NAME          // pointer to name of service to start 
-// LPCTSTR lpDisplayName = TS_MGR_SERVICE_DISPLAY_NAME  // pointer to display name 
-// DWORD dwDesiredAccess = SERVICE_ALL_ACCESS           // type of access to service 
-// DWORD dwServiceType   = SERVICE_WIN32_OWN_PROCESS    // type of service 
-// DWORD dwStartType     = SERVICE_AUTO_START           // when to start service 
-// DWORD dwErrorControl  = SERVICE_ERROR_NORMAL         // severity if service fails to start 
+//
+// LPCTSTR lpServiceName = TS_MGR_SERVICE_NAME          // pointer to name of service to start
+// LPCTSTR lpDisplayName = TS_MGR_SERVICE_DISPLAY_NAME  // pointer to display name
+// DWORD dwDesiredAccess = SERVICE_ALL_ACCESS           // type of access to service
+// DWORD dwServiceType   = SERVICE_WIN32_OWN_PROCESS    // type of service
+// DWORD dwStartType     = SERVICE_AUTO_START           // when to start service
+// DWORD dwErrorControl  = SERVICE_ERROR_NORMAL         // severity if service fails to start
 
 #endif // MGMT_SERVICE
 
@@ -93,13 +93,13 @@
 #define TS_COP_SERVICE_DESCRIPTION  "Monitors the health of Traffic Server and Traffic Manager"
 
 // These are the attributes for creating the cop service.
-// 
-// LPCTSTR lpServiceName = TS_COP_SERVICE_NAME          // pointer to name of service to start 
-// LPCTSTR lpDisplayName = TS_COP_SERVICE_DISPLAY_NAME  // pointer to display name 
-// DWORD dwDesiredAccess = SERVICE_ALL_ACCESS           // type of access to service 
-// DWORD dwServiceType   = SERVICE_WIN32_OWN_PROCESS    // type of service 
-// DWORD dwStartType     = SERVICE_AUTO_START           // when to start service 
-// DWORD dwErrorControl  = SERVICE_ERROR_NORMAL         // severity if service fails to start 
+//
+// LPCTSTR lpServiceName = TS_COP_SERVICE_NAME          // pointer to name of service to start
+// LPCTSTR lpDisplayName = TS_COP_SERVICE_DISPLAY_NAME  // pointer to display name
+// DWORD dwDesiredAccess = SERVICE_ALL_ACCESS           // type of access to service
+// DWORD dwServiceType   = SERVICE_WIN32_OWN_PROCESS    // type of service
+// DWORD dwStartType     = SERVICE_AUTO_START           // when to start service
+// DWORD dwErrorControl  = SERVICE_ERROR_NORMAL         // severity if service fails to start
 
 #endif // COP_SERVICE
 

Modified: trafficserver/traffic/trunk/proxy/ParentSelection.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ParentSelection.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ParentSelection.cc (original)
+++ trafficserver/traffic/trunk/proxy/ParentSelection.cc Thu May 13 07:09:39 2010
@@ -136,7 +136,7 @@ ParentConfig::startup()
   PARENT_RegisterConfigUpdateFunc(default_var, parentSelection_CB, (void *) PARENT_DEFAULT_CB);
   //   Retry time
   PARENT_RegisterConfigUpdateFunc(retry_var, parentSelection_CB, (void *) PARENT_RETRY_CB);
-  //   Enable 
+  //   Enable
   PARENT_RegisterConfigUpdateFunc(enable_var, parentSelection_CB, (void *) PARENT_ENABLE_CB);
 
   //   Fail Threshold
@@ -1218,7 +1218,7 @@ REGRESSION_TEST(ParentResult) {
       }
     }
   }
-  
+
   return err;
 }
 
@@ -1315,8 +1315,8 @@ EXCLUSIVE_REGRESSION_TEST(PARENTSELECTIO
     // Test 6+ BUGBUG needs to be fixed
 //   ST(7) REINIT
 //   br(request, "www.microsoft.net");
-//   FP RE( verify(result,PARENT_SPECIFIED,"zoo.net",341) + 
-//       verify(result,PARENT_SPECIFIED,"zoo.net",347) + 
+//   FP RE( verify(result,PARENT_SPECIFIED,"zoo.net",341) +
+//       verify(result,PARENT_SPECIFIED,"zoo.net",347) +
 //       verify(result,PARENT_SPECIFIED,"zoo.edu",111) ,7)
     // Test 6++ BUGBUG needs to be fixed
 //   ST(7) REINIT

Modified: trafficserver/traffic/trunk/proxy/ParentSelection.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ParentSelection.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ParentSelection.h (original)
+++ trafficserver/traffic/trunk/proxy/ParentSelection.h Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
  *
  *  ParentSelection.h - Interface to Parent Selection System
  *
- * 
+ *
  ****************************************************************************/
 
 #ifndef _PARENT_SELECTION_H_
@@ -75,7 +75,7 @@ struct ParentResult
   // Internal use only
   //   Not to be modified by HTTP
   int line_number;
-  P_table *epoch;               // A pointer to the table used.  
+  P_table *epoch;               // A pointer to the table used.
   ParentRecord *rec;
   inku32 last_parent;
   inku32 start_parent;

Modified: trafficserver/traffic/trunk/proxy/PluginVC.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/PluginVC.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/PluginVC.cc (original)
+++ trafficserver/traffic/trunk/proxy/PluginVC.cc Thu May 13 07:09:39 2010
@@ -22,40 +22,40 @@
  */
 
 /****************************************************************************
- 
+
    PluginVC.cc
- 
+
    Description: Allows bi-directional transfer for data from one
       continuation to another via a mechanism that impersonates a
       NetVC.  Should implement all external attributes of NetVConnections.
- 
+
    Since data is transfered within Traffic Server, this is a two
-   headed beast.  One NetVC on initiating side (active side) and 
+   headed beast.  One NetVC on initiating side (active side) and
    one NetVC on the receiving side (passive side).
- 
+
    The two NetVC subclasses, PluginVC, are part PluginVCCore object.  All
    three objects share the same mutex.  That mutex is required
    for doing operations that affect the shared buffers,
    read state from the PluginVC on the other side or deal with deallocation.
- 
+
    To simplify the code, all data passing through the system goes initially
    into a shared buffer.  There are two shared buffers, one for each
    direction of the connection.  While it's more efficient to transfer
    the data from one buffer to another directly, this creates a lot
    of tricky conditions since you must be holding the lock for both
-   sides, in additional this VC's lock.  Additionally, issues like 
-   watermarks are very hard to deal with.  Since we try to 
+   sides, in additional this VC's lock.  Additionally, issues like
+   watermarks are very hard to deal with.  Since we try to
    to move data by IOBufferData references the efficiency penalty shouldn't
-   be too bad and if it is a big pentaly, a brave soul can reimplement 
+   be too bad and if it is a big pentaly, a brave soul can reimplement
    to move the data directly without the intermediate buffer.
- 
+
    Locking is difficult issue for this multi-headed beast.  In each
-   PluginVC, there a two locks. The one we got from our PluginVCCore and 
-   the lock from the state machine using the PluginVC.  The read side 
-   lock & the write side lock must be the same.  The regular net processor has 
-   this constraint as well.  In order to handle scheduling of retry events cleanly, 
+   PluginVC, there a two locks. The one we got from our PluginVCCore and
+   the lock from the state machine using the PluginVC.  The read side
+   lock & the write side lock must be the same.  The regular net processor has
+   this constraint as well.  In order to handle scheduling of retry events cleanly,
    we have two event poitners, one for each lock.  sm_lock_retry_event can only
-   be changed while holding the using state machine's lock and 
+   be changed while holding the using state machine's lock and
    core_lock_retry_event can only be manipulated while holding the PluginVC's
    lock.  On entry to PluginVC::main_handler, we obtain all the locks
    before looking at the events.  If we can't get all the locks
@@ -63,12 +63,12 @@
    obtained in the beginning of the handler, we know we are running
    exclusively in the later parts of the handler and we will
    be free from do_io or reenable calls on the PluginVC.
- 
+
    The assumption is made (conistant with IO Core spec) that any close,
-   shutdown, reenable, or do_io_{read,write) operation is done by the callee 
+   shutdown, reenable, or do_io_{read,write) operation is done by the callee
    while holding the lock for that side of the operation.
-   
-   
+
+
  ****************************************************************************/
 
 #include "PluginVC.h"

Modified: trafficserver/traffic/trunk/proxy/PluginVC.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/PluginVC.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/PluginVC.h (original)
+++ trafficserver/traffic/trunk/proxy/PluginVC.h Thu May 13 07:09:39 2010
@@ -30,7 +30,7 @@
       NetVC.  Should implement all external attributes of NetVConnections.
       [See PluginVC.cc for further comments]
 
-   
+
  ****************************************************************************/
 
 #ifndef _PLUGIN_VC_H_

Modified: trafficserver/traffic/trunk/proxy/Prefetch.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Prefetch.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Prefetch.cc (original)
+++ trafficserver/traffic/trunk/proxy/Prefetch.cc Thu May 13 07:09:39 2010
@@ -49,7 +49,7 @@ struct html_tag prefetch_allowable_html_
   {NULL, NULL}
 };
 
-// this attribute table is hard coded. It has to be the same size as 
+// this attribute table is hard coded. It has to be the same size as
 // the prefetch_allowable_html_tags table
 struct html_tag prefetch_allowable_html_attrs[] = {
   {NULL, NULL},
@@ -96,7 +96,7 @@ setup_object_header(char *header, inku32
 {
   inku32 *hdr = (inku32 *) header;
   hdr[0] = htonl(size);
-  hdr[1] = 0;                   //we are not pinning 
+  hdr[1] = 0;                   //we are not pinning
   hdr[2] = (url_promise) ? htonl(PRELOAD_HDR_URL_PROMISE_FLAG) : 0;
 }
 
@@ -143,7 +143,7 @@ findDomainFromHost(const char *host, int
       }
     }
   }
-  // for non-top level domains, require the first char is not '.' and 
+  // for non-top level domains, require the first char is not '.' and
   // two '.' minimum, e.g. abc.va.us
   int num_dots = 0;
   while (h_cur != host) {
@@ -461,8 +461,8 @@ PrefetchTransform::redirect(HTTPHdr * re
   char *req_url = NULL;
   char *redirect_url = NULL;
 
-  /* Check for responses validity. If the response is valid, determine the status of the response. 
-     We need to find out if there was a redirection (301, 302, 303, 307). 
+  /* Check for responses validity. If the response is valid, determine the status of the response.
+     We need to find out if there was a redirection (301, 302, 303, 307).
    */
   if ((resp != NULL) && (resp->valid())) {
     response_status = resp->status_get();
@@ -975,7 +975,7 @@ PrefetchBlaster::init(PrefetchUrlEntry *
       const char *host_end = host_start + host_len - 1;
       int cmp_len = p_trans->domain_end - p_trans->domain_start + 1;
 
-      if (cmp_len <= 0 || host_len<cmp_len || (host_len> cmp_len && host_start[host_len - cmp_len - 1] != '.') ||    //nbc.com != cnbc.com 
+      if (cmp_len <= 0 || host_len<cmp_len || (host_len> cmp_len && host_start[host_len - cmp_len - 1] != '.') ||    //nbc.com != cnbc.com
           strncasecmp(p_trans->domain_start, host_end - (cmp_len - 1), cmp_len) != 0) {
         delete_auth = true;
       } else
@@ -1130,7 +1130,7 @@ PrefetchBlaster::handleCookieHeaders(HTT
     return;
 
   if (!domain_start && (!thost_start || no_dot == false)) {
-    // mising domain name information 
+    // mising domain name information
     add_cookies = false;
     goto Lcheckcookie;
   }
@@ -1149,7 +1149,7 @@ PrefetchBlaster::handleCookieHeaders(HTT
   if (domain_start) {
     cmp_len = domain_end - domain_start + 1;
 
-    if (host_len<cmp_len || (host_len> cmp_len && host_start[host_len - cmp_len - 1] != '.') ||      //nbc.com != cnbc.com 
+    if (host_len<cmp_len || (host_len> cmp_len && host_start[host_len - cmp_len - 1] != '.') ||      //nbc.com != cnbc.com
         strncasecmp(domain_start, host_end - (cmp_len - 1), cmp_len) != 0) {
       add_cookies = false;
       goto Lcheckcookie;
@@ -1243,8 +1243,8 @@ PrefetchBlaster::handleCookieHeaders(HTT
           if (prefix_len > 0 && memchr(host_start, '.', prefix_len))
             goto Lnotmatch;
 
-          // Ok, when we get here, it should be a real match as far as 
-          //        domain is concerned. 
+          // Ok, when we get here, it should be a real match as far as
+          //        domain is concerned.
           // possibly overwrite the default domain matching result
           domain_match = true;
           continue;
@@ -1367,7 +1367,7 @@ PrefetchBlaster::handleCookieHeaders(HTT
         }
       }
     }
-    // add_cookies now means whether new Cookie headers are created 
+    // add_cookies now means whether new Cookie headers are created
     // from the Set-Cookie headers
     // now also check the existing Cookie headers from the req_hdr
     add_cookies = add_cookies || existing_req_cookies;

Modified: trafficserver/traffic/trunk/proxy/Prefetch.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Prefetch.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Prefetch.h (original)
+++ trafficserver/traffic/trunk/proxy/Prefetch.h Thu May 13 07:09:39 2010
@@ -110,7 +110,7 @@ public:
   int len;
   INK_MD5 md5;
 
-  //PrefetchBlastType   resp_blast_proto;  
+  //PrefetchBlastType   resp_blast_proto;
   //HTTPHdr *           request;
   PrefetchBlaster *resp_blaster;
 

Modified: trafficserver/traffic/trunk/proxy/ProtoSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/ProtoSM.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/ProtoSM.h (original)
+++ trafficserver/traffic/trunk/proxy/ProtoSM.h Thu May 13 07:09:39 2010
@@ -28,7 +28,7 @@
    Description:
       Common elements for protocol state machines
 
-   
+
  ****************************************************************************/
 
 #ifndef _PROTO_SM_H_
@@ -112,7 +112,7 @@ template<class VCTentry, int max_entries
 
 // void ProtoVCTable::cleanup_entry(HttpVCEntry* e)
 //
-//    Closes the associate vc for the entry, 
+//    Closes the associate vc for the entry,
 //     and the call remove_entry
 //
 template<class VCTentry, int max_entries>

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

Modified: trafficserver/traffic/trunk/proxy/Raf.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Raf.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Raf.cc (original)
+++ trafficserver/traffic/trunk/proxy/Raf.cc Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #include "Raf.h"
@@ -665,7 +665,7 @@ RafCont::output_resp_hdr(const char *id,
 }
 
 // void RafCont::output_raf_arg(const char* arg)
-//  
+//
 //  Outputs an encoded raf argument.  Adds a leading space to it
 //
 void

Modified: trafficserver/traffic/trunk/proxy/Raf.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Raf.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Raf.h (original)
+++ trafficserver/traffic/trunk/proxy/Raf.h Thu May 13 07:09:39 2010
@@ -27,7 +27,7 @@
 
    Description:
 
-   
+
  ****************************************************************************/
 
 #ifndef _TS_RAF_H_

Modified: trafficserver/traffic/trunk/proxy/RegressionSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/RegressionSM.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/RegressionSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/RegressionSM.cc Thu May 13 07:09:39 2010
@@ -226,7 +226,7 @@ struct ReRegressionSM : RegressionSM {
 
 REGRESSION_TEST(RegressionSM)(RegressionTest *t, int atype, int *pstatus) {
   r_sequential(
-    t, 
+    t,
     r_parallel(t, new ReRegressionSM(t), new ReRegressionSM(t), NULL),
     r_sequential(t, new ReRegressionSM(t), new ReRegressionSM(t), NULL),
     r_parallel(t, 3, new ReRegressionSM(t)),

Modified: trafficserver/traffic/trunk/proxy/RegressionSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/RegressionSM.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/RegressionSM.h (original)
+++ trafficserver/traffic/trunk/proxy/RegressionSM.h Thu May 13 07:09:39 2010
@@ -62,7 +62,7 @@ struct RegressionSM : Continuation {
   void child_done(int status);
   void xrun(RegressionSM *parent);
 
-  RegressionSM(RegressionTest *at = NULL) : 
+  RegressionSM(RegressionTest *at = NULL) :
     t(at), status(REGRESSION_TEST_INPROGRESS),
     pstatus(0), parent(0), nwaiting(0), nchildren(0), children(0), ichild(0), par(false), rep(false),
     pending_action(0)

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

Modified: trafficserver/traffic/trunk/proxy/SocksProxy.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/SocksProxy.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/SocksProxy.cc (original)
+++ trafficserver/traffic/trunk/proxy/SocksProxy.cc Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
   This implements SOCKS server. We intecept the http traffic and send it
   through HTTP. Others are tunneled through directly to the socks server.
 
-  
+
 */
 #include "inktomi++.h"
 #include "StatSystem.h"

Modified: trafficserver/traffic/trunk/proxy/StatPages.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/StatPages.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/StatPages.cc (original)
+++ trafficserver/traffic/trunk/proxy/StatPages.cc Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
 
   StatPages.cc
 
-  
+
  ****************************************************************************/
 
 #include "ink_config.h"
@@ -114,8 +114,8 @@ bool StatPagesManager::is_stat_page(URL 
   host[length] = '\0';
   unescapifyStr(host);
   length = strlen(host);
-//return ((host[0] == '{') && (host[length-1] == '}')); 
-//Bug fixed by YTS Team, yamsat BZ58899    
+//return ((host[0] == '{') && (host[length-1] == '}'));
+//Bug fixed by YTS Team, yamsat BZ58899
   bool
     retVal;
   if ((host[0] == '{') && (host[length - 1] == '}'))

Modified: trafficserver/traffic/trunk/proxy/StatPages.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/StatPages.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/StatPages.h (original)
+++ trafficserver/traffic/trunk/proxy/StatPages.h Thu May 13 07:09:39 2010
@@ -25,7 +25,7 @@
 
   StatPages.h
 
-  
+
  ****************************************************************************/
 
 #ifndef _StatPages_h_
@@ -39,7 +39,7 @@
 //
 // 1. Access from Browswers
 //
-//    By special URLS: 
+//    By special URLS:
 //
 //      http://{module}/component/sub-component/request-type?arguments
 //
@@ -55,7 +55,7 @@
 //       extension type e.g.:
 //
 //         http://{http}/groups/use_graph.gif?august
-//  
+//
 //    B. Each protocol/sybsystem should have their own information.
 //       For example
 

Modified: trafficserver/traffic/trunk/proxy/StatSystem.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/StatSystem.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/StatSystem.cc (original)
+++ trafficserver/traffic/trunk/proxy/StatSystem.cc Thu May 13 07:09:39 2010
@@ -22,7 +22,7 @@
  */
 
 /****************************************************************************
- 
+
   StatSystem.cc --
   Created On          : Fri Apr 3 19:41:39 1998
  ****************************************************************************/
@@ -581,7 +581,7 @@ initialize_all_global_stats()
   // Jira TS-21
   REC_ReadConfigString(local_state_dir, "proxy.config.local_state_dir", PATH_NAME_MAX);
   if ((err = stat(local_state_dir, &s)) < 0) {
-    ink_strncpy(local_state_dir,system_local_state_dir,sizeof(local_state_dir)); 
+    ink_strncpy(local_state_dir,system_local_state_dir,sizeof(local_state_dir));
     if ((err = stat(local_state_dir, &s)) < 0) {
       Warning("Unable to stat() local state directory '%s': %d %d, %s", local_state_dir, err, errno, strerror(errno));
       Warning(" Please set 'proxy.config.local_state_dir' to allow statistics collection");
@@ -1110,22 +1110,22 @@ TransactionMilestones::invariant()
      ///////////////////////////
      // user agent milestones //
      ///////////////////////////
-     UIF(order_correct, 
+     UIF(order_correct,
      ((user_agent_accept <= user_agent_begin_read) || (user_agent_accept == 0)));
      UIF(order_correct, (user_agent_begin_read <= user_agent_read_header_done));
-     UIF(order_correct, 
-     ((user_agent_read_header_done <= user_agent_begin_write) || 
+     UIF(order_correct,
+     ((user_agent_read_header_done <= user_agent_begin_write) ||
      (user_agent_begin_write == 0)));
      UIF(order_correct, (user_agent_read_header_done <= user_agent_close));
-     UIF(order_correct, 
+     UIF(order_correct,
      ((user_agent_begin_write <= user_agent_close) || (user_agent_begin_write == 0)));
      /////////////////////////////////
      // user agent  -- data sources //
      /////////////////////////////////
-     UIF(order_correct, 
+     UIF(order_correct,
      ((user_agent_begin <= origin_server_open_begin) ||
      (origin_server_open_begin == 0)));
-     UIF(order_correct, 
+     UIF(order_correct,
      ((user_agent_begin <= raw_origin_server_connect_begin) ||
      (raw_origin_server_connect_begin == 0)));
      UIF(order_correct,
@@ -1136,10 +1136,10 @@ TransactionMilestones::invariant()
      // origin server //
      ///////////////////
      UIF(order_correct, (origin_server_open_begin <= origin_server_open_end));
-     UIF(order_correct, 
+     UIF(order_correct,
      ((origin_server_open_end <= origin_server_begin_write) ||
      (origin_server_begin_write == 0)));
-     UIF(order_correct, 
+     UIF(order_correct,
      ((origin_server_open_end <= origin_server_begin_read) ||
      (origin_server_begin_read == 0)));
 

Modified: trafficserver/traffic/trunk/proxy/StatSystem.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/StatSystem.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/StatSystem.h (original)
+++ trafficserver/traffic/trunk/proxy/StatSystem.h Thu May 13 07:09:39 2010
@@ -119,7 +119,7 @@ typedef enum
   //
   server_open_time,             // o_s_open_end - o_s_open_begin
   server_response_time,         // o_s_begin_read - o_s_begin_write
-  server_read_time,             // o_s_read_header_done - o_s_begin_read              
+  server_read_time,             // o_s_read_header_done - o_s_begin_read
   //
   TOTAL_HTTP_TRANSACTION_MILESTONES
 } HttpTransactionMilestone_t;
@@ -136,7 +136,7 @@ extern ink_hrtime TenSecondHttpMilestone
 //                       Welcome to enum land!                         //
 //---------------------------------------------------------------------//
 
-// Before adding a stat variable, decide whether it is of 
+// Before adding a stat variable, decide whether it is of
 // a "transaction" type or if it is of a "dynamic" type.
 // Then add the stat variable to the appropriate enumeration
 // type. Make sure that DYN_STAT_START is large enough

Modified: trafficserver/traffic/trunk/proxy/StateEventLogger.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/StateEventLogger.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/StateEventLogger.h (original)
+++ trafficserver/traffic/trunk/proxy/StateEventLogger.h Thu May 13 07:09:39 2010
@@ -58,7 +58,7 @@
    // ...
    disklog(TestStateEvent(my_param1b,my_param2b));
   @endcode
-  
+
 */
 
 #ifndef _StateEventLogger_h_

Modified: trafficserver/traffic/trunk/proxy/Stuffer.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Stuffer.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Stuffer.cc (original)
+++ trafficserver/traffic/trunk/proxy/Stuffer.cc Thu May 13 07:09:39 2010
@@ -701,7 +701,7 @@ StufferCacheIncomingRequest(CacheVC * ca
 #undef BUF_SIZE
 }
 
-//simple hash_table implementation      
+//simple hash_table implementation
 int
 StufferHashTable::index(const char *s)
 {

Modified: trafficserver/traffic/trunk/proxy/TestDNS.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/TestDNS.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/TestDNS.cc (original)
+++ trafficserver/traffic/trunk/proxy/TestDNS.cc Thu May 13 07:09:39 2010
@@ -30,7 +30,7 @@
 
   The main state machine is encapulated in the StateMachine instance.
 
-  
+
  ****************************************************************************/
 
 #include "DNS.h"
@@ -64,7 +64,7 @@ FILE *fin;
 //
 //      TestDnsStateMachine
 //
-//  An instance of TestDnsStateMachine is created for each host 
+//  An instance of TestDnsStateMachine is created for each host
 //
 //////////////////////////////////////////////////////////////////////////////
 class TestDnsStateMachine:public Continuation
@@ -189,13 +189,13 @@ complete()
     cumul_throughput = state_machines_finished * 1.0 * HRTIME_SECOND / (now - start_time);
     throughput = measurement_interval * 1.0 * HRTIME_SECOND / (now - last_measurement_time);
     last_measurement_time = now;
-//    cout << state_machines_finished << ": " << 
-//    "Cumul. Thrput " << cumul_throughput << 
+//    cout << state_machines_finished << ": " <<
+//    "Cumul. Thrput " << cumul_throughput <<
 //    " per sec; Thrput for last " << measurement_interval << " requests: "
 //    << throughput << " per sec\n";
 //    cout.flush();
-//    fout_rate << state_machines_finished << ": " << 
-//    "Cumul. Thrput " << cumul_throughput << 
+//    fout_rate << state_machines_finished << ": " <<
+//    "Cumul. Thrput " << cumul_throughput <<
 //    " per sec; Thrput for last " << measurement_interval << " requests: "
 //    << throughput << " per sec\n";
     fout_rate << (now - start_time) * 1.0 / HRTIME_SECOND << " " << state_machines_finished << " " << cumul_throughput

Modified: trafficserver/traffic/trunk/proxy/TestHook.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/TestHook.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/TestHook.cc (original)
+++ trafficserver/traffic/trunk/proxy/TestHook.cc Thu May 13 07:09:39 2010
@@ -149,7 +149,7 @@ history[history_pos%HISTORY_SIZE].event 
 history[history_pos%HISTORY_SIZE].ndone = _ndone; \
 history_pos++; }
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::requestDataEvent
 //
 //      Called back whenever there is request data available.
@@ -186,7 +186,7 @@ StateMachine::requestDataEvent(int event
 }
 
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::parse
 //
 //      Called on a chunk of bytes representing a piece of a request
@@ -283,7 +283,7 @@ StateMachine::parse()
 }
 
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::responseDataEvent
 //
 //      Called back whenever there is an event and we are generating
@@ -322,7 +322,7 @@ StateMachine::responseDataEvent(int even
 }
 
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::fill
 //
 //      This is the synthetic server routine that writes a header,
@@ -370,7 +370,7 @@ StateMachine::fill()
 }
 
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::startResponse
 //
 //      Called when the request is parsed, to set up the state
@@ -397,7 +397,7 @@ StateMachine::startResponse()
 }
 
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::killStateMachine
 //
 //      Called when the response is generated, to clean up and
@@ -415,7 +415,7 @@ StateMachine::killStateMachine()
 
 
 ////////////////////////////////////////////////////////////////////////
-// 
+//
 //      StateMachine::computeBodySize
 //
 //      Chooses a body size to send based on the URL.

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

Modified: trafficserver/traffic/trunk/proxy/Transform.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Transform.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Transform.cc (original)
+++ trafficserver/traffic/trunk/proxy/Transform.cc Thu May 13 07:09:39 2010
@@ -273,7 +273,7 @@ TransformTerminus::handle_event(int even
         m_write_vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
       }
 
-      // We could have closed on the write callback 
+      // We could have closed on the write callback
       if (m_closed != 0 && m_tvc->m_closed != 0) {
         return 0;
       }
@@ -1073,7 +1073,7 @@ RangeTransform::transform_to_range()
         m_output_vio->nbytes = m_done;
         m_output_vio->reenable();
 
-        // if we are detaching before processing all the 
+        // if we are detaching before processing all the
         //   input data, send VC_EVENT_EOS to let the upstream know
         //   that it can rely on us consuming any more data
         int cb_event = (m_write_vio.ntodo() > 0) ? VC_EVENT_EOS : VC_EVENT_WRITE_COMPLETE;
@@ -1094,9 +1094,9 @@ RangeTransform::transform_to_range()
         // keep this part for future support of out-of-order Range
         // if this is NOT a sequential Range compared to the previous one -
         // start of current Range is larger than the end of last Range, do
-        // not need to go back to the start of the IOBuffereReader. 
-        // Otherwise, reset the IOBufferReader. 
-        //if ( *start > prev_end ) 
+        // not need to go back to the start of the IOBuffereReader.
+        // Otherwise, reset the IOBufferReader.
+        //if ( *start > prev_end )
         *done_byte = prev_end;
         //else
         //  reader->reset();
@@ -1105,7 +1105,7 @@ RangeTransform::transform_to_range()
       }
     }
 
-    // When we need to read and there is nothing available 
+    // When we need to read and there is nothing available
     avail = reader->read_avail();
     if (avail == 0)
       break;
@@ -1172,8 +1172,8 @@ RangeTransform::add_sub_header(int index
   -------------------------------------------------------------------------*/
 
 /*
- * this function changes the response header to reflect this is 
- * a Range response. 
+ * this function changes the response header to reflect this is
+ * a Range response.
  */
 
 void

Modified: trafficserver/traffic/trunk/proxy/UDPAPITest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/UDPAPITest.cc?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/UDPAPITest.cc (original)
+++ trafficserver/traffic/trunk/proxy/UDPAPITest.cc Thu May 13 07:09:39 2010
@@ -42,7 +42,7 @@ UDPTestInit()
   ip = inet_addr("209.131.48.79");
   readMutexp = INKMutexCreate();
   cont = INKContCreate(&handle_callbacks, readMutexp);
-//      INKUDPBind(cont, INADDR_ANY,1813); 
+//      INKUDPBind(cont, INADDR_ANY,1813);
   INKUDPBind(cont, ip, 1813);
 }
 

Modified: trafficserver/traffic/trunk/proxy/Update.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/Update.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/Update.h (original)
+++ trafficserver/traffic/trunk/proxy/Update.h Thu May 13 07:09:39 2010
@@ -26,7 +26,7 @@
 
   Update.h
 
-  
+
 ****************************************************************************/
 
 #include "P_EventSystem.h"
@@ -246,7 +246,7 @@ extern UpdateManager updateManager;
 
 //////////////////////////////////////////////////////////////////////////
 // UpdateConfigManager -- Handle Update subsystem global configuration
-//                        and URL list updates 
+//                        and URL list updates
 //////////////////////////////////////////////////////////////////////////
 typedef int (UpdateConfigManager::*UpdateConfigManagerContHandler) (int, void *);
 
@@ -284,7 +284,7 @@ private:
 };
 
 ////////////////////////////////////////////////////////////////////////
-// UpdateScheduler -- Handle scheduling of UpdateEntry objects 
+// UpdateScheduler -- Handle scheduling of UpdateEntry objects
 ////////////////////////////////////////////////////////////////////////
 typedef int (UpdateScheduler::*UpdateSchedulerContHandler) (int, void *);
 

Modified: trafficserver/traffic/trunk/proxy/api/ts/InkAPIPrivateIOCore.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/api/ts/InkAPIPrivateIOCore.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/api/ts/InkAPIPrivateIOCore.h (original)
+++ trafficserver/traffic/trunk/proxy/api/ts/InkAPIPrivateIOCore.h Thu May 13 07:09:39 2010
@@ -107,10 +107,10 @@ public:
   VConnection *m_output_vc;
 };
 
-/**************************************************************** 
+/****************************************************************
  *  IMPORTANT - READ ME
  * Any plugin using the IO Core must enter
- *   with a held mutex.  SDK 1.0, 1.1 & 2.0 did not 
+ *   with a held mutex.  SDK 1.0, 1.1 & 2.0 did not
  *   have this restriction so we need to add a mutex
  *   to Plugin's Continuation if it trys to use the IOCore
  * Not only does the plugin have to have a mutex
@@ -121,8 +121,8 @@ public:
 
 //
 // FORCE_PLUGIN_MUTEX -- define 'UNSAFE_FORCE_MUTEX' if you
-// do *not* want the locking macro to be thread safe.  
-// Otherwise, access during 'null-mutex' case will be serialized 
+// do *not* want the locking macro to be thread safe.
+// Otherwise, access during 'null-mutex' case will be serialized
 // in a locking manner (too bad for the net threads).
 //
 
@@ -165,10 +165,10 @@ extern "C"
   INKReturnCode sdk_sanity_check_hostlookup_structure(INKHostLookupResult);
   INKReturnCode sdk_sanity_check_iocore_structure(void *);
 
-/* ---------------------------------------------------------------------- 
+/* ----------------------------------------------------------------------
  *
  * Interfaces for Raft project
- * 
+ *
  * ---------------------------------------------------------------------- */
 
   inkapi INKMutex INKMutexCreateInternal(void);

Modified: trafficserver/traffic/trunk/proxy/api/ts/ts.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/api/ts/ts.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/api/ts/ts.h (original)
+++ trafficserver/traffic/trunk/proxy/api/ts/ts.h Thu May 13 07:09:39 2010
@@ -441,7 +441,7 @@ extern "C"
   {
      NO_CALLBACK = 0,
      AFTER_HEADER ,
-     AFTER_BODY 
+     AFTER_BODY
   } INKFetchWakeUpOptions;
   extern inkapi const void *INK_ERROR_PTR;
 
@@ -488,7 +488,7 @@ extern "C"
   typedef void *(*INKThreadFunc) (void *data);
   typedef int (*INKEventFunc) (INKCont contp, INKEvent event, void *edata);
   typedef void (*INKConfigDestroyFunc) (void *data);
-  typedef struct 
+  typedef struct
   {
      int success_event_id;
      int failure_event_id;
@@ -2144,8 +2144,8 @@ extern "C"
   inkapi INKReturnCode INKHttpConnect(unsigned int log_ip, int log_port, INKVConn * vc);
   inkapi INKReturnCode INKFetchUrl(const char *request,int request_len, unsigned int ip, int port , INKCont contp, INKFetchWakeUpOptions callback_options,INKFetchEvent event);
   inkapi INKReturnCode INKFetchPages(INKFetchUrlParams_t *params);
- 
-  /* Check if HTTP State machine is internal or not */ 
+
+  /* Check if HTTP State machine is internal or not */
   inkapi int INKHttpIsInternalRequest(INKHttpTxn txnp);
 
   // --------------------------------------------------------------------------
@@ -2222,8 +2222,8 @@ extern "C"
 
       @param contp continuation that is called back when the attempted
         net connection either succeeds or fails.
-      @param ip of the host to connect to, in network byte order. 
-      @param port of the host to connect to, in host byte order. 
+      @param ip of the host to connect to, in network byte order.
+      @param port of the host to connect to, in host byte order.
       @return something allows you to check if the connection is complete,
         or cancel the attempt to connect.
 

Modified: trafficserver/traffic/trunk/proxy/api/ts/ts_private.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/api/ts/ts_private.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/api/ts/ts_private.h (original)
+++ trafficserver/traffic/trunk/proxy/api/ts/ts_private.h Thu May 13 07:09:39 2010
@@ -24,10 +24,10 @@
 /*  ts_private.h
  *
  *
- *   Interfaces in this header file are experimental, undocumented and 
+ *   Interfaces in this header file are experimental, undocumented and
  *   are subject to change even across minor releases of Traffic Server.
- *   None of the interfaces in this file are committed to be stable 
- *   unless they are migrated to ts/ts.h  If you require stable APIs to 
+ *   None of the interfaces in this file are committed to be stable
+ *   unless they are migrated to ts/ts.h  If you require stable APIs to
  *   Traffic Server, DO NOT USE anything in this file.
  *
  *   $Revision: 1.3 $ $Date: 2003-06-01 18:36:51 $
@@ -82,7 +82,7 @@ extern "C"
 
 #define INK_HTTP_CNTL_OFF  (void*) 0
 #define INK_HTTP_CNTL_ON   (void*) 1
-/* usage: 
+/* usage:
    void *onoff = 0;
    INKHttpTxnCntl(.., INK_HTTP_CNTL_GET_LOGGING_MODE, &onoff);
    if (onoff == INK_HTTP_CNTL_ON) ....

Modified: trafficserver/traffic/trunk/proxy/api/ts/ts_private_frozen.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/api/ts/ts_private_frozen.h?rev=943821&r1=943820&r2=943821&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/api/ts/ts_private_frozen.h (original)
+++ trafficserver/traffic/trunk/proxy/api/ts/ts_private_frozen.h Thu May 13 07:09:39 2010
@@ -22,10 +22,10 @@
  */
 
 /*
- *   Interfaces in this header file are experimental, undocumented and 
+ *   Interfaces in this header file are experimental, undocumented and
  *   are subject to change even across minor releases of Traffic Server.
- *   None of the interfaces in this file are committed to be stable 
- *   unless they are migrated to ts/ts.h  If you require stable APIs to 
+ *   None of the interfaces in this file are committed to be stable
+ *   unless they are migrated to ts/ts.h  If you require stable APIs to
  *   Traffic Server, DO NOT USE anything in this file.
  */
 
@@ -40,7 +40,7 @@ extern "C"
 #endif                          /* __cplusplus */
 
 /****************************************************************************
- *  Create a new field and assign it a name 
+ *  Create a new field and assign it a name
  *  contact: MIXT
  ****************************************************************************/
   inkapi INKMLoc INKMimeHdrFieldCreateNamed(INKMBuffer bufp, INKMLoc mh_mloc, const char *name, int name_len);
@@ -386,24 +386,24 @@ extern "C"
  *	 must be dealt with by the user.
  *    3) Upon receipt of a machine offline, no guarantees are made about
  *	 messages sent prior to the machine offline.
- *    4) A node transitioning to the online state in an active cluster, 
+ *    4) A node transitioning to the online state in an active cluster,
  *	 is assumed to have no prior knowledge of messages processed in
  *	 the past.
- *    5) Key point to reiterate, actions taken in the functions specified in 
- *	 INKAddClusterStatusFunction() and INKAddClusterRPCFunction() must 
- *       be non-blocking (i.e. usage of INKMutexLock() and file i/o is 
+ *    5) Key point to reiterate, actions taken in the functions specified in
+ *	 INKAddClusterStatusFunction() and INKAddClusterRPCFunction() must
+ *       be non-blocking (i.e. usage of INKMutexLock() and file i/o is
  *       not allowed).
  *    6) INKSendClusterRPC() can only process INKClusterRPCMsg_t generated
  *	 by INKAllocClusterRPCMsg().  Failure to adhere to this rule will
  *	 result in heap corruption.
  *    7) Messages sent via INKSendClusterRPC() must be at least 4 bytes in
  * 	 length.
- *    8) The user is not provided with any alignment guarantees on the 
- *	 'm_data' field in the INKClusterRPCMsg_t returned via 
+ *    8) The user is not provided with any alignment guarantees on the
+ *	 'm_data' field in the INKClusterRPCMsg_t returned via
  *	 INKAllocClusterRPCMsg().  Assume byte alignment.
  *    9) INKSendClusterRPC() interface owns the memory and is responsible
  *       for freeing the memory.
- *   10) RPC functions defined via INKAddClusterRPCFunction() own the 
+ *   10) RPC functions defined via INKAddClusterRPCFunction() own the
  *       memory when invoked and are responsible for freeing it via
  *	 INKFreeRPCMsg().
  */
@@ -450,7 +450,7 @@ extern "C"
  *  Subscribe to node up/down status notification.     			    *
  *	Return == 0 Success						    *
  *	Return != 0 Failure						    *
- * contact: OXY, DY 
+ * contact: OXY, DY
  ****************************************************************************/
   inkapi int
     INKAddClusterStatusFunction(INKClusterStatusFunction Status_Function, INKMutex m, INKClusterStatusHandle_t * h);
@@ -458,7 +458,7 @@ extern "C"
  *  Cancel subscription to node up/down status notification. 		    *
  *	Return == 0 Success						    *
  *	Return != 0 Failure						    *
- * contact: OXY, DY 
+ * contact: OXY, DY
  ****************************************************************************/
   inkapi int INKDeleteClusterStatusFunction(INKClusterStatusHandle_t * h);
 
@@ -466,7 +466,7 @@ extern "C"
  *  Get the struct in_addr associated with the INKNodeHandle_t.	    	    *
  *	Return == 0 Success						    *
  *	Return != 0 Failure						    *
- * contact: OXY, DY 
+ * contact: OXY, DY
  ****************************************************************************/
   inkapi int INKNodeHandleToIPAddr(INKNodeHandle_t * h, struct in_addr *in);
 
@@ -525,7 +525,7 @@ extern "C"
  ****************************************************************************/
   inkapi int INKSendClusterRPC(INKNodeHandle_t * nh, INKClusterRPCMsg_t * msg);
 
-/* ---------------------------------------------------------------------- 
+/* ----------------------------------------------------------------------
  * Interfaces used for the AAA project
  * ---------------------------------------------------------------------- */
 
@@ -581,14 +581,14 @@ extern "C"
  ****************************************************************************/
   inkapi INKReturnCode INKUserPolicyFetch(INKU32 ip, char *name);
 
-/* ---------------------------------------------------------------------- 
+/* ----------------------------------------------------------------------
  *
  * Aerocast, MIXT SDK
  * contact: MIXT
  *
  * ----------------------------------------------------------------------  */
 #define INK_EVENT_MIXT_READ_REQUEST_HDR INK_EVENT_INTERNAL_60201
-/* ---------------------------------------------------------------------- 
+/* ----------------------------------------------------------------------
  * Prefetch APIs
  * ----------------------------------------------------------------------  */