You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@httpd.apache.org by ji...@apache.org on 2011/09/23 15:39:35 UTC

svn commit: r1174751 [2/4] - in /httpd/httpd/trunk: modules/aaa/ modules/arch/netware/ modules/arch/unix/ modules/arch/win32/ modules/cache/ modules/cluster/ modules/core/ modules/dav/fs/ modules/dav/main/ modules/echo/ modules/examples/ modules/experi...

Modified: httpd/httpd/trunk/modules/examples/mod_example_ipc.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/examples/mod_example_ipc.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/examples/mod_example_ipc.c (original)
+++ httpd/httpd/trunk/modules/examples/mod_example_ipc.c Fri Sep 23 13:39:32 2011
@@ -14,12 +14,12 @@
  * limitations under the License.
  */
 
-/* 
- *  mod_example_ipc -- Apache sample module 
- * 
+/*
+ *  mod_example_ipc -- Apache sample module
+ *
  * This module illustrates the use in an Apache 2.x module of the Interprocess
- * Communications routines that come with APR. It is example code, and not meant 
- * to be used in a production server. 
+ * Communications routines that come with APR. It is example code, and not meant
+ * to be used in a production server.
  *
  * To play with this sample module first compile it into a DSO file and install
  * it into Apache's modules directory by running:
@@ -42,8 +42,8 @@
  * The module allocates a counter in shared memory, which is incremented by the
  * request handler under a mutex. After installation, activate the handler by
  * hitting the URL configured above with ab at various concurrency levels to see
- * how mutex contention affects server performance. 
- */ 
+ * how mutex contention affects server performance.
+ */
 
 #include "apr.h"
 #include "apr_strings.h"
@@ -81,15 +81,15 @@ static const char *exipc_mutex_type = "e
 
 /* Data structure for shared memory block */
 typedef struct exipc_data {
-    apr_uint64_t counter; 
+    apr_uint64_t counter;
     /* More fields if necessary */
 } exipc_data;
 
-/* 
- * Clean up the shared memory block. This function is registered as 
+/*
+ * Clean up the shared memory block. This function is registered as
  * cleanup function for the configuration pool, which gets called
- * on restarts. It assures that the new children will not talk to a stale 
- * shared memory segment. 
+ * on restarts. It assures that the new children will not talk to a stale
+ * shared memory segment.
  */
 static apr_status_t shm_cleanup_wrapper(void *unused) {
     if (exipc_shm)
@@ -103,36 +103,36 @@ static apr_status_t shm_cleanup_wrapper(
  * adjust the mutex settings using the Mutex directive.
  */
 
-static int exipc_pre_config(apr_pool_t *pconf, apr_pool_t *plog, 
+static int exipc_pre_config(apr_pool_t *pconf, apr_pool_t *plog,
                             apr_pool_t *ptemp)
 {
     ap_mutex_register(pconf, exipc_mutex_type, NULL, APR_LOCK_DEFAULT, 0);
     return OK;
 }
 
-/* 
+/*
  * This routine is called in the parent, so we'll set up the shared
- * memory segment and mutex here. 
+ * memory segment and mutex here.
  */
 
-static int exipc_post_config(apr_pool_t *pconf, apr_pool_t *plog, 
+static int exipc_post_config(apr_pool_t *pconf, apr_pool_t *plog,
                              apr_pool_t *ptemp, server_rec *s)
 {
     apr_status_t rs;
     exipc_data *base;
-    const char *tempdir; 
+    const char *tempdir;
 
 
-    /* 
+    /*
      * Do nothing if we are not creating the final configuration.
      * The parent process gets initialized a couple of times as the
      * server starts up, and we don't want to create any more mutexes
-     * and shared memory segments than we're actually going to use. 
-     */ 
+     * and shared memory segments than we're actually going to use.
+     */
     if (ap_state_query(AP_SQ_MAIN_STATE) == AP_SQ_MS_CREATE_PRE_CONFIG)
         return OK;
 
-    /* 
+    /*
      * The shared memory allocation routines take a file name.
      * Depending on system-specific implementation of these
      * routines, that file may or may not actually be created. We'd
@@ -141,26 +141,26 @@ static int exipc_post_config(apr_pool_t 
      */
     rs = apr_temp_dir_get(&tempdir, pconf);
     if (APR_SUCCESS != rs) {
-        ap_log_error(APLOG_MARK, APLOG_ERR, rs, s, 
+        ap_log_error(APLOG_MARK, APLOG_ERR, rs, s,
                      "Failed to find temporary directory");
         return HTTP_INTERNAL_SERVER_ERROR;
     }
 
     /* Create the shared memory segment */
 
-    /* 
-     * Create a unique filename using our pid. This information is 
+    /*
+     * Create a unique filename using our pid. This information is
      * stashed in the global variable so the children inherit it.
      */
-    shmfilename = apr_psprintf(pconf, "%s/httpd_shm.%ld", tempdir, 
+    shmfilename = apr_psprintf(pconf, "%s/httpd_shm.%ld", tempdir,
                                (long int)getpid());
 
     /* Now create that segment */
-    rs = apr_shm_create(&exipc_shm, sizeof(exipc_data), 
+    rs = apr_shm_create(&exipc_shm, sizeof(exipc_data),
                         (const char *) shmfilename, pconf);
     if (APR_SUCCESS != rs) {
-        ap_log_error(APLOG_MARK, APLOG_ERR, rs, s, 
-                     "Failed to create shared memory segment on file %s", 
+        ap_log_error(APLOG_MARK, APLOG_ERR, rs, s,
+                     "Failed to create shared memory segment on file %s",
                      shmfilename);
         return HTTP_INTERNAL_SERVER_ERROR;
     }
@@ -177,17 +177,17 @@ static int exipc_post_config(apr_pool_t 
         return HTTP_INTERNAL_SERVER_ERROR;
     }
 
-    /* 
+    /*
      * Destroy the shm segment when the configuration pool gets destroyed. This
      * happens on server restarts. The parent will then (above) allocate a new
-     * shm segment that the new children will bind to. 
+     * shm segment that the new children will bind to.
      */
-    apr_pool_cleanup_register(pconf, NULL, shm_cleanup_wrapper, 
-                              apr_pool_cleanup_null);    
+    apr_pool_cleanup_register(pconf, NULL, shm_cleanup_wrapper,
+                              apr_pool_cleanup_null);
     return OK;
 }
 
-/* 
+/*
  * This routine gets called when a child inits. We use it to attach
  * to the shared memory segment, and reinitialize the mutex.
  */
@@ -195,17 +195,17 @@ static int exipc_post_config(apr_pool_t 
 static void exipc_child_init(apr_pool_t *p, server_rec *s)
 {
     apr_status_t rs;
-         
-    /* 
+
+    /*
      * Re-open the mutex for the child. Note we're reusing
-     * the mutex pointer global here. 
+     * the mutex pointer global here.
      */
-    rs = apr_global_mutex_child_init(&exipc_mutex, 
+    rs = apr_global_mutex_child_init(&exipc_mutex,
                                      apr_global_mutex_lockfile(exipc_mutex),
                                      p);
     if (APR_SUCCESS != rs) {
-        ap_log_error(APLOG_MARK, APLOG_CRIT, rs, s, 
-                     "Failed to reopen mutex %s in child", 
+        ap_log_error(APLOG_MARK, APLOG_CRIT, rs, s,
+                     "Failed to reopen mutex %s in child",
                      exipc_mutex_type);
         /* There's really nothing else we can do here, since This
          * routine doesn't return a status. If this ever goes wrong,
@@ -213,7 +213,7 @@ static void exipc_child_init(apr_pool_t 
          * will.
          */
         exit(1); /* Ugly, but what else? */
-    } 
+    }
 }
 
 /* The sample content handler */
@@ -223,21 +223,21 @@ static int exipc_handler(request_rec *r)
     int camped;
     apr_time_t startcamp;
     apr_int64_t timecamped;
-    apr_status_t rs; 
+    apr_status_t rs;
     exipc_data *base;
-    
+
     if (strcmp(r->handler, "example_ipc")) {
         return DECLINED;
     }
-    
-    /* 
-     * The main function of the handler, aside from sending the 
-     * status page to the client, is to increment the counter in 
-     * the shared memory segment. This action needs to be mutexed 
-     * out using the global mutex. 
+
+    /*
+     * The main function of the handler, aside from sending the
+     * status page to the client, is to increment the counter in
+     * the shared memory segment. This action needs to be mutexed
+     * out using the global mutex.
      */
-     
-    /* 
+
+    /*
      * First, acquire the lock. This code is a lot more involved than
      * it usually needs to be, because the process based trylock
      * routine is not implemented on unix platforms. I left it in to
@@ -245,11 +245,11 @@ static int exipc_handler(request_rec *r)
      * and platforms where trylock works.
      */
     for (camped = 0, timecamped = 0; camped < MAXCAMP; camped++) {
-        rs = apr_global_mutex_trylock(exipc_mutex); 
+        rs = apr_global_mutex_trylock(exipc_mutex);
         if (APR_STATUS_IS_EBUSY(rs)) {
             apr_sleep(CAMPOUT);
         } else if (APR_SUCCESS == rs) {
-            gotlock = 1; 
+            gotlock = 1;
             break; /* Get out of the loop */
         } else if (APR_STATUS_IS_ENOTIMPL(rs)) {
             /* If it's not implemented, just hang in the mutex. */
@@ -261,36 +261,36 @@ static int exipc_handler(request_rec *r)
                 break; /* Out of the loop */
             } else {
                 /* Some error, log and bail */
-                ap_log_error(APLOG_MARK, APLOG_ERR, rs, r->server, 
-                             "Child %ld failed to acquire lock", 
+                ap_log_error(APLOG_MARK, APLOG_ERR, rs, r->server,
+                             "Child %ld failed to acquire lock",
                              (long int)getpid());
                 break; /* Out of the loop without having the lock */
-            }                
+            }
         } else {
             /* Some other error, log and bail */
-            ap_log_error(APLOG_MARK, APLOG_ERR, rs, r->server, 
-                         "Child %ld failed to try and acquire lock", 
+            ap_log_error(APLOG_MARK, APLOG_ERR, rs, r->server,
+                         "Child %ld failed to try and acquire lock",
                          (long int)getpid());
             break; /* Out of the loop without having the lock */
-            
+
         }
-        /* 
+        /*
          * The only way to get to this point is if the trylock worked
          * and returned BUSY. So, bump the time and try again
          */
         timecamped += CAMPOUT;
-        ap_log_error(APLOG_MARK, APLOG_NOERRNO | APLOG_NOTICE, 
+        ap_log_error(APLOG_MARK, APLOG_NOERRNO | APLOG_NOTICE,
                      0, r->server, "Child %ld camping out on mutex for %" APR_INT64_T_FMT
                      " microseconds",
                      (long int) getpid(), timecamped);
     } /* Lock acquisition loop */
-    
+
     /* Sleep for a millisecond to make it a little harder for
-     * httpd children to acquire the lock. 
+     * httpd children to acquire the lock.
      */
     apr_sleep(SLEEPYTIME);
-    
-    r->content_type = "text/html";      
+
+    r->content_type = "text/html";
 
     if (!r->header_only) {
         ap_rputs(HTML_HEADER, r);
@@ -299,32 +299,32 @@ static int exipc_handler(request_rec *r)
             base = (exipc_data *)apr_shm_baseaddr_get(exipc_shm);
             base->counter++;
             /* Send a page with our pid and the new value of the counter. */
-            ap_rprintf(r, "<p>Lock acquired after %ld microseoncds.</p>\n", 
-                       (long int) timecamped); 
+            ap_rprintf(r, "<p>Lock acquired after %ld microseoncds.</p>\n",
+                       (long int) timecamped);
             ap_rputs("<table border=\"1\">\n", r);
-            ap_rprintf(r, "<tr><td>Child pid:</td><td>%d</td></tr>\n", 
+            ap_rprintf(r, "<tr><td>Child pid:</td><td>%d</td></tr>\n",
                        (int) getpid());
-            ap_rprintf(r, "<tr><td>Counter:</td><td>%u</td></tr>\n", 
+            ap_rprintf(r, "<tr><td>Counter:</td><td>%u</td></tr>\n",
                        (unsigned int)base->counter);
             ap_rputs("</table>\n", r);
         } else {
-            /* 
+            /*
              * Send a page saying that we couldn't get the lock. Don't say
              * what the counter is, because without the lock the value could
-             * race. 
+             * race.
              */
             ap_rprintf(r, "<p>Child %d failed to acquire lock "
-                       "after camping out for %d microseconds.</p>\n", 
+                       "after camping out for %d microseconds.</p>\n",
                        (int) getpid(), (int) timecamped);
         }
-        ap_rputs(HTML_FOOTER, r); 
+        ap_rputs(HTML_FOOTER, r);
     } /* r->header_only */
-    
+
     /* Release the lock */
     if (gotlock)
-        rs = apr_global_mutex_unlock(exipc_mutex); 
-    /* Swallowing the result because what are we going to do with it at 
-     * this stage? 
+        rs = apr_global_mutex_unlock(exipc_mutex);
+    /* Swallowing the result because what are we going to do with it at
+     * this stage?
      */
 
     return OK;
@@ -333,14 +333,14 @@ static int exipc_handler(request_rec *r)
 static void exipc_register_hooks(apr_pool_t *p)
 {
     ap_hook_pre_config(exipc_pre_config, NULL, NULL, APR_HOOK_MIDDLE);
-    ap_hook_post_config(exipc_post_config, NULL, NULL, APR_HOOK_MIDDLE); 
-    ap_hook_child_init(exipc_child_init, NULL, NULL, APR_HOOK_MIDDLE); 
+    ap_hook_post_config(exipc_post_config, NULL, NULL, APR_HOOK_MIDDLE);
+    ap_hook_child_init(exipc_child_init, NULL, NULL, APR_HOOK_MIDDLE);
     ap_hook_handler(exipc_handler, NULL, NULL, APR_HOOK_MIDDLE);
 }
 
 /* Dispatch list for API hooks */
 AP_DECLARE_MODULE(example_ipc) = {
-    STANDARD20_MODULE_STUFF, 
+    STANDARD20_MODULE_STUFF,
     NULL,                  /* create per-dir    config structures */
     NULL,                  /* merge  per-dir    config structures */
     NULL,                  /* create per-server config structures */

Modified: httpd/httpd/trunk/modules/experimental/mod_noloris.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/experimental/mod_noloris.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/experimental/mod_noloris.c (original)
+++ httpd/httpd/trunk/modules/experimental/mod_noloris.c Fri Sep 23 13:39:32 2011
@@ -80,7 +80,7 @@ static int noloris_conn(conn_rec *conn)
     }
 
     /* store this client IP for the monitor to pick up */
- 
+
     ap_update_child_status_from_conn(conn->sbh, SERVER_READY, conn);
 
     return DECLINED;

Modified: httpd/httpd/trunk/modules/filters/mod_buffer.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_buffer.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_buffer.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_buffer.c Fri Sep 23 13:39:32 2011
@@ -141,7 +141,7 @@ static apr_status_t buffer_out_filter(ap
             /* pass what we have down the chain */
             rv = ap_pass_brigade(f->next, ctx->bb);
             if (rv) {
-                /* should break out of the loop, since our write to the client 
+                /* should break out of the loop, since our write to the client
                  * failed in some way. */
                 continue;
             }

Modified: httpd/httpd/trunk/modules/filters/mod_charset_lite.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_charset_lite.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_charset_lite.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_charset_lite.c Fri Sep 23 13:39:32 2011
@@ -249,7 +249,7 @@ static int find_code_page(request_rec *r
 
     reqinfo->dc = dc;
     output_ctx->dc = dc;
-    output_ctx->tmpbb = apr_brigade_create(r->pool, 
+    output_ctx->tmpbb = apr_brigade_create(r->pool,
                                            r->connection->bucket_alloc);
     ap_set_module_config(r->request_config, &charset_lite_module, reqinfo);
 
@@ -319,7 +319,7 @@ static void xlate_insert_filter(request_
     charset_dir_t *dc = ap_get_module_config(r->per_dir_config,
                                              &charset_lite_module);
 
-    if (dc && (dc->implicit_add == IA_NOIMPADD)) { 
+    if (dc && (dc->implicit_add == IA_NOIMPADD)) {
         ap_log_rerror(APLOG_MARK, APLOG_TRACE6, 0, r,
                       "xlate output filter not added implicitly because "
                       "CharsetOptions included 'NoImplicitAdd'");
@@ -805,7 +805,7 @@ static apr_status_t xlate_out_filter(ap_
          */
             strcmp(mime_type, DIR_MAGIC_TYPE) == 0 ||
 #endif
-            strncasecmp(mime_type, "message/", 8) == 0 || 
+            strncasecmp(mime_type, "message/", 8) == 0 ||
             dc->force_xlate == FX_FORCE)) {
 
             rv = apr_xlate_open(&ctx->xlate,

Modified: httpd/httpd/trunk/modules/filters/mod_data.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_data.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_data.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_data.c Fri Sep 23 13:39:32 2011
@@ -224,7 +224,7 @@ static apr_status_t data_out_filter(ap_f
             /* pass what we have down the chain */
             rv = ap_pass_brigade(f->next, ctx->bb);
             if (rv) {
-                /* should break out of the loop, since our write to the client 
+                /* should break out of the loop, since our write to the client
                  * failed in some way. */
                 continue;
             }

Modified: httpd/httpd/trunk/modules/filters/mod_deflate.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_deflate.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_deflate.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_deflate.c Fri Sep 23 13:39:32 2011
@@ -416,7 +416,7 @@ static void deflate_check_etag(request_r
 
             apr_table_setn(r->headers_out, "ETag", newtag);
         }
-    }   
+    }
 }
 
 static apr_status_t deflate_out_filter(ap_filter_t *f,

Modified: httpd/httpd/trunk/modules/filters/mod_filter.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_filter.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_filter.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_filter.c Fri Sep 23 13:39:32 2011
@@ -509,8 +509,8 @@ static const char *filter_chain(cmd_parm
         break;
 
     case '!':        /* Empty the chain */
-                     /** IG: Add a NULL provider to the beginning so that 
-                      *  we can ensure that we'll empty everything before 
+                     /** IG: Add a NULL provider to the beginning so that
+                      *  we can ensure that we'll empty everything before
                       *  this when doing config merges later */
         p = apr_pcalloc(cmd->pool, sizeof(mod_filter_chain));
         p->fname = NULL;
@@ -622,7 +622,7 @@ static void filter_insert(request_rec *r
      *  through the chain, and prune out the NULL filters */
 
     for (p = cfg->chain; p; p = p->next) {
-        if (p->fname == NULL) 
+        if (p->fname == NULL)
             cfg->chain = p->next;
     }
 

Modified: httpd/httpd/trunk/modules/filters/mod_include.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_include.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_include.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_include.c Fri Sep 23 13:39:32 2011
@@ -1551,7 +1551,7 @@ static int parse_expr(include_ctx_t *ctx
             }
             else {
                 current->value = 0;
-                ap_log_rerror(APLOG_MARK, APLOG_DEBUG, rr->status, r, 
+                ap_log_rerror(APLOG_MARK, APLOG_DEBUG, rr->status, r,
                               "mod_include: The tested "
                               "subrequest -A \"%s\" returned an error code.",
                               current->right->token.value);

Modified: httpd/httpd/trunk/modules/filters/mod_reqtimeout.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_reqtimeout.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_reqtimeout.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_reqtimeout.c Fri Sep 23 13:39:32 2011
@@ -80,7 +80,7 @@ static apr_status_t check_time_left(reqt
     *time_left_p = ccfg->timeout_at - apr_time_now();
     if (*time_left_p <= 0)
         return APR_TIMEUP;
-    
+
     if (*time_left_p < apr_time_from_sec(1)) {
         *time_left_p = apr_time_from_sec(1);
     }
@@ -393,7 +393,7 @@ static int reqtimeout_after_body(request
     ccfg->new_max_timeout = cfg->header_max_timeout;
     ccfg->min_rate = cfg->header_min_rate;
     ccfg->rate_factor = cfg->header_rate_factor;
-    
+
     ccfg->type = "header";
 
     return OK;
@@ -470,7 +470,7 @@ static const char *set_reqtimeout_param(
     else {
         return "Unknown RequestReadTimeout parameter";
     }
-    
+
     if ((rate_str = ap_strcasestr(val, ",minrate="))) {
         initial_str = apr_pstrndup(p, val, rate_str - val);
         rate_str += strlen(",minrate=");
@@ -487,7 +487,7 @@ static const char *set_reqtimeout_param(
             if (ret)
                 return ret;
         }
-        
+
         ret = parse_int(p, initial_str, &initial);
     }
     else {
@@ -495,7 +495,7 @@ static const char *set_reqtimeout_param(
             return "Must set MinRate option if using timeout range";
         ret = parse_int(p, val, &initial);
     }
-        
+
     if (ret)
         return ret;
 
@@ -526,11 +526,11 @@ static const char *set_reqtimeouts(cmd_p
     reqtimeout_srv_cfg *conf =
     ap_get_module_config(cmd->server->module_config,
                          &reqtimeout_module);
-    
+
     while (*arg) {
         char *word, *val;
         const char *err;
-        
+
         word = ap_getword_conf(cmd->temp_pool, &arg);
         val = strchr(word, '=');
         if (!val) {
@@ -541,14 +541,14 @@ static const char *set_reqtimeouts(cmd_p
             *val++ = '\0';
 
         err = set_reqtimeout_param(conf, cmd->pool, word, val);
-        
+
         if (err)
             return apr_psprintf(cmd->temp_pool, "RequestReadTimeout: %s=%s: %s",
                                word, val, err);
     }
-    
+
     return NULL;
-    
+
 }
 
 static void reqtimeout_hooks(apr_pool_t *pool)

Modified: httpd/httpd/trunk/modules/filters/mod_sed.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_sed.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_sed.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_sed.c Fri Sep 23 13:39:32 2011
@@ -5,14 +5,14 @@
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- *  http://www.apache.org/licenses/LICENSE-2.0. 
- * 
- * Unless required by applicable law or agreed to in writing, software 
- * distributed under the License is distributed on an "AS IS" BASIS, 
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express 
- * or implied. 
+ *  http://www.apache.org/licenses/LICENSE-2.0.
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied.
  * See the License for the specific language governing permissions and
- * limitations under the License. 
+ * limitations under the License.
  */
 
 #include "httpd.h"
@@ -490,7 +490,7 @@ static apr_status_t sed_request_filter(a
 static const char *sed_add_expr(cmd_parms *cmd, void *cfg, const char *arg)
 {
     int offset = (int) (long) cmd->info;
-    sed_expr_config *sed_cfg = 
+    sed_expr_config *sed_cfg =
                 (sed_expr_config *) (((char *) cfg) + offset);
     if (compile_sed_expr(sed_cfg, cmd, arg) != APR_SUCCESS) {
         return apr_psprintf(cmd->temp_pool,

Modified: httpd/httpd/trunk/modules/filters/mod_substitute.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/mod_substitute.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/mod_substitute.c (original)
+++ httpd/httpd/trunk/modules/filters/mod_substitute.c Fri Sep 23 13:39:32 2011
@@ -124,7 +124,7 @@ static void do_pattmatch(ap_filter_t *f,
     subst_pattern_t *script;
 
     APR_BRIGADE_INSERT_TAIL(mybb, inb);
-    
+
     script = (subst_pattern_t *) cfg->patterns->elts;
     apr_pool_create(&tpool, tmp_pool);
     scratch = NULL;
@@ -281,7 +281,7 @@ static apr_status_t substitute_filter(ap
     apr_status_t rv;
 
     substitute_module_ctx *ctx = f->ctx;
-    
+
     /*
      * First time around? Create the saved bb that we used for each pass
      * through. Note that we can also get here when we explicitly clear ctx,
@@ -560,7 +560,7 @@ static const char *set_pattern(cmd_parms
 
     if (is_pattern) {
         nscript->patlen = strlen(from);
-        nscript->pattern = apr_strmatch_precompile(cmd->pool, from, 
+        nscript->pattern = apr_strmatch_precompile(cmd->pool, from,
                                                    !ignore_case);
     }
     else {

Modified: httpd/httpd/trunk/modules/filters/regexp.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/regexp.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/regexp.c (original)
+++ httpd/httpd/trunk/modules/filters/regexp.c Fri Sep 23 13:39:32 2011
@@ -2,8 +2,8 @@
  * Copyright (c) 2005, 2008 Sun Microsystems, Inc. All Rights Reserved.
  * Use is subject to license terms.
  *
- *	Copyright (c) 1984, 1986, 1987, 1988, 1989 AT&T	
- *	  All Rights Reserved  	
+ *	Copyright (c) 1984, 1986, 1987, 1988, 1989 AT&T
+ *	  All Rights Reserved
  *
  * University Copyright- Copyright (c) 1982, 1986, 1988
  * The Regents of the University of California
@@ -16,14 +16,14 @@
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- *  http://www.apache.org/licenses/LICENSE-2.0. 
- * 
- * Unless required by applicable law or agreed to in writing, software 
- * distributed under the License is distributed on an "AS IS" BASIS, 
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express 
- * or implied. 
+ *  http://www.apache.org/licenses/LICENSE-2.0.
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied.
  * See the License for the specific language governing permissions and
- * limitations under the License. 
+ * limitations under the License.
  */
 
 /* Code moved from regexp.h */

Modified: httpd/httpd/trunk/modules/filters/sed0.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/sed0.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/sed0.c (original)
+++ httpd/httpd/trunk/modules/filters/sed0.c Fri Sep 23 13:39:32 2011
@@ -3,19 +3,19 @@
  * Use is subject to license terms.
  *
  *	Copyright (c) 1984 AT&T
- *	  All Rights Reserved  	
+ *	  All Rights Reserved
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- *  http://www.apache.org/licenses/LICENSE-2.0. 
- * 
- * Unless required by applicable law or agreed to in writing, software 
- * distributed under the License is distributed on an "AS IS" BASIS, 
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express 
- * or implied. 
+ *  http://www.apache.org/licenses/LICENSE-2.0.
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied.
  * See the License for the specific language governing permissions and
- * limitations under the License. 
+ * limitations under the License.
  */
 
 #include "apr.h"
@@ -85,7 +85,7 @@ apr_status_t sed_init_commands(sed_comma
 
     return APR_SUCCESS;
 }
- 
+
 /*
  * sed_destroy_commands
  */
@@ -541,7 +541,7 @@ jtcommon:
                     command_errf(commands, SEDERR_NRMES);
                     return -1;
                 }
-            } else 
+            } else
                 op = commands->rep->re1;
             commands->rep->rhs = p;
 

Modified: httpd/httpd/trunk/modules/filters/sed1.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/filters/sed1.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/filters/sed1.c (original)
+++ httpd/httpd/trunk/modules/filters/sed1.c Fri Sep 23 13:39:32 2011
@@ -3,19 +3,19 @@
  * Use is subject to license terms.
  *
  *	Copyright (c) 1984 AT&T
- *	  All Rights Reserved  	
+ *	  All Rights Reserved
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- *  http://www.apache.org/licenses/LICENSE-2.0. 
- * 
- * Unless required by applicable law or agreed to in writing, software 
- * distributed under the License is distributed on an "AS IS" BASIS, 
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express 
- * or implied. 
+ *  http://www.apache.org/licenses/LICENSE-2.0.
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied.
  * See the License for the specific language governing permissions and
- * limitations under the License. 
+ * limitations under the License.
  */
 
 #include "apr.h"
@@ -394,7 +394,7 @@ apr_status_t sed_eval_buffer(sed_eval_t 
             eval->lreadyflag = 1;
             break;
         }
-        
+
         appendmem_to_linebuf(eval, buf, llen + 1);
         --eval->lspend;
         /* replace new line character with NULL */
@@ -953,7 +953,7 @@ static apr_status_t command(sed_eval_t *
             copy_to_holdbuf(eval, eval->genbuf);
             break;
 
-        case YCOM: 
+        case YCOM:
             p1 = eval->linebuf;
             p2 = ipc->re1;
             while((*p1 = p2[(unsigned char)*p1]) != 0)    p1++;

Modified: httpd/httpd/trunk/modules/generators/mod_autoindex.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/generators/mod_autoindex.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/generators/mod_autoindex.c (original)
+++ httpd/httpd/trunk/modules/generators/mod_autoindex.c Fri Sep 23 13:39:32 2011
@@ -583,8 +583,8 @@ static const command_rec autoindex_cmds[
                   "{Ascending,Descending} {Name,Size,Description,Date}"),
     AP_INIT_ITERATE("IndexIgnore", add_ignore, NULL, DIR_CMD_PERMS,
                     "one or more file extensions"),
-    AP_INIT_FLAG("IndexIgnoreReset", ap_set_flag_slot, 
-                 (void *)APR_OFFSETOF(autoindex_config_rec, ign_noinherit), 
+    AP_INIT_FLAG("IndexIgnoreReset", ap_set_flag_slot,
+                 (void *)APR_OFFSETOF(autoindex_config_rec, ign_noinherit),
                  DIR_CMD_PERMS,
                  "Reset the inherited list of IndexIgnore filenames"),
     AP_INIT_ITERATE2("AddDescription", add_desc, BY_PATH, DIR_CMD_PERMS,
@@ -1101,9 +1101,9 @@ static void emit_head(request_rec *r, ch
     if (emit_amble) {
         emit_preamble(r, emit_xhtml, title);
     }
-    
+
     d = (autoindex_config_rec *) ap_get_module_config(r->per_dir_config, &autoindex_module);
-    
+
     if (emit_H1) {
         if (d->style_sheet != NULL) {
     	    /* Insert style id if stylesheet used */
@@ -2313,7 +2313,7 @@ static int handle_autoindex(request_rec 
         ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                       "Cannot serve directory %s: No matching DirectoryIndex (%s) found, and "
                       "server-generated directory index forbidden by "
-                      "Options directive", 
+                      "Options directive",
                        r->filename,
                        index_names ? index_names : "none");
         return HTTP_FORBIDDEN;

Modified: httpd/httpd/trunk/modules/generators/mod_cgi.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/generators/mod_cgi.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/generators/mod_cgi.c (original)
+++ httpd/httpd/trunk/modules/generators/mod_cgi.c Fri Sep 23 13:39:32 2011
@@ -53,7 +53,7 @@
 #include "mod_core.h"
 #include "mod_cgi.h"
 
-#if APR_HAVE_STRUCT_RLIMIT 
+#if APR_HAVE_STRUCT_RLIMIT
 #if defined (RLIMIT_CPU) || defined (RLIMIT_NPROC) || defined (RLIMIT_DATA) || defined(RLIMIT_VMEM) || defined(RLIMIT_AS)
 #define AP_CGI_USE_RLIMIT
 #endif

Modified: httpd/httpd/trunk/modules/generators/mod_cgid.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/generators/mod_cgid.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/generators/mod_cgid.c (original)
+++ httpd/httpd/trunk/modules/generators/mod_cgid.c Fri Sep 23 13:39:32 2011
@@ -70,7 +70,7 @@
 #include <sys/stat.h>
 #include <sys/un.h> /* for sockaddr_un */
 
-#if APR_HAVE_STRUCT_RLIMIT 
+#if APR_HAVE_STRUCT_RLIMIT
 #if defined (RLIMIT_CPU) || defined (RLIMIT_NPROC) || defined (RLIMIT_DATA) || defined(RLIMIT_VMEM) || defined(RLIMIT_AS)
 #define AP_CGID_USE_RLIMIT
 #endif
@@ -174,7 +174,7 @@ typedef struct {
 } cgid_server_conf;
 
 #ifdef AP_CGID_USE_RLIMIT
-typedef struct { 
+typedef struct {
 #ifdef RLIMIT_CPU
     int    limit_cpu_set;
     struct rlimit limit_cpu;

Modified: httpd/httpd/trunk/modules/generators/mod_status.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/generators/mod_status.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/generators/mod_status.c (original)
+++ httpd/httpd/trunk/modules/generators/mod_status.c Fri Sep 23 13:39:32 2011
@@ -829,7 +829,7 @@ static int status_handler(request_rec *r
                                ap_escape_html(r->pool,
                                               ws_record->vhost),
                                ap_escape_html(r->pool,
-                                              ap_escape_logitem(r->pool, 
+                                              ap_escape_logitem(r->pool,
                                                       ws_record->request)));
                 } /* no_table_report */
             } /* for (j...) */

Modified: httpd/httpd/trunk/modules/http/byterange_filter.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/http/byterange_filter.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/http/byterange_filter.c (original)
+++ httpd/httpd/trunk/modules/http/byterange_filter.c Fri Sep 23 13:39:32 2011
@@ -101,7 +101,7 @@ static int ap_set_byterange(request_rec 
     if (r->assbackwards) {
         return 0;
     }
-    
+
     /*
      * Check for Range request-header (HTTP/1.1) or Request-Range for
      * backwards-compatibility with second-draft Luotonen/Franks
@@ -112,27 +112,27 @@ static int ap_set_byterange(request_rec 
      * Request-Range based requests to work around a bug in Netscape
      * Navigator 2-3 and MSIE 3.
      */
-    
+
     if (!(range = apr_table_get(r->headers_in, "Range"))) {
         range = apr_table_get(r->headers_in, "Request-Range");
     }
-    
+
     if (!range || strncasecmp(range, "bytes=", 6) || r->status != HTTP_OK) {
         return 0;
     }
-    
+
     /* is content already a single range? */
     if (apr_table_get(r->headers_out, "Content-Range")) {
         return 0;
     }
-    
+
     /* is content already a multiple range? */
     if ((ct = apr_table_get(r->headers_out, "Content-Type"))
         && (!strncasecmp(ct, "multipart/byteranges", 20)
             || !strncasecmp(ct, "multipart/x-byteranges", 22))) {
             return 0;
         }
-    
+
     /*
      * Check the If-Range header for Etag or Date.
      * Note that this check will return false (as required) if either
@@ -150,7 +150,7 @@ static int ap_set_byterange(request_rec 
             return 0;
         }
     }
-    
+
     range += 6;
     it = range;
     while (*it) {
@@ -167,19 +167,19 @@ static int ap_set_byterange(request_rec 
         char *dash;
         char *errp;
         apr_off_t number, start, end;
-        
+
         if (!*cur)
             break;
-        
+
         /*
          * Per RFC 2616 14.35.1: If there is at least one syntactically invalid
          * byte-range-spec, we must ignore the whole header.
          */
-        
+
         if (!(dash = strchr(cur, '-'))) {
             return 0;
         }
-        
+
         if (dash == cur) {
             /* In the form "-5" */
             if (apr_strtoff(&number, dash+1, &errp, 10) || *errp) {
@@ -210,7 +210,7 @@ static int ap_set_byterange(request_rec 
                 end = clength - 1;
             }
         }
-        
+
         if (start < 0) {
             start = 0;
         }
@@ -221,7 +221,7 @@ static int ap_set_byterange(request_rec 
         if (end >= clength) {
             end = clength - 1;
         }
-        
+
         if (!in_merge) {
             /* new set */
             ostart = start;
@@ -230,11 +230,11 @@ static int ap_set_byterange(request_rec 
             continue;
         }
         in_merge = 0;
-        
+
         if (start >= ostart && end <= oend) {
             in_merge = 1;
         }
-        
+
         if (start < ostart && end >= ostart-1) {
             ostart = start;
             ++*reversals;
@@ -244,7 +244,7 @@ static int ap_set_byterange(request_rec 
             oend = end;
             in_merge = 1;
         }
-        
+
         if (in_merge) {
             ++*overlaps;
             continue;
@@ -260,7 +260,7 @@ static int ap_set_byterange(request_rec 
             num_ranges++;
         }
     }
-    
+
     if (in_merge) {
         idx = (indexes_t *)apr_array_push(*indexes);
         idx->start = ostart;
@@ -294,7 +294,7 @@ static int ap_set_byterange(request_rec 
     ap_log_rerror(APLOG_MARK, APLOG_DEBUG, 0, r,
                   "Range: %s | %s (%d : %d : %"APR_OFF_T_FMT")",
                   it, r->range, *overlaps, *reversals, clength);
-    
+
     return num_ranges;
 }
 

Modified: httpd/httpd/trunk/modules/http/http_core.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/http/http_core.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/http/http_core.c (original)
+++ httpd/httpd/trunk/modules/http/http_core.c Fri Sep 23 13:39:32 2011
@@ -101,14 +101,14 @@ static const command_rec http_cmds[] = {
 
 static const char *http_scheme(const request_rec *r)
 {
-    /* 
-     * The http module shouldn't return anything other than 
+    /*
+     * The http module shouldn't return anything other than
      * "http" (the default) or "https".
      */
     if (r->server->server_scheme &&
         (strcmp(r->server->server_scheme, "https") == 0))
         return "https";
-    
+
     return "http";
 }
 
@@ -117,7 +117,7 @@ static apr_port_t http_port(const reques
     if (r->server->server_scheme &&
         (strcmp(r->server->server_scheme, "https") == 0))
         return DEFAULT_HTTPS_PORT;
-    
+
     return DEFAULT_HTTP_PORT;
 }
 
@@ -150,7 +150,7 @@ static int ap_process_http_async_connect
                 r = NULL;
             }
 
-            if (cs->state != CONN_STATE_WRITE_COMPLETION && 
+            if (cs->state != CONN_STATE_WRITE_COMPLETION &&
                 cs->state != CONN_STATE_SUSPENDED) {
                 /* Something went wrong; close the connection */
                 cs->state = CONN_STATE_LINGER;

Modified: httpd/httpd/trunk/modules/http/http_filters.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/http/http_filters.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/http/http_filters.c (original)
+++ httpd/httpd/trunk/modules/http/http_filters.c Fri Sep 23 13:39:32 2011
@@ -392,11 +392,11 @@ apr_status_t ap_http_filter(ap_filter_t 
 
             /* Detect chunksize error (such as overflow) */
             if (rv != APR_SUCCESS || ctx->remaining < 0) {
-                ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, f->r, "Error reading first chunk %s ", 
+                ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, f->r, "Error reading first chunk %s ",
                               (ctx->remaining < 0) ? "(overflow)" : "");
                 ctx->remaining = 0; /* Reset it in case we have to
                                      * come back here later */
-                if (APR_STATUS_IS_TIMEUP(rv)) { 
+                if (APR_STATUS_IS_TIMEUP(rv)) {
                     http_error = HTTP_REQUEST_TIME_OUT;
                 }
                 return bail_out_on_error(ctx, f, http_error);
@@ -498,11 +498,11 @@ apr_status_t ap_http_filter(ap_filter_t 
 
                 /* Detect chunksize error (such as overflow) */
                 if (rv != APR_SUCCESS || ctx->remaining < 0) {
-                    ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, f->r, "Error reading chunk %s ", 
+                    ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, f->r, "Error reading chunk %s ",
                                   (ctx->remaining < 0) ? "(overflow)" : "");
                     ctx->remaining = 0; /* Reset it in case we have to
                                          * come back here later */
-                    if (APR_STATUS_IS_TIMEUP(rv)) { 
+                    if (APR_STATUS_IS_TIMEUP(rv)) {
                         http_error = HTTP_REQUEST_TIME_OUT;
                     }
                     return bail_out_on_error(ctx, f, http_error);

Modified: httpd/httpd/trunk/modules/http/http_protocol.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/http/http_protocol.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/http/http_protocol.c (original)
+++ httpd/httpd/trunk/modules/http/http_protocol.c Fri Sep 23 13:39:32 2011
@@ -158,7 +158,7 @@ static int is_mpm_running(void)
     if (ap_mpm_query(AP_MPMQ_MPM_STATE, &mpm_state)) {
       return 0;
     }
-  
+
     if (mpm_state == AP_MPMQ_STOPPING) {
       return 0;
     }

Modified: httpd/httpd/trunk/modules/http/http_request.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/http/http_request.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/http/http_request.c (original)
+++ httpd/httpd/trunk/modules/http/http_request.c Fri Sep 23 13:39:32 2011
@@ -252,14 +252,14 @@ AP_DECLARE(void) ap_process_request_afte
     bb = apr_brigade_create(r->connection->pool, r->connection->bucket_alloc);
     b = ap_bucket_eor_create(r->connection->bucket_alloc, r);
     APR_BRIGADE_INSERT_HEAD(bb, b);
-    
+
     ap_pass_brigade(r->connection->output_filters, bb);
-    
+
     /* From here onward, it is no longer safe to reference r
      * or r->pool, because r->pool may have been destroyed
      * already by the EOR bucket's cleanup function.
      */
-    
+
     c->cs->state = CONN_STATE_WRITE_COMPLETION;
     check_pipeline(c);
     AP_PROCESS_REQUEST_RETURN((uintptr_t)r, r->uri, r->status);

Modified: httpd/httpd/trunk/modules/ldap/util_ldap.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ldap/util_ldap.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ldap/util_ldap.c (original)
+++ httpd/httpd/trunk/modules/ldap/util_ldap.c Fri Sep 23 13:39:32 2011
@@ -44,7 +44,7 @@
 
 /* Default define for ldap functions that need a SIZELIMIT but
  * do not have the define
- * XXX This should be removed once a supporting #define is 
+ * XXX This should be removed once a supporting #define is
  *  released through APR-Util.
  */
 #ifndef APR_LDAP_SIZELIMIT
@@ -59,7 +59,7 @@
 #endif
 #endif
 
-#define AP_LDAP_HOPLIMIT_UNSET -1 
+#define AP_LDAP_HOPLIMIT_UNSET -1
 #define AP_LDAP_CHASEREFERRALS_OFF 0
 #define AP_LDAP_CHASEREFERRALS_ON 1
 
@@ -154,10 +154,10 @@ static void uldap_connection_close(util_
       * but always check/fix the binddn/bindpw when we take them out
       * of the pool
       */
-     if (!ldc->keep) { 
+     if (!ldc->keep) {
          uldap_connection_unbind(ldc);
      }
-     else { 
+     else {
          /* mark our connection as available for reuse */
          ldc->freed = apr_time_now();
 #if APR_HAS_THREADS
@@ -202,7 +202,7 @@ static apr_status_t uldap_connection_unb
  *
  * The caller should hold the lock for this connection
  */
-static apr_status_t util_ldap_connection_remove (void *param) { 
+static apr_status_t util_ldap_connection_remove (void *param) {
     util_ldap_connection_t *ldc = param, *l  = NULL, *prev = NULL;
     util_ldap_state_t *st;
 
@@ -220,9 +220,9 @@ static apr_status_t util_ldap_connection
     for (l=st->connections; l; l=l->next) {
         if (l == ldc) {
             if (prev) {
-                prev->next = l->next; 
+                prev->next = l->next;
             }
-            else { 
+            else {
                 st->connections = l->next;
             }
             break;
@@ -244,8 +244,8 @@ static apr_status_t util_ldap_connection
 
     /* Destory the pool associated with this connection */
 
-    apr_pool_destroy(ldc->pool);   
-   
+    apr_pool_destroy(ldc->pool);
+
     return APR_SUCCESS;
 }
 #endif
@@ -257,7 +257,7 @@ static int uldap_connection_init(request
     int version  = LDAP_VERSION3;
     apr_ldap_err_t *result = NULL;
 #ifdef LDAP_OPT_NETWORK_TIMEOUT
-    struct timeval connectionTimeout = {0}; 
+    struct timeval connectionTimeout = {0};
 #endif
     util_ldap_state_t *st =
         (util_ldap_state_t *)ap_get_module_config(r->server->module_config,
@@ -343,7 +343,7 @@ static int uldap_connection_init(request
     ldap_option = ldc->deref;
     ldap_set_option(ldc->ldap, LDAP_OPT_DEREF, &ldap_option);
 
-    if (ldc->ChaseReferrals == AP_LDAP_CHASEREFERRALS_ON) { 
+    if (ldc->ChaseReferrals == AP_LDAP_CHASEREFERRALS_ON) {
         /* Set options for rebind and referrals. */
         ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                 "LDAP: Setting referrals to %s.",
@@ -449,8 +449,8 @@ static int uldap_connection_init(request
     return(rc);
 }
 
-static int uldap_ld_errno(util_ldap_connection_t *ldc) 
-{ 
+static int uldap_ld_errno(util_ldap_connection_t *ldc)
+{
     int ldaprc;
 #ifdef LDAP_OPT_ERROR_NUMBER
     if (LDAP_SUCCESS == ldap_get_option(ldc->ldap, LDAP_OPT_ERROR_NUMBER, &ldaprc)) return ldaprc;
@@ -463,7 +463,7 @@ static int uldap_ld_errno(util_ldap_conn
 
 /*
  * Replacement function for ldap_simple_bind_s() with a timeout.
- * To do this in a portable way, we have to use ldap_simple_bind() and 
+ * To do this in a portable way, we have to use ldap_simple_bind() and
  * ldap_result().
  *
  * Returns LDAP_SUCCESS on success; and an error code on failure
@@ -551,7 +551,7 @@ static int uldap_connection_open(request
      */
 
     while (failures <= st->retries) {
-        if (failures > 0 && st->retry_delay > 0) { 
+        if (failures > 0 && st->retry_delay > 0) {
             apr_sleep(st->retry_delay);
         }
         rc = uldap_simple_bind(ldc, (char *)ldc->binddn, (char *)ldc->bindpw,
@@ -561,7 +561,7 @@ static int uldap_connection_open(request
 
         failures++;
 
-        if (AP_LDAP_IS_SERVER_DOWN(rc)) { 
+        if (AP_LDAP_IS_SERVER_DOWN(rc)) {
              ap_log_rerror(APLOG_MARK, APLOG_TRACE2, 0, r,
                           "ldap_simple_bind() failed with server down "
                           "(try %d)", failures);
@@ -569,24 +569,24 @@ static int uldap_connection_open(request
         else if (rc == LDAP_TIMEOUT) {
             ap_log_rerror(APLOG_MARK, APLOG_INFO, 0, r,
                           "ldap_simple_bind() timed out on %s "
-                          "connection, dropped by firewall?", 
+                          "connection, dropped by firewall?",
                           new_connection ? "new" : "reused");
         }
-        else { 
+        else {
             /* Other errors not retryable */
             break;
         }
 
         if (!(failures % 2)) {
-            ap_log_rerror(APLOG_MARK, APLOG_TRACE2, 0, r, 
+            ap_log_rerror(APLOG_MARK, APLOG_TRACE2, 0, r,
                           "attempt to re-init the connection");
             uldap_connection_unbind(ldc);
-            if (LDAP_SUCCESS != uldap_connection_init(r, ldc)) { 
+            if (LDAP_SUCCESS != uldap_connection_init(r, ldc)) {
                 /* leave rc as the initial bind return code */
                 break;
             }
         }
-    } 
+    }
 
     /* free the handle if there was an error
     */
@@ -693,10 +693,10 @@ static util_ldap_connection_t *
             && (l->deref == deref) && (l->secure == secureflag)
             && !compare_client_certs(dc->client_certs, l->client_certs))
         {
-            if (st->connection_pool_ttl > 0) { 
-                if (l->bound && (now - l->freed) > st->connection_pool_ttl) { 
-                    ap_log_rerror(APLOG_MARK, APLOG_TRACE1, 0, r, 
-                                  "Removing LDAP connection last used %" APR_TIME_T_FMT " seconds ago", 
+            if (st->connection_pool_ttl > 0) {
+                if (l->bound && (now - l->freed) > st->connection_pool_ttl) {
+                    ap_log_rerror(APLOG_MARK, APLOG_TRACE1, 0, r,
+                                  "Removing LDAP connection last used %" APR_TIME_T_FMT " seconds ago",
                                   (now - l->freed) / APR_USEC_PER_SEC);
                     uldap_connection_unbind(l);
                     /* Go ahead (by falling through) and use it, so we don't create more just to unbind some other old ones */
@@ -730,7 +730,7 @@ static util_ldap_connection_t *
                 /* the bind credentials have changed */
                 /* no check for connection_pool_ttl, since we are unbinding any way */
                 uldap_connection_unbind(l);
-                        
+
                 util_ldap_strdup((char**)&(l->binddn), binddn);
                 util_ldap_strdup((char**)&(l->bindpw), bindpw);
                 break;
@@ -762,7 +762,7 @@ static util_ldap_connection_t *
 #endif
             return NULL;
         }
- 
+
         /*
          * Add the new connection entry to the linked list. Note that we
          * don't actually establish an LDAP connection yet; that happens
@@ -800,7 +800,7 @@ static util_ldap_connection_t *
         /* whether or not to keep this connection in the pool when it's returned */
         l->keep = (st->connection_pool_ttl == 0) ? 0 : 1;
 
-        if (l->ChaseReferrals == AP_LDAP_CHASEREFERRALS_ON) { 
+        if (l->ChaseReferrals == AP_LDAP_CHASEREFERRALS_ON) {
             if (apr_pool_create(&(l->rebind_pool), l->pool) != APR_SUCCESS) {
                 ap_log_rerror(APLOG_MARK, APLOG_CRIT, 0, r,
                               "util_ldap: Failed to create memory pool");
@@ -1070,7 +1070,7 @@ start_over:
                             (char *)dn,
                             (char *)attrib,
                             (char *)value);
-    if (AP_LDAP_IS_SERVER_DOWN(result)) { 
+    if (AP_LDAP_IS_SERVER_DOWN(result)) {
         /* connection failed - try again */
         ldc->reason = "ldap_compare_s() failed with server down";
         uldap_connection_unbind(ldc);
@@ -2530,7 +2530,7 @@ static const char *util_ldap_set_chase_r
 
 static const char *util_ldap_set_debug_level(cmd_parms *cmd,
                                              void *config,
-                                             const char *arg) { 
+                                             const char *arg) {
 #ifdef AP_LDAP_OPT_DEBUG
     util_ldap_state_t *st =
         (util_ldap_state_t *)ap_get_module_config(cmd->server->module_config,
@@ -2548,7 +2548,7 @@ static const char *util_ldap_set_debug_l
     st->debug_level = atoi(arg);
     return NULL;
 #endif
-} 
+}
 
 static const char *util_ldap_set_referral_hop_limit(cmd_parms *cmd,
                                                     void *config,
@@ -2558,7 +2558,7 @@ static const char *util_ldap_set_referra
 
     dc->ReferralHopLimit = atol(hop_limit);
 
-    if (dc->ReferralHopLimit <= 0) { 
+    if (dc->ReferralHopLimit <= 0) {
         return "LDAPReferralHopLimit must be greater than zero (Use 'LDAPReferrals Off' to disable referral chasing)";
     }
 
@@ -2638,11 +2638,11 @@ static const char *util_ldap_set_conn_tt
         (util_ldap_state_t *)ap_get_module_config(cmd->server->module_config,
                                                   &ldap_module);
 
-    if (ap_timeout_parameter_parse(val, &timeout, "s") != APR_SUCCESS) { 
+    if (ap_timeout_parameter_parse(val, &timeout, "s") != APR_SUCCESS) {
         return "LDAPConnPoolTTL has wrong format";
     }
 
-    if (timeout < 0) { 
+    if (timeout < 0) {
         /* reserve -1 for default value */
         timeout =  AP_LDAP_CONNPOOL_INFINITE;
     }
@@ -2663,11 +2663,11 @@ static const char *util_ldap_set_retry_d
         return err;
     }
 
-    if (ap_timeout_parameter_parse(val, &timeout, "s") != APR_SUCCESS) { 
+    if (ap_timeout_parameter_parse(val, &timeout, "s") != APR_SUCCESS) {
         return "LDAPRetryDelay has wrong format";
     }
 
-    if (timeout < 0) { 
+    if (timeout < 0) {
         return "LDAPRetryDelay must be >= 0";
     }
 
@@ -2689,11 +2689,11 @@ static const char *util_ldap_set_retries
     }
 
     st->retries = atoi(val);
-    if (st->retries < 0) { 
+    if (st->retries < 0) {
         return  "LDAPRetries must be >= 0";
     }
 
-    return NULL; 
+    return NULL;
 }
 
 static void *util_ldap_create_config(apr_pool_t *p, server_rec *s)
@@ -2701,7 +2701,7 @@ static void *util_ldap_create_config(apr
     util_ldap_state_t *st =
         (util_ldap_state_t *)apr_pcalloc(p, sizeof(util_ldap_state_t));
 
-    /* Create a per vhost pool for mod_ldap to use, serialized with 
+    /* Create a per vhost pool for mod_ldap to use, serialized with
      * st->mutex (also one per vhost).  both are replicated by fork(),
      * no shared memory managed by either.
      */
@@ -2746,7 +2746,7 @@ static void *util_ldap_merge_config(apr_
     st->mutex = overrides->mutex;
 #endif
 
-    /* The cache settings can not be modified in a 
+    /* The cache settings can not be modified in a
         virtual host since all server use the same
         shared memory cache. */
     st->cache_bytes = base->cache_bytes;
@@ -2754,7 +2754,7 @@ static void *util_ldap_merge_config(apr_
     st->search_cache_size = base->search_cache_size;
     st->compare_cache_ttl = base->compare_cache_ttl;
     st->compare_cache_size = base->compare_cache_size;
-    st->util_ldap_cache_lock = base->util_ldap_cache_lock; 
+    st->util_ldap_cache_lock = base->util_ldap_cache_lock;
 
     st->connections = NULL;
     st->ssl_supported = 0; /* not known until post-config and re-merged */
@@ -2763,22 +2763,22 @@ static void *util_ldap_merge_config(apr_
     st->secure = (overrides->secure_set == 0) ? base->secure
                                               : overrides->secure;
 
-    /* These LDAP connection settings can not be overwritten in 
-        a virtual host. Once set in the base server, they must 
+    /* These LDAP connection settings can not be overwritten in
+        a virtual host. Once set in the base server, they must
         remain the same. None of the LDAP SDKs seem to be able
-        to handle setting the verify_svr_cert flag on a 
+        to handle setting the verify_svr_cert flag on a
         per-connection basis.  The OpenLDAP client appears to be
         able to handle the connection timeout per-connection
         but the Novell SDK cannot.  Allowing the timeout to
         be set by each vhost is of little value so rather than
-        trying to make special expections for one LDAP SDK, GLOBAL_ONLY 
+        trying to make special expections for one LDAP SDK, GLOBAL_ONLY
         is being enforced on this setting as well. */
     st->connectionTimeout = base->connectionTimeout;
     st->opTimeout = base->opTimeout;
     st->verify_svr_cert = base->verify_svr_cert;
     st->debug_level = base->debug_level;
 
-    st->connection_pool_ttl = (overrides->connection_pool_ttl == AP_LDAP_CONNPOOL_DEFAULT) ? 
+    st->connection_pool_ttl = (overrides->connection_pool_ttl == AP_LDAP_CONNPOOL_DEFAULT) ?
                                 base->connection_pool_ttl : overrides->connection_pool_ttl;
 
     st->retries = base->retries;
@@ -2953,11 +2953,11 @@ static int util_ldap_post_config(apr_poo
     apr_ldap_rebind_init (p);
 
 #ifdef AP_LDAP_OPT_DEBUG
-    if (st->debug_level > 0) { 
+    if (st->debug_level > 0) {
         result = ldap_set_option(NULL, AP_LDAP_OPT_DEBUG, &st->debug_level);
         if (result != LDAP_SUCCESS) {
             ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
-                    "LDAP: Could not set the LDAP library debug level to %d:(%d) %s", 
+                    "LDAP: Could not set the LDAP library debug level to %d:(%d) %s",
                     st->debug_level, result, ldap_err2string(result));
         }
     }
@@ -2996,9 +2996,9 @@ static const command_rec util_ldap_cmds[
     AP_INIT_TAKE1("LDAPCacheEntries", util_ldap_set_cache_entries,
                   NULL, RSRC_CONF,
                   "Set the maximum number of entries that are possible in the "
-                  "LDAP search cache. Use 0 or -1 to disable the search cache " 
+                  "LDAP search cache. Use 0 or -1 to disable the search cache "
                   "(default: 1024)"),
-                  
+
     AP_INIT_TAKE1("LDAPCacheTTL", util_ldap_set_cache_ttl,
                   NULL, RSRC_CONF,
                   "Set the maximum time (in seconds) that an item can be "
@@ -3008,7 +3008,7 @@ static const command_rec util_ldap_cmds[
     AP_INIT_TAKE1("LDAPOpCacheEntries", util_ldap_set_opcache_entries,
                   NULL, RSRC_CONF,
                   "Set the maximum number of entries that are possible "
-                  "in the LDAP compare cache. Use 0 or -1 to disable the compare cache " 
+                  "in the LDAP compare cache. Use 0 or -1 to disable the compare cache "
                   "(default: 1024)"),
 
     AP_INIT_TAKE1("LDAPOpCacheTTL", util_ldap_set_opcache_ttl,

Modified: httpd/httpd/trunk/modules/loggers/mod_log_config.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/loggers/mod_log_config.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/loggers/mod_log_config.c (original)
+++ httpd/httpd/trunk/modules/loggers/mod_log_config.c Fri Sep 23 13:39:32 2011
@@ -1082,7 +1082,7 @@ static int config_log_transaction(reques
     else if (cls->condition_expr != NULL) {
         const char *err;
         int rc = ap_expr_exec(r, cls->condition_expr, &err);
-        if (rc < 0) 
+        if (rc < 0)
             ap_log_rerror(APLOG_MARK, APLOG_WARNING, 0, r,
                            "Error evaluating log condition: %s", err);
         if (rc <= 0)

Modified: httpd/httpd/trunk/modules/loggers/mod_log_forensic.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/loggers/mod_log_forensic.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/loggers/mod_log_forensic.c (original)
+++ httpd/httpd/trunk/modules/loggers/mod_log_forensic.c Fri Sep 23 13:39:32 2011
@@ -195,7 +195,7 @@ static int log_before(request_rec *r)
     if (!(id = apr_table_get(r->subprocess_env, "UNIQUE_ID"))) {
         /* we make the assumption that we can't go through all the PIDs in
            under 1 second */
-        id = apr_psprintf(r->pool, "%" APR_PID_T_FMT ":%lx:%x", getpid(), 
+        id = apr_psprintf(r->pool, "%" APR_PID_T_FMT ":%lx:%x", getpid(),
                           time(NULL), apr_atomic_inc32(&next_id));
     }
     ap_set_module_config(r->request_config, &log_forensic_module, (char *)id);

Modified: httpd/httpd/trunk/modules/lua/lua_request.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/lua/lua_request.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/lua/lua_request.c (original)
+++ httpd/httpd/trunk/modules/lua/lua_request.c Fri Sep 23 13:39:32 2011
@@ -342,7 +342,7 @@ static int req_dispatch(lua_State *L)
                               "request_rec->dispatching %s -> apr table",
                               name);
                 rs = (*func)(r);
-                ap_lua_push_apr_table(L, rs);          
+                ap_lua_push_apr_table(L, rs);
                 return 1;
             }
 
@@ -594,7 +594,7 @@ AP_LUA_DECLARE(void) ap_lua_load_request
                  makefun(&req_notes, APL_REQ_FUNTYPE_TABLE, p));
     apr_hash_set(dispatch, "subprocess_env", APR_HASH_KEY_STRING,
                  makefun(&req_subprocess_env, APL_REQ_FUNTYPE_TABLE, p));
-    
+
 
     lua_pushlightuserdata(L, dispatch);
     lua_setfield(L, LUA_REGISTRYINDEX, "Apache2.Request.dispatch");

Modified: httpd/httpd/trunk/modules/lua/lua_vmprep.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/lua/lua_vmprep.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/lua/lua_vmprep.c (original)
+++ httpd/httpd/trunk/modules/lua/lua_vmprep.c Fri Sep 23 13:39:32 2011
@@ -238,7 +238,7 @@ static void munge_path(lua_State *L,
                        const char *sub_pat,
                        const char *rep_pat,
                        apr_pool_t *pool,
-                       apr_array_header_t *paths, 
+                       apr_array_header_t *paths,
                        const char *file)
 {
     const char *current;
@@ -287,7 +287,7 @@ static int loadjitmodule(lua_State *L, a
 static apr_status_t vm_construct(void **vm, void *params, apr_pool_t *lifecycle_pool)
 {
     lua_State* L;
-    
+
     ap_lua_vm_spec *spec = params;
 
     L = luaL_newstate();
@@ -321,17 +321,17 @@ static apr_status_t vm_construct(void **
         if (rc != 0) {
             char *err;
             switch (rc) {
-                case LUA_ERRSYNTAX: 
-                    err = "syntax error"; 
+                case LUA_ERRSYNTAX:
+                    err = "syntax error";
                     break;
-                case LUA_ERRMEM:    
-                    err = "memory allocation error"; 
+                case LUA_ERRMEM:
+                    err = "memory allocation error";
                     break;
-                case LUA_ERRFILE:   
-                    err = "error opening or reading file"; 
+                case LUA_ERRFILE:
+                    err = "error opening or reading file";
                     break;
                 default:
-                    err = "unknown error"; 
+                    err = "unknown error";
                     break;
             }
             ap_log_perror(APLOG_MARK, APLOG_ERR, 0, lifecycle_pool,
@@ -354,7 +354,7 @@ static apr_status_t vm_construct(void **
 
 static apr_status_t vm_destruct(void *vm, void *params, apr_pool_t *pool)
 {
-    lua_State *L = (lua_State *)vm; 
+    lua_State *L = (lua_State *)vm;
 
     (void)params;
     (void)pool;
@@ -390,8 +390,8 @@ AP_LUA_DECLARE(lua_State*)ap_lua_get_lua
         if (apr_pool_userdata_get((void **)&reslist,
                                   "mod_lua", spec->pool) == APR_SUCCESS) {
             if(reslist==NULL) {
-                if(apr_reslist_create(&reslist, 
-                                      spec->vm_server_pool_min, 
+                if(apr_reslist_create(&reslist,
+                                      spec->vm_server_pool_min,
                                       spec->vm_server_pool_max,
                                       spec->vm_server_pool_max,
                                       0,

Modified: httpd/httpd/trunk/modules/lua/mod_lua.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/lua/mod_lua.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/lua/mod_lua.c (original)
+++ httpd/httpd/trunk/modules/lua/mod_lua.c Fri Sep 23 13:39:32 2011
@@ -34,7 +34,7 @@ APR_IMPLEMENT_OPTIONAL_HOOK_RUN_ALL(ap_l
      module AP_MODULE_DECLARE_DATA lua_module;
 
 /**
- * error reporting if lua has an error. 
+ * error reporting if lua has an error.
  * Extracts the error from lua stack and prints
  */
 static void report_lua_error(lua_State *L, request_rec *r)
@@ -73,7 +73,7 @@ static apr_status_t luahood(ap_filter_t 
     apr_status_t rs;
     for ( b = APR_BRIGADE_FIRST(bb);
           b != APR_BRIGADE_SENTINEL(bb);
-          b = APR_BUCKET_NEXT(b)) 
+          b = APR_BUCKET_NEXT(b))
     {
         if (APR_BUCKET_IS_EOS(b)) {kl
             break;
@@ -87,9 +87,9 @@ static apr_status_t luahood(ap_filter_t 
         char *mine = apr_pstrmemdup(f->r->pool, buffer, bytes);
         ap_log_rerror(APLOG_MARK, APLOG_DEBUG, 0, f->r, "sending '%s'", mine);
     }
-    
+
     ap_pass_brigade(f->next, bb);
-    
+
     return OK;
 }
 */
@@ -169,7 +169,7 @@ static int lua_handler(request_rec *r)
 
 
 /**
- * Like mod_alias except for lua handler fun :-) 
+ * Like mod_alias except for lua handler fun :-)
  */
 static int lua_alias_munger(request_rec *r)
 {
@@ -356,7 +356,7 @@ typedef struct cr_ctx
 
 /* Okay, this deserves a little explaination -- in order for the errors that lua
  * generates to be 'accuarate', including line numbers, we basically inject
- * N line number new lines into the 'top' of the chunk reader..... 
+ * N line number new lines into the 'top' of the chunk reader.....
  *
  * be happy. this is cool.
  *
@@ -788,7 +788,7 @@ static const char *register_package_cdir
 
 /**
  * Called for config directive which looks like
- * LuaCodeCache 
+ * LuaCodeCache
  */
 static const char *register_code_cache(cmd_parms *cmd, void *_cfg,
                                        const char *arg)

Modified: httpd/httpd/trunk/modules/mappers/mod_dir.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/mappers/mod_dir.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/mappers/mod_dir.c (original)
+++ httpd/httpd/trunk/modules/mappers/mod_dir.c Fri Sep 23 13:39:32 2011
@@ -90,9 +90,9 @@ static const char *configure_redirect(cm
     dir_config_rec *d = d_;
     int status;
 
-    if (!strcasecmp(arg1, "ON")) 
+    if (!strcasecmp(arg1, "ON"))
         status = HTTP_MOVED_TEMPORARILY;
-    else if (!strcasecmp(arg1, "OFF")) 
+    else if (!strcasecmp(arg1, "OFF"))
         status = REDIRECT_OFF;
     else if (!strcasecmp(arg1, "permanent"))
         status = HTTP_MOVED_PERMANENTLY;
@@ -100,13 +100,13 @@ static const char *configure_redirect(cm
         status = HTTP_MOVED_TEMPORARILY;
     else if (!strcasecmp(arg1, "seeother"))
         status = HTTP_SEE_OTHER;
-    else if (apr_isdigit(*arg1)) { 
+    else if (apr_isdigit(*arg1)) {
         status = atoi(arg1);
-        if (!ap_is_HTTP_REDIRECT(status)) { 
+        if (!ap_is_HTTP_REDIRECT(status)) {
             return "DirectoryIndexRedirect only accepts values between 300 and 399";
         }
     }
-    else { 
+    else {
         return "DirectoryIndexRedirect ON|OFF|permanent|temp|seeother|3xx";
     }
 
@@ -122,7 +122,7 @@ static const command_rec dir_cmds[] =
                     "a list of file names"),
     AP_INIT_FLAG("DirectorySlash", configure_slash, NULL, DIR_CMD_PERMS,
                  "On or Off"),
-    AP_INIT_TAKE1("DirectoryIndexRedirect", configure_redirect, 
+    AP_INIT_TAKE1("DirectoryIndexRedirect", configure_redirect,
                    NULL, DIR_CMD_PERMS, "On, Off, or a 3xx status code."),
 
     {NULL}
@@ -299,8 +299,8 @@ static int fixup_dir(request_rec *r)
         if (rr->status == HTTP_OK
             && (   (rr->handler && !strcmp(rr->handler, "proxy-server"))
                 || rr->finfo.filetype == APR_REG)) {
-  
-            if (ap_is_HTTP_REDIRECT(d->redirect_index)) { 
+
+            if (ap_is_HTTP_REDIRECT(d->redirect_index)) {
                 apr_table_setn(r->headers_out, "Location", ap_construct_url(r->pool, rr->uri, r));
                 return d->redirect_index;
             }
@@ -347,9 +347,9 @@ static int fixup_dir(request_rec *r)
     }
 
     /* record what we tried, mostly for the benefit of mod_autoindex */
-    apr_table_set(r->notes, "dir-index-names", 
-                  d->index_names ? 
-                  apr_array_pstrcat(r->pool, d->index_names, ','): 
+    apr_table_set(r->notes, "dir-index-names",
+                  d->index_names ?
+                  apr_array_pstrcat(r->pool, d->index_names, ','):
                   AP_DEFAULT_INDEX);
 
     /* nothing for us to do, pass on through */

Modified: httpd/httpd/trunk/modules/mappers/mod_imagemap.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/mappers/mod_imagemap.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/mappers/mod_imagemap.c (original)
+++ httpd/httpd/trunk/modules/mappers/mod_imagemap.c Fri Sep 23 13:39:32 2011
@@ -477,12 +477,12 @@ static void menu_header(request_rec *r, 
 {
     ap_set_content_type(r, "text/html; charset=ISO-8859-1");
 
-    ap_rvputs(r, DOCTYPE_HTML_3_2, "<html><head>\n<title>Menu for ", 
+    ap_rvputs(r, DOCTYPE_HTML_3_2, "<html><head>\n<title>Menu for ",
               ap_escape_html(r->pool, r->uri),
               "</title>\n</head><body>\n", NULL);
 
     if (!strcasecmp(menu, "formatted")) {
-        ap_rvputs(r, "<h1>Menu for ", 
+        ap_rvputs(r, "<h1>Menu for ",
                   ap_escape_html(r->pool, r->uri),
                   "</h1>\n<hr />\n\n", NULL);
     }

Modified: httpd/httpd/trunk/modules/mappers/mod_rewrite.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/mappers/mod_rewrite.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/mappers/mod_rewrite.c (original)
+++ httpd/httpd/trunk/modules/mappers/mod_rewrite.c Fri Sep 23 13:39:32 2011
@@ -1663,7 +1663,7 @@ static char *lookup_map(request_rec *r, 
         rewritelog((r, 5, NULL, "cache lookup OK: map=%s[SQL] key=%s, val=%s",
                     name, key, value));
         return *value ? value : NULL;
-        
+
     /*
      * Program file map
      */
@@ -2336,7 +2336,7 @@ static char *do_expand(char *input, rewr
                     current->len = span;
                     current->string = bri->source + bri->regmatch[n].rm_so;
                 }
-                
+
                 outlen += span;
             }
 
@@ -2751,7 +2751,7 @@ static void *config_server_merge(apr_poo
                                               overrides->rewritemaps);
         a->rewriteconds    = apr_array_append(p, base->rewriteconds,
                                               overrides->rewriteconds);
-        a->rewriterules    = apr_array_append(p, base->rewriterules, 
+        a->rewriterules    = apr_array_append(p, base->rewriterules,
                                               overrides->rewriterules);
     }
     else {
@@ -3331,7 +3331,7 @@ static const char *cmd_rewriterule_setfl
     case 'B':
         if (!*key || !strcasecmp(key, "ackrefescaping")) {
             cfg->flags |= RULEFLAG_ESCAPEBACKREF;
-        } 
+        }
         else {
             ++error;
         }
@@ -3365,9 +3365,9 @@ static const char *cmd_rewriterule_setfl
         break;
     case 'd':
     case 'D':
-        if (!*key || !strcasecmp(key, "PI") || !strcasecmp(key,"iscardpath")) {       
+        if (!*key || !strcasecmp(key, "PI") || !strcasecmp(key,"iscardpath")) {
             cfg->flags |= (RULEFLAG_DISCARDPATHINFO);
-        } 
+        }
         break;
     case 'e':
     case 'E':
@@ -4031,7 +4031,7 @@ static int apply_rewrite_rule(rewriterul
     r->filename = newuri;
 
     if (ctx->perdir && (p->flags & RULEFLAG_DISCARDPATHINFO)) {
-        r->path_info = NULL; 
+        r->path_info = NULL;
     }
 
     splitout_queryargs(r, p->flags & RULEFLAG_QSAPPEND, p->flags & RULEFLAG_QSDISCARD);
@@ -4064,12 +4064,12 @@ static int apply_rewrite_rule(rewriterul
          * instead.  See PR 39746, 46428, and other headaches. */
         if (ctx->perdir && (p->flags & RULEFLAG_NOESCAPE) == 0) {
             char *old_filename = r->filename;
-            
+
             r->filename = ap_escape_uri(r->pool, r->filename);
             rewritelog((r, 2, ctx->perdir, "escaped URI in per-dir context "
                         "for proxy, %s -> %s", old_filename, r->filename));
         }
-        
+
         fully_qualify_uri(r);
 
         rewritelog((r, 2, ctx->perdir, "forcing proxy-throughput with %s",
@@ -4209,7 +4209,7 @@ static int apply_rewrite_list(request_re
                 break;
             }
 
-            if (p->flags & RULEFLAG_END) { 
+            if (p->flags & RULEFLAG_END) {
                 rewritelog((r, 8, perdir, "Rule has END flag, no further rewriting for this request"));
                 apr_pool_userdata_set("1", really_last_key, apr_pool_cleanup_null, r->pool);
                 break;
@@ -4397,9 +4397,9 @@ static int hook_uri2file(request_rec *r)
         return DECLINED;
     }
 
-    /* END flag was used as a RewriteRule flag on this request */ 
+    /* END flag was used as a RewriteRule flag on this request */
     apr_pool_userdata_get(&skipdata, really_last_key, r->pool);
-    if (skipdata != NULL) { 
+    if (skipdata != NULL) {
         rewritelog((r, 8, NULL, "Declining, no further rewriting due to END flag"));
         return DECLINED;
     }
@@ -4698,9 +4698,9 @@ static int hook_fixup(request_rec *r)
         }
     }
 
-    /* END flag was used as a RewriteRule flag on this request */ 
+    /* END flag was used as a RewriteRule flag on this request */
     apr_pool_userdata_get(&skipdata, really_last_key, r->pool);
-    if (skipdata != NULL) { 
+    if (skipdata != NULL) {
         rewritelog((r, 8, dconf->directory, "Declining, no further rewriting due to END flag"));
         return DECLINED;
     }
@@ -4833,18 +4833,18 @@ static int hook_fixup(request_rec *r)
             /* append the QUERY_STRING part */
             if (r->args) {
                 char *escaped_args = NULL;
-                int noescape = (rulestatus == ACTION_NOESCAPE || 
+                int noescape = (rulestatus == ACTION_NOESCAPE ||
                                 (oargs && !strcmp(r->args, oargs)));
-                             
+
                 r->filename = apr_pstrcat(r->pool, r->filename, "?",
-                                          noescape 
+                                          noescape
                                             ? r->args
                                             : (escaped_args = ap_escape_uri(r->pool, r->args)),
                                           NULL);
 
                 rewritelog((r, 1, dconf->directory, "%s %s to query string for redirect %s",
-                            noescape ? "copying" : "escaping",  
-                            r->args , 
+                            noescape ? "copying" : "escaping",
+                            r->args ,
                             noescape ? "" : escaped_args));
             }
 

Modified: httpd/httpd/trunk/modules/mappers/mod_speling.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/mappers/mod_speling.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/mappers/mod_speling.c (original)
+++ httpd/httpd/trunk/modules/mappers/mod_speling.c Fri Sep 23 13:39:32 2011
@@ -107,7 +107,7 @@ static const command_rec speling_cmds[] 
                   (void*)APR_OFFSETOF(spconfig, enabled), OR_OPTIONS,
                  "whether or not to fix miscapitalized/misspelled requests"),
     AP_INIT_FLAG("CheckCaseOnly", ap_set_flag_slot,
-                  (void*)APR_OFFSETOF(spconfig, case_only), OR_OPTIONS, 
+                  (void*)APR_OFFSETOF(spconfig, case_only), OR_OPTIONS,
                  "whether or not to fix only miscapitalized requests"),
     { NULL }
 };

Modified: httpd/httpd/trunk/modules/mappers/mod_userdir.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/mappers/mod_userdir.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/mappers/mod_userdir.c (original)
+++ httpd/httpd/trunk/modules/mappers/mod_userdir.c Fri Sep 23 13:39:32 2011
@@ -116,17 +116,17 @@ static void *merge_userdir_config(apr_po
 {
     userdir_config *cfg = apr_pcalloc(p, sizeof(userdir_config));
     userdir_config *base = basev, *overrides = overridesv;
- 
+
     cfg->globally_disabled = (overrides->globally_disabled != O_DEFAULT) ?
                              overrides->globally_disabled :
                              base->globally_disabled;
     cfg->userdir = (overrides->userdir != DEFAULT_USER_DIR) ?
                    overrides->userdir : base->userdir;
- 
+
     /* not merged */
     cfg->enabled_users = overrides->enabled_users;
     cfg->disabled_users = overrides->disabled_users;
-    
+
     return cfg;
 }
 

Modified: httpd/httpd/trunk/modules/metadata/mod_remoteip.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/metadata/mod_remoteip.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/metadata/mod_remoteip.c (original)
+++ httpd/httpd/trunk/modules/metadata/mod_remoteip.c Fri Sep 23 13:39:32 2011
@@ -39,9 +39,9 @@ typedef struct {
 typedef struct {
     /** The header to retrieve a proxy-via ip list */
     const char *header_name;
-    /** A header to record the proxied IP's 
-     * (removed as the physical connection and 
-     * from the proxy-via ip header value list) 
+    /** A header to record the proxied IP's
+     * (removed as the physical connection and
+     * from the proxy-via ip header value list)
      */
     const char *proxies_header_name;
     /** A list of trusted proxies, ideally configured
@@ -153,8 +153,8 @@ static const char *proxies_set(cmd_parms
         apr_sockaddr_t *temp_sa;
 
         if (s) {
-            return apr_pstrcat(cmd->pool, "RemoteIP: Error parsing IP ", arg, 
-                               " the subnet /", s, " is invalid for ", 
+            return apr_pstrcat(cmd->pool, "RemoteIP: Error parsing IP ", arg,
+                               " the subnet /", s, " is invalid for ",
                                cmd->cmd->name, NULL);
         }
 
@@ -166,7 +166,7 @@ static const char *proxies_set(cmd_parms
             rv = apr_ipsubnet_create(&match->ip, ip, NULL, cmd->pool);
             if (!(temp_sa = temp_sa->next))
                 break;
-            match = (remoteip_proxymatch_t *) 
+            match = (remoteip_proxymatch_t *)
                     apr_array_push(config->proxymatch_ip);
             match->internal = internal;
         }
@@ -175,7 +175,7 @@ static const char *proxies_set(cmd_parms
     if (rv != APR_SUCCESS) {
         char msgbuf[128];
         apr_strerror(rv, msgbuf, sizeof(msgbuf));
-        return apr_pstrcat(cmd->pool, "RemoteIP: Error parsing IP ", arg, 
+        return apr_pstrcat(cmd->pool, "RemoteIP: Error parsing IP ", arg,
                            " (", msgbuf, " error) for ", cmd->cmd->name, NULL);
     }
 
@@ -196,7 +196,7 @@ static const char *proxylist_read(cmd_pa
     rv = ap_pcfg_openfile(&cfp, cmd->temp_pool, filename);
     if (rv != APR_SUCCESS) {
         return apr_psprintf(cmd->pool, "%s: Could not open file %s: %s",
-                            cmd->cmd->name, filename, 
+                            cmd->cmd->name, filename,
                             apr_strerror(rv, lbuf, sizeof(lbuf)));
     }
 
@@ -207,7 +207,7 @@ static const char *proxylist_read(cmd_pa
                 break;
             errmsg = proxies_set(cmd, internal, arg);
             if (errmsg) {
-                errmsg = apr_psprintf(cmd->pool, "%s at line %d of %s", 
+                errmsg = apr_psprintf(cmd->pool, "%s at line %d of %s",
                                       errmsg, cfp->line_number, filename);
                 return errmsg;
             }
@@ -292,7 +292,7 @@ static int remoteip_modify_connection(re
             *(parse_remote++) = '\0';
         }
 
-        while (*parse_remote == ' ') 
+        while (*parse_remote == ' ')
             ++parse_remote;
 
         eos = parse_remote + strlen(parse_remote) - 1;
@@ -309,12 +309,12 @@ static int remoteip_modify_connection(re
 
 #ifdef REMOTEIP_OPTIMIZED
         /* Decode remote_addr - sucks; apr_sockaddr_vars_set isn't 'public' */
-        if (inet_pton(AF_INET, parse_remote, 
+        if (inet_pton(AF_INET, parse_remote,
                       &temp_sa->sa.sin.sin_addr) > 0) {
             apr_sockaddr_vars_set(temp_sa, APR_INET, temp_sa.port);
         }
 #if APR_HAVE_IPV6
-        else if (inet_pton(AF_INET6, parse_remote, 
+        else if (inet_pton(AF_INET6, parse_remote,
                            &temp_sa->sa.sin6.sin6_addr) > 0) {
             apr_sockaddr_vars_set(temp_sa, APR_INET6, temp_sa.port);
         }
@@ -323,9 +323,9 @@ static int remoteip_modify_connection(re
             rv = apr_get_netos_error();
 #else /* !REMOTEIP_OPTIMIZED */
         /* We map as IPv4 rather than IPv6 for equivilant host names
-         * or IPV4OVERIPV6 
+         * or IPV4OVERIPV6
          */
-        rv = apr_sockaddr_info_get(&temp_sa,  parse_remote, 
+        rv = apr_sockaddr_info_get(&temp_sa,  parse_remote,
                                    APR_UNSPEC, temp_sa->port,
                                    APR_IPV4_ADDR_OK, r->pool);
         if (rv != APR_SUCCESS) {
@@ -348,7 +348,7 @@ static int remoteip_modify_connection(re
               && ((temp_sa->family == APR_INET
                    /* For internet (non-Internal proxies) deny all
                     * RFC3330 designated local/private subnets:
-                    * 10.0.0.0/8   169.254.0.0/16  192.168.0.0/16 
+                    * 10.0.0.0/8   169.254.0.0/16  192.168.0.0/16
                     * 127.0.0.0/8  172.16.0.0/12
                     */
                       && (addrbyte[0] == 10
@@ -358,7 +358,7 @@ static int remoteip_modify_connection(re
                        || (addrbyte[0] == 192 && addrbyte[1] == 168)))
 #if APR_HAVE_IPV6
                || (temp_sa->family == APR_INET6
-                   /* For internet (non-Internal proxies) we translated 
+                   /* For internet (non-Internal proxies) we translated
                     * IPv4-over-IPv6-mapped addresses as IPv4, above.
                     * Accept only Global Unicast 2000::/3 defined by RFC4291
                     */
@@ -386,7 +386,7 @@ static int remoteip_modify_connection(re
         /* Set remote_ip string */
         if (!internal) {
             if (proxy_ips)
-                proxy_ips = apr_pstrcat(r->pool, proxy_ips, ", ", 
+                proxy_ips = apr_pstrcat(r->pool, proxy_ips, ", ",
                                         c->remote_ip, NULL);
             else
                 proxy_ips = c->remote_ip;
@@ -400,7 +400,7 @@ static int remoteip_modify_connection(re
     if (!conn || (c->remote_addr == conn->orig_addr))
         return OK;
 
-    /* Fixups here, remote becomes the new Via header value, etc 
+    /* Fixups here, remote becomes the new Via header value, etc
      * In the heavy operations above we used request scope, to limit
      * conn pool memory growth on keepalives, so here we must scope
      * the final results to the connection pool lifetime.
@@ -416,7 +416,7 @@ static int remoteip_modify_connection(re
     if (remote)
         remote = apr_pstrdup(c->pool, remote);
     conn->proxied_remote = remote;
-    conn->prior_remote = apr_pstrdup(c->pool, apr_table_get(r->headers_in, 
+    conn->prior_remote = apr_pstrdup(c->pool, apr_table_get(r->headers_in,
                                                       config->header_name));
     if (proxy_ips)
         proxy_ips = apr_pstrdup(c->pool, proxy_ips);
@@ -440,7 +440,7 @@ ditto_request_rec:
     }
 
     ap_log_rerror(APLOG_MARK, APLOG_INFO|APLOG_NOERRNO, 0, r,
-                  conn->proxy_ips 
+                  conn->proxy_ips
                       ? "Using %s as client's IP by proxies %s"
                       : "Using %s as client's IP by internal proxies",
                   conn->proxied_ip, conn->proxy_ips);

Modified: httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_bybusyness.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_bybusyness.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_bybusyness.c (original)
+++ httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_bybusyness.c Fri Sep 23 13:39:32 2011
@@ -35,7 +35,7 @@ static proxy_worker *find_best_bybusynes
     int checked_standby;
 
     int total_factor = 0;
-    
+
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy: Entering bybusyness for BALANCER (%s)",
                  balancer->name);
@@ -76,7 +76,7 @@ static proxy_worker *find_best_bybusynes
 
                     (*worker)->s->lbstatus += (*worker)->s->lbfactor;
                     total_factor += (*worker)->s->lbfactor;
-                    
+
                     if (!mycandidate
                         || (*worker)->s->busy < mycandidate->s->busy
                         || ((*worker)->s->busy == mycandidate->s->busy && (*worker)->s->lbstatus > mycandidate->s->lbstatus))

Modified: httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_byrequests.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_byrequests.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_byrequests.c (original)
+++ httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_byrequests.c Fri Sep 23 13:39:32 2011
@@ -79,7 +79,7 @@ static proxy_worker *find_best_byrequest
     int max_lbset = 0;
     int checking_standby;
     int checked_standby;
-    
+
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy: Entering byrequests for BALANCER (%s)",
                  balancer->name);