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 2005/11/10 16:22:44 UTC

svn commit: r332309 [7/13] - in /httpd/httpd/branches/2.2.x: modules/aaa/ modules/arch/netware/ modules/arch/win32/ modules/cache/ modules/dav/fs/ modules/dav/lock/ modules/dav/main/ modules/debug/ modules/echo/ modules/experimental/ modules/filters/ m...

Modified: httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_balancer.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_balancer.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_balancer.c (original)
+++ httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_balancer.c Thu Nov 10 07:20:05 2005
@@ -33,7 +33,7 @@
 
     if (strncasecmp(url, "balancer:", 9) == 0) {
         url += 9;
-    }    
+    }
     else {
         return DECLINED;
     }
@@ -78,7 +78,7 @@
                                  proxy_balancer *balancer)
 {
     int i;
-    proxy_worker *workers;    
+    proxy_worker *workers;
 
     workers = (proxy_worker *)balancer->workers->elts;
 
@@ -111,7 +111,7 @@
                             const char *name)
 {
     char *path = NULL;
-    
+
     for (path = strstr(url, name); path; path = strstr(path + 1, name)) {
         path += (strlen(name) + 1);
         if (*path == '=') {
@@ -137,13 +137,13 @@
     const char *start_cookie;
 
     if ((cookies = apr_table_get(r->headers_in, "Cookie"))) {
-        for (start_cookie = ap_strstr_c(cookies, name); start_cookie; 
+        for (start_cookie = ap_strstr_c(cookies, name); start_cookie;
              start_cookie = ap_strstr_c(start_cookie + 1, name)) {
             if (start_cookie == cookies ||
                 start_cookie[-1] == ';' ||
                 start_cookie[-1] == ',' ||
                 isspace(start_cookie[-1])) {
-                
+
                 start_cookie += strlen(name);
                 while(*start_cookie && isspace(*start_cookie))
                     ++start_cookie;
@@ -161,7 +161,7 @@
                     return cookie;
                 }
             }
-        }     
+        }
     }
     return NULL;
 }
@@ -235,13 +235,13 @@
                                       request_rec *r)
 {
     proxy_worker *candidate = NULL;
-    
+
     if (PROXY_THREAD_LOCK(balancer) != APR_SUCCESS)
-        return NULL;    
+        return NULL;
 
     candidate = (*balancer->lbmethod->finder)(balancer, r);
 
-/*    
+/*
         PROXY_THREAD_UNLOCK(balancer);
         return NULL;
 */
@@ -258,10 +258,10 @@
          */
 #if APR_HAS_THREADS
         if (balancer->timeout) {
-            /* XXX: This can perhaps be build using some 
+            /* XXX: This can perhaps be build using some
              * smarter mechanism, like tread_cond.
-             * But since the statuses can came from 
-             * different childs, use the provided algo. 
+             * But since the statuses can came from
+             * different childs, use the provided algo.
              */
             apr_interval_time_t timeout = balancer->timeout;
             apr_interval_time_t step, tval = 0;
@@ -290,7 +290,7 @@
 {
     const char *scheme = strstr(*url, "://");
     const char *path = NULL;
-    
+
     if (scheme)
         path = ap_strchr_c(scheme + 3, '/');
 
@@ -302,7 +302,7 @@
     }
 
     *url = apr_pstrcat(r->pool, worker->name, path, NULL);
-   
+
     return OK;
 }
 
@@ -317,7 +317,7 @@
     apr_status_t rv;
 
     *worker = NULL;
-    /* Step 1: check if the url is for us 
+    /* Step 1: check if the url is for us
      * The url we can handle starts with 'balancer://'
      * If balancer is already provided skip the search
      * for balancer, because this is failover attempt.
@@ -325,9 +325,9 @@
     if (!*balancer &&
         !(*balancer = ap_proxy_get_balancer(r->pool, conf, *url)))
         return DECLINED;
-    
+
     /* Step 2: find the session route */
-    
+
     runtime = find_session_route(*balancer, r, &route, url);
     /* Lock the LoadBalancer
      * XXX: perhaps we need the process lock here
@@ -341,7 +341,7 @@
         int i, total_factor = 0;
         proxy_worker *workers;
         /* We have a sticky load balancer
-         * Update the workers status 
+         * Update the workers status
          * so that even session routes get
          * into account.
          */
@@ -376,7 +376,7 @@
             ap_log_error(APLOG_MARK, APLOG_ERR, 0, r->server,
                          "proxy: BALANCER: (%s). All workers are in error state",
                          (*balancer)->name);
-        
+
             return HTTP_SERVICE_UNAVAILABLE;
         }
         *worker = runtime;
@@ -398,7 +398,7 @@
                  (*balancer)->name, (*worker)->name, *url);
 
     return access_status;
-} 
+}
 
 static int proxy_balancer_post_request(proxy_worker *worker,
                                        proxy_balancer *balancer,
@@ -420,17 +420,17 @@
      * track on that.
      */
 
-    PROXY_THREAD_UNLOCK(balancer);        
+    PROXY_THREAD_UNLOCK(balancer);
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy_balancer_post_request for (%s)", balancer->name);
 
     return OK;
-} 
+}
 
 static void recalc_factors(proxy_balancer *balancer)
 {
     int i;
-    proxy_worker *workers;    
+    proxy_worker *workers;
 
 
     /* Recalculate lbfactors */
@@ -448,7 +448,7 @@
     }
 }
 
-/* Manages the loadfactors and member status 
+/* Manages the loadfactors and member status
  */
 static int balancer_handler(request_rec *r)
 {
@@ -580,9 +580,9 @@
             for (n = 0; n < balancer->workers->nelts; n++) {
                 ap_rputs("        <httpd:worker>\n", r);
                 ap_rvputs(r, "          <httpd:scheme>", worker->scheme,
-                          "</httpd:scheme>\n", NULL);                
+                          "</httpd:scheme>\n", NULL);
                 ap_rvputs(r, "          <httpd:hostname>", worker->hostname,
-                          "</httpd:hostname>\n", NULL);                
+                          "</httpd:hostname>\n", NULL);
                ap_rprintf(r, "          <httpd:loadfactor>%d</httpd:loadfactor>\n",
                           worker->s->lbfactor);
                 ap_rputs("        </httpd:worker>\n", r);
@@ -593,7 +593,7 @@
             ++balancer;
         }
         ap_rputs("  </httpd:balancers>\n", r);
-        ap_rputs("</httpd:manager>", r);         
+        ap_rputs("</httpd:manager>", r);
     }
     else {
         ap_set_content_type(r, "text/html");
@@ -611,11 +611,11 @@
             ap_rputs("<hr />\n<h3>LoadBalancer Status for ", r);
             ap_rvputs(r, "<a href=\"", r->uri, "?b=",
                       balancer->name + sizeof("balancer://") - 1,
-                      "\">", NULL); 
+                      "\">", NULL);
             ap_rvputs(r, balancer->name, "</a></h3>\n\n", NULL);
             ap_rputs("\n\n<table border=\"0\" style=\"text-align: left;\"><tr>"
                 "<th>StickySession</th><th>Timeout</th><th>FailoverAttempts</th><th>Method</th>"
-                "</tr>\n<tr>", r);                
+                "</tr>\n<tr>", r);
             ap_rvputs(r, "<td>", balancer->sticky, NULL);
             ap_rprintf(r, "</td><td>%" APR_TIME_T_FMT "</td>",
                 apr_time_sec(balancer->timeout));
@@ -635,7 +635,7 @@
                 ap_rvputs(r, "<tr>\n<td><a href=\"", r->uri, "?b=",
                           balancer->name + sizeof("balancer://") - 1, "&w=",
                           ap_escape_uri(r->pool, worker->name),
-                          "\">", NULL); 
+                          "\">", NULL);
                 ap_rvputs(r, worker->name, "</a></td>", NULL);
                 ap_rvputs(r, "<td>", worker->s->route, NULL);
                 ap_rvputs(r, "</td><td>", worker->s->redirect, NULL);
@@ -660,25 +660,25 @@
             ap_rputs("<h3>Edit worker settings for ", r);
             ap_rvputs(r, wsel->name, "</h3>\n", NULL);
             ap_rvputs(r, "<form method=\"GET\" action=\"", NULL);
-            ap_rvputs(r, r->uri, "\">\n<dl>", NULL); 
+            ap_rvputs(r, r->uri, "\">\n<dl>", NULL);
             ap_rputs("<table><tr><td>Load factor:</td><td><input name=\"lf\" type=text ", r);
-            ap_rprintf(r, "value=\"%d\"></td><tr>\n", wsel->s->lbfactor);            
+            ap_rprintf(r, "value=\"%d\"></td><tr>\n", wsel->s->lbfactor);
             ap_rputs("<tr><td>Route:</td><td><input name=\"wr\" type=text ", r);
-            ap_rvputs(r, "value=\"", wsel->route, NULL); 
-            ap_rputs("\"></td><tr>\n", r);            
+            ap_rvputs(r, "value=\"", wsel->route, NULL);
+            ap_rputs("\"></td><tr>\n", r);
             ap_rputs("<tr><td>Route Redirect:</td><td><input name=\"rr\" type=text ", r);
-            ap_rvputs(r, "value=\"", wsel->redirect, NULL); 
-            ap_rputs("\"></td><tr>\n", r);            
+            ap_rvputs(r, "value=\"", wsel->redirect, NULL);
+            ap_rputs("\"></td><tr>\n", r);
             ap_rputs("<tr><td>Status:</td><td>Disabled: <input name=\"dw\" value=\"Disable\" type=radio", r);
             if (wsel->s->status & PROXY_WORKER_DISABLED)
                 ap_rputs(" checked", r);
             ap_rputs("> | Enabled: <input name=\"dw\" value=\"Enable\" type=radio", r);
             if (!(wsel->s->status & PROXY_WORKER_DISABLED))
                 ap_rputs(" checked", r);
-            ap_rputs("></td><tr>\n", r);            
+            ap_rputs("></td><tr>\n", r);
             ap_rputs("<tr><td colspan=2><input type=submit value=\"Submit\"></td></tr>\n", r);
             ap_rvputs(r, "</table>\n<input type=hidden name=\"w\" ",  NULL);
-            ap_rvputs(r, "value=\"", ap_escape_uri(r->pool, wsel->name), "\">\n", NULL); 
+            ap_rvputs(r, "value=\"", ap_escape_uri(r->pool, wsel->name), "\">\n", NULL);
             ap_rvputs(r, "<input type=hidden name=\"b\" ", NULL);
             ap_rvputs(r, "value=\"", bsel->name + sizeof("balancer://") - 1,
                       "\">\n</form>\n", NULL);
@@ -688,7 +688,7 @@
             ap_rputs("<h3>Edit balancer settings for ", r);
             ap_rvputs(r, bsel->name, "</h3>\n", NULL);
             ap_rvputs(r, "<form method=\"GET\" action=\"", NULL);
-            ap_rvputs(r, r->uri, "\">\n<dl>", NULL); 
+            ap_rvputs(r, r->uri, "\">\n<dl>", NULL);
             ap_rputs("<table><tr><td>StickySession Identifier:</td><td><input name=\"ss\" type=text ", r);
             if (bsel->sticky)
                 ap_rvputs(r, "value=\"", bsel->sticky, "\"", NULL);
@@ -733,8 +733,8 @@
         proxy_balancer *balancer;
         int i;
         conf = (proxy_server_conf *)ap_get_module_config(sconf, &proxy_module);
-    
-        /* Initialize shared scoreboard data */ 
+
+        /* Initialize shared scoreboard data */
         balancer = (proxy_balancer *)conf->balancers->elts;
         for (i = 0; i < conf->balancers->nelts; i++) {
             init_balancer_members(conf, s, balancer);
@@ -790,7 +790,7 @@
  *   b a d c d a c d b d ...
  *
  */
- 
+
 static proxy_worker *find_best_byrequests(proxy_balancer *balancer,
                                 request_rec *r)
 {
@@ -798,7 +798,7 @@
     int total_factor = 0;
     proxy_worker *worker = (proxy_worker *)balancer->workers->elts;
     proxy_worker *mycandidate = NULL;
- 
+
 
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy: Entering byrequests for BALANCER (%s)",
@@ -859,7 +859,7 @@
     apr_off_t curmin = 0;
     proxy_worker *worker = (proxy_worker *)balancer->workers->elts;
     proxy_worker *mycandidate = NULL;
-    
+
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy: Entering bytraffic for BALANCER (%s)",
                  balancer->name);
@@ -887,7 +887,7 @@
         }
         worker++;
     }
-    
+
     if (mycandidate) {
         mycandidate->s->elected++;
     }
@@ -925,8 +925,8 @@
      /* manager handler */
     ap_hook_handler(balancer_handler, NULL, NULL, APR_HOOK_FIRST);
     ap_hook_child_init(child_init, aszPred, NULL, APR_HOOK_MIDDLE);
-    proxy_hook_pre_request(proxy_balancer_pre_request, NULL, NULL, APR_HOOK_FIRST);    
-    proxy_hook_post_request(proxy_balancer_post_request, NULL, NULL, APR_HOOK_FIRST);    
+    proxy_hook_pre_request(proxy_balancer_pre_request, NULL, NULL, APR_HOOK_FIRST);
+    proxy_hook_post_request(proxy_balancer_post_request, NULL, NULL, APR_HOOK_FIRST);
     proxy_hook_canon_handler(proxy_balancer_canon, NULL, NULL, APR_HOOK_FIRST);
     ap_register_provider(p, PROXY_LBMETHOD, "bytraffic", "0", &bytraffic);
     ap_register_provider(p, PROXY_LBMETHOD, "byrequests", "0", &byrequests);

Modified: httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_connect.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_connect.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_connect.c (original)
+++ httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_connect.c Thu Nov 10 07:20:05 2005
@@ -23,7 +23,7 @@
 
 module AP_MODULE_DECLARE_DATA proxy_connect_module;
 
-/*  
+/*
  * This handles Netscape CONNECT method secure proxy requests.
  * A connection is opened to the specified host and data is
  * passed through between the WWW site and the browser.
@@ -32,8 +32,8 @@
  * "Tunneling SSL Through a WWW Proxy" currently at
  * http://www.mcom.com/newsref/std/tunneling_ssl.html.
  *
- * If proxyhost and proxyport are set, we send a CONNECT to 
- * the specified proxy..  
+ * If proxyhost and proxyport are set, we send a CONNECT to
+ * the specified proxy..
  *
  * FIXME: this doesn't log the number of bytes sent, but
  *        that may be okay, since the data is supposed to
@@ -73,8 +73,8 @@
 
 /* CONNECT handler */
 static int proxy_connect_handler(request_rec *r, proxy_worker *worker,
-                                 proxy_server_conf *conf, 
-                                 char *url, const char *proxyname, 
+                                 proxy_server_conf *conf,
+                                 char *url, const char *proxyname,
                                  apr_port_t proxyport)
 {
     apr_pool_t *p = r->pool;
@@ -239,7 +239,7 @@
         ap_xlate_proto_to_ascii(buffer, nbytes);
         apr_socket_send(client_socket, buffer, &nbytes);
 #if 0
-        /* This is safer code, but it doesn't work yet.  I'm leaving it 
+        /* This is safer code, but it doesn't work yet.  I'm leaving it
          * here so that I can fix it later.
          */
         r->status = HTTP_OK;

Modified: httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_ftp.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_ftp.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_ftp.c (original)
+++ httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_ftp.c Thu Nov 10 07:20:05 2005
@@ -733,7 +733,7 @@
 
     backend->close_on_recycle = 1;
     ap_set_module_config(r->connection->conn_config, &proxy_ftp_module, NULL);
-    ap_proxy_release_connection("FTP", backend, r->server);    
+    ap_proxy_release_connection("FTP", backend, r->server);
 
     return OK;
 }
@@ -769,7 +769,7 @@
     char buffer[MAX_STRING_LEN];
     char *ftpmessage = NULL;
     char *path, *strp, *type_suffix, *cwd = NULL;
-    apr_uri_t uri; 
+    apr_uri_t uri;
     char *user = NULL;
 /*    char *account = NULL; how to supply an account in a URL? */
     const char *password = NULL;
@@ -914,8 +914,8 @@
                                     connectname, APR_UNSPEC,
                                     connectport, 0,
                                     address_pool);
-    if (worker->is_address_reusable && !worker->cp->addr) {        
-        worker->cp->addr = connect_addr;            
+    if (worker->is_address_reusable && !worker->cp->addr) {
+        worker->cp->addr = connect_addr;
         PROXY_THREAD_UNLOCK(worker);
     }
     /*
@@ -945,9 +945,9 @@
             }
             return status;
         }
-        /* TODO: see if ftp could use determine_connection */ 
+        /* TODO: see if ftp could use determine_connection */
         backend->addr = connect_addr;
-        ap_set_module_config(c->conn_config, &proxy_ftp_module, backend);        
+        ap_set_module_config(c->conn_config, &proxy_ftp_module, backend);
     }
 
 
@@ -1221,7 +1221,7 @@
                 }
 
 #if !defined (TPF) && !defined(BEOS)
-                if (conf->recv_buffer_size > 0 
+                if (conf->recv_buffer_size > 0
                         && (rv = apr_socket_opt_set(data_sock, APR_SO_RCVBUF,
                                                     conf->recv_buffer_size))) {
                     ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
@@ -1309,7 +1309,7 @@
                 }
 
 #if !defined (TPF) && !defined(BEOS)
-                if (conf->recv_buffer_size > 0 
+                if (conf->recv_buffer_size > 0
                         && (rv = apr_socket_opt_set(data_sock, APR_SO_RCVBUF,
                                                     conf->recv_buffer_size))) {
                     ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
@@ -1355,7 +1355,7 @@
         local_port = local_addr->port;
         apr_sockaddr_ip_get(&local_ip, local_addr);
 
-        if ((rv = apr_socket_opt_set(local_sock, APR_SO_REUSEADDR, one)) 
+        if ((rv = apr_socket_opt_set(local_sock, APR_SO_REUSEADDR, one))
                 != APR_SUCCESS) {
 #ifndef _OSD_POSIX              /* BS2000 has this option "always on" */
             ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
@@ -1478,7 +1478,7 @@
             ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                              "proxy: FTP: SIZE shows this is a directory");
             dirlisting = 1;
-            rc = proxy_ftp_command(apr_pstrcat(p, "CWD ", 
+            rc = proxy_ftp_command(apr_pstrcat(p, "CWD ",
                            ftp_escape_globbingchars(p, path), CRLF, NULL),
                            r, origin, bb, &ftpmessage);
             /* possible results: 250, 421, 500, 501, 502, 530, 550 */
@@ -1778,10 +1778,10 @@
                      "proxy: FTP: start body send");
 
         /* read the body, pass it to the output filters */
-        while (ap_get_brigade(data->input_filters, 
-                              bb, 
-                              AP_MODE_READBYTES, 
-                              APR_BLOCK_READ, 
+        while (ap_get_brigade(data->input_filters,
+                              bb,
+                              AP_MODE_READBYTES,
+                              APR_BLOCK_READ,
                               conf->io_buffer_size) == APR_SUCCESS) {
 #if DEBUGGING
             {

Modified: httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_http.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_http.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_http.c (original)
+++ httpd/httpd/branches/2.2.x/modules/proxy/mod_proxy_http.c Thu Nov 10 07:20:05 2005
@@ -92,7 +92,7 @@
     if (ap_strchr_c(host, ':')) { /* if literal IPv6 address */
         host = apr_pstrcat(r->pool, "[", host, "]", NULL);
     }
-    r->filename = apr_pstrcat(r->pool, "proxy:", scheme, "://", host, sport, 
+    r->filename = apr_pstrcat(r->pool, "proxy:", scheme, "://", host, sport,
             "/", path, (search) ? "?" : "", (search) ? search : "", NULL);
     return OK;
 }
@@ -228,20 +228,20 @@
         apr_brigade_length(input_brigade, 1, &bytes);
 
         hdr_len = apr_snprintf(chunk_hdr, sizeof(chunk_hdr),
-                               "%" APR_UINT64_T_HEX_FMT CRLF, 
+                               "%" APR_UINT64_T_HEX_FMT CRLF,
                                (apr_uint64_t)bytes);
-        
+
         ap_xlate_proto_to_ascii(chunk_hdr, hdr_len);
         e = apr_bucket_transient_create(chunk_hdr, hdr_len,
                                         bucket_alloc);
         APR_BRIGADE_INSERT_HEAD(input_brigade, e);
-        
+
         /*
          * Append the end-of-chunk CRLF
          */
         e = apr_bucket_immortal_create(ASCII_CRLF, 2, bucket_alloc);
         APR_BRIGADE_INSERT_TAIL(input_brigade, e);
-        
+
         if (header_brigade) {
             /* we never sent the header brigade, so go ahead and
              * take care of that now
@@ -267,7 +267,7 @@
         else {
             bb = input_brigade;
         }
-        
+
         /* The request is flushed below this loop with chunk EOS header */
         status = pass_brigade(bucket_alloc, r, p_conn, origin, bb, 0);
         if (status != APR_SUCCESS) {
@@ -388,7 +388,7 @@
         else {
             bb = input_brigade;
         }
-        
+
         /* Once we hit EOS, we are ready to flush. */
         status = pass_brigade(bucket_alloc, r, p_conn, origin, bb, seen_eos);
         if (status != APR_SUCCESS) {
@@ -407,7 +407,7 @@
             return status;
         }
     }
-    
+
     if (bytes_streamed != cl_val) {
         ap_log_error(APLOG_MARK, APLOG_ERR, 0, r->server,
                      "proxy: client %s given Content-Length did not match"
@@ -520,7 +520,7 @@
             }
 
         }
-        
+
         bytes_spooled += bytes;
 
         if (seen_eos) {
@@ -605,7 +605,7 @@
     /* strip connection listed hop-by-hop headers from the request */
     /* even though in theory a connection: close coming from the client
      * should not affect the connection to the server, it's unlikely
-     * that subsequent client requests will hit this thread/process, 
+     * that subsequent client requests will hit this thread/process,
      * so we cancel server keepalive if the client does.
      */
     if (ap_proxy_liststr(apr_table_get(r->headers_in,
@@ -641,25 +641,25 @@
         } else {
             buf = apr_pstrcat(p, "Host: ", uri->hostname, CRLF, NULL);
         }
-    } 
+    }
     else {
-        /* don't want to use r->hostname, as the incoming header might have a 
-         * port attached 
+        /* don't want to use r->hostname, as the incoming header might have a
+         * port attached
          */
-        const char* hostname = apr_table_get(r->headers_in,"Host");        
+        const char* hostname = apr_table_get(r->headers_in,"Host");
         if (!hostname) {
             hostname =  r->server->server_hostname;
             ap_log_rerror(APLOG_MARK, APLOG_WARNING, 0, r,
                           "proxy: no HTTP 0.9 request (with no host line) "
                           "on incoming request and preserve host set "
-                          "forcing hostname to be %s for uri %s", 
-                          hostname, 
+                          "forcing hostname to be %s for uri %s",
+                          hostname,
                           r->uri );
         }
         buf = apr_pstrcat(p, "Host: ", hostname, CRLF, NULL);
     }
     ap_xlate_proto_to_ascii(buf, strlen(buf));
-    e = apr_bucket_pool_create(buf, strlen(buf), p, c->bucket_alloc);        
+    e = apr_bucket_pool_create(buf, strlen(buf), p, c->bucket_alloc);
     APR_BRIGADE_INSERT_TAIL(header_brigade, e);
 
     /* handle Via */
@@ -741,7 +741,7 @@
     headers_in_array = apr_table_elts(r->headers_in);
     headers_in = (const apr_table_entry_t *) headers_in_array->elts;
     for (counter = 0; counter < headers_in_array->nelts; counter++) {
-        if (headers_in[counter].key == NULL 
+        if (headers_in[counter].key == NULL
              || headers_in[counter].val == NULL
 
             /* Already sent */
@@ -755,7 +755,7 @@
              || !strcasecmp(headers_in[counter].key, "Trailer")
              || !strcasecmp(headers_in[counter].key, "Upgrade")
 
-            /* XXX: @@@ FIXME: "Proxy-Authorization" should *only* be 
+            /* XXX: @@@ FIXME: "Proxy-Authorization" should *only* be
              * suppressed if THIS server requested the authentication,
              * not when a frontend proxy requested it!
              *
@@ -830,7 +830,7 @@
      * that the can and have done so unless they they remove
      * their decoding from the headers_in T-E list.
      * XXX: Make this extensible, but in doing so, presume the
-     * encoding has been done by the extensions' handler, and 
+     * encoding has been done by the extensions' handler, and
      * do not modify add_te_chunked's logic
      */
     if (old_te_val && strcmp(old_te_val, "chunked") != 0) {
@@ -900,7 +900,7 @@
      * surrender once we hit 80 bytes less than MAX_MEM_SPOOL
      * (an arbitrary value.)
      */
-    } while ((bytes_read < MAX_MEM_SPOOL - 80) 
+    } while ((bytes_read < MAX_MEM_SPOOL - 80)
               && !APR_BUCKET_IS_EOS(APR_BRIGADE_LAST(input_brigade)));
 
     /* Use chunked request body encoding or send a content-length body?
@@ -909,10 +909,10 @@
      *
      *   We have no request body (handled by RB_STREAM_CL)
      *
-     *   We have a request body length <= MAX_MEM_SPOOL 
+     *   We have a request body length <= MAX_MEM_SPOOL
      *
      *   The administrator has setenv force-proxy-request-1.0
-     *   
+     *
      *   The client sent a C-L body, and the administrator has
      *   not setenv proxy-sendchunked or has set setenv proxy-sendcl
      *
@@ -935,12 +935,12 @@
      * input to a temporary file.  Chunked is always preferable.
      *
      * We can only trust the client-provided C-L if the T-E header
-     * is absent, and the filters are unchanged (the body won't 
+     * is absent, and the filters are unchanged (the body won't
      * be resized by another content filter).
      */
     if (APR_BUCKET_IS_EOS(APR_BRIGADE_LAST(input_brigade))) {
         /* The whole thing fit, so our decision is trivial, use
-         * the filtered bytes read from the client for the request 
+         * the filtered bytes read from the client for the request
          * body Content-Length.
          *
          * If we expected no body, and read no body, do not set
@@ -952,7 +952,7 @@
         rb_method = RB_STREAM_CL;
     }
     else if (old_te_val) {
-        if (force10 
+        if (force10
              || (apr_table_get(r->subprocess_env, "proxy-sendcl")
                   && !apr_table_get(r->subprocess_env, "proxy-sendchunks"))) {
             rb_method = RB_SPOOL_CL;
@@ -965,7 +965,7 @@
         if (r->input_filters == r->proto_input_filters) {
             rb_method = RB_STREAM_CL;
         }
-        else if (!force10 
+        else if (!force10
                   && apr_table_get(r->subprocess_env, "proxy-sendchunks")
                   && !apr_table_get(r->subprocess_env, "proxy-sendcl")) {
             rb_method = RB_STREAM_CHUNKED;
@@ -995,11 +995,11 @@
     /* send the request body, if any. */
     switch(rb_method) {
     case RB_STREAM_CHUNKED:
-        status = stream_reqbody_chunked(p, r, p_conn, origin, header_brigade, 
+        status = stream_reqbody_chunked(p, r, p_conn, origin, header_brigade,
                                         input_brigade);
         break;
     case RB_STREAM_CL:
-        status = stream_reqbody_cl(p, r, p_conn, origin, header_brigade, 
+        status = stream_reqbody_cl(p, r, p_conn, origin, header_brigade,
                                    input_brigade, old_cl_val);
         break;
     case RB_SPOOL_CL:
@@ -1018,7 +1018,7 @@
         ap_log_error(APLOG_MARK, APLOG_ERR, status, r->server,
                      "proxy: pass request body failed to %pI (%s)"
                      " from %s (%s)",
-                     p_conn->addr, 
+                     p_conn->addr,
                      p_conn->hostname ? p_conn->hostname: "",
                      c->remote_ip,
                      c->remote_host ? c->remote_host: "");
@@ -1265,7 +1265,7 @@
                 buffer[13] = '\0';
             }
             r->status_line = apr_pstrdup(p, &buffer[9]);
-            
+
 
             /* read the headers. */
             /* N.B. for HTTP/1.0 clients, we have to fold line-wrapped headers*/
@@ -1312,10 +1312,10 @@
             /* can't have both Content-Length and Transfer-Encoding */
             if (apr_table_get(r->headers_out, "Transfer-Encoding")
                     && apr_table_get(r->headers_out, "Content-Length")) {
-                /* 
+                /*
                  * 2616 section 4.4, point 3: "if both Transfer-Encoding
                  * and Content-Length are received, the latter MUST be
-                 * ignored"; 
+                 * ignored";
                  *
                  * To help mitigate HTTP Splitting, unset Content-Length
                  * and shut down the backend server connection
@@ -1335,7 +1335,7 @@
             ap_proxy_clear_connection(p, r->headers_out);
             if ((buf = apr_table_get(r->headers_out, "Content-Type"))) {
                 ap_set_content_type(r, apr_pstrdup(p, buf));
-            }            
+            }
             ap_proxy_pre_http_request(origin,rp);
 
             /* handle Via header in response */
@@ -1442,7 +1442,7 @@
 
             ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                          "proxy: start body send");
-             
+
             /*
              * if we are overriding the errors, we can't put the content
              * of the page into the brigade
@@ -1456,7 +1456,7 @@
                     apr_off_t readbytes;
                     apr_status_t rv;
 
-                    rv = ap_get_brigade(rp->input_filters, bb, 
+                    rv = ap_get_brigade(rp->input_filters, bb,
                                         AP_MODE_READBYTES, mode,
                                         conf->io_buffer_size);
 
@@ -1467,7 +1467,7 @@
                         /* flush to the client and switch to blocking mode */
                         e = apr_bucket_flush_create(c->bucket_alloc);
                         APR_BRIGADE_INSERT_TAIL(bb, e);
-                        if (ap_pass_brigade(r->output_filters, bb) 
+                        if (ap_pass_brigade(r->output_filters, bb)
                             || c->aborted) {
                             backend->close = 1;
                             break;
@@ -1486,7 +1486,7 @@
                     }
                     /* next time try a non-blocking read */
                     mode = APR_NONBLOCK_READ;
-                    
+
                     apr_brigade_length(bb, 0, &readbytes);
                     backend->worker->s->read += readbytes;
 #if DEBUGGING
@@ -1565,7 +1565,7 @@
            }
             return status;
         }
-    } else 
+    } else
         return OK;
 }
 
@@ -1583,7 +1583,7 @@
     if (backend->close || (r->proto_num < HTTP_VERSION(1,1))) {
         backend->close_on_recycle = 1;
         ap_set_module_config(r->connection->conn_config, &proxy_http_module, NULL);
-        ap_proxy_release_connection(scheme, backend, r->server);    
+        ap_proxy_release_connection(scheme, backend, r->server);
     }
     return OK;
 }
@@ -1599,7 +1599,7 @@
  */
 static int proxy_http_handler(request_rec *r, proxy_worker *worker,
                               proxy_server_conf *conf,
-                              char *url, const char *proxyname, 
+                              char *url, const char *proxyname,
                               apr_port_t proxyport)
 {
     int status;
@@ -1660,9 +1660,9 @@
     }
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
              "proxy: HTTP: serving URL %s", url);
-    
-    
-    /* only use stored info for top-level pages. Sub requests don't share 
+
+
+    /* only use stored info for top-level pages. Sub requests don't share
      * in keepalives
      */
     if (!r->main) {
@@ -1705,7 +1705,7 @@
                                                  c, r->server)) != OK)
             goto cleanup;
     }
-   
+
     /* Step Four: Send the Request */
     if ((status = ap_proxy_http_request(p, r, backend, backend->connection,
                                         conf, uri, url, server_portstr)) != OK)

Modified: httpd/httpd/branches/2.2.x/modules/proxy/proxy_util.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/proxy/proxy_util.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/proxy/proxy_util.c (original)
+++ httpd/httpd/branches/2.2.x/modules/proxy/proxy_util.c Thu Nov 10 07:20:05 2005
@@ -38,7 +38,7 @@
 static int proxy_match_hostname(struct dirconn_entry *This, request_rec *r);
 static int proxy_match_word(struct dirconn_entry *This, request_rec *r);
 
-APR_IMPLEMENT_OPTIONAL_HOOK_RUN_ALL(proxy, PROXY, int, create_req, 
+APR_IMPLEMENT_OPTIONAL_HOOK_RUN_ALL(proxy, PROXY, int, create_req,
                                    (request_rec *r, request_rec *pr), (r, pr),
                                    OK, DECLINED)
 
@@ -132,7 +132,7 @@
  * Convert a URL-encoded string to canonical form.
  * It decodes characters which need not be encoded,
  * and encodes those which must be encoded, and does not touch
- * those which must not be touched. 
+ * those which must not be touched.
  */
 PROXY_DECLARE(char *)ap_proxy_canonenc(apr_pool_t *p, const char *x, int len, enum enctype t,
     int forcedec, int proxyreq)
@@ -495,14 +495,14 @@
 PROXY_DECLARE(int) ap_proxyerror(request_rec *r, int statuscode, const char *message)
 {
     apr_table_setn(r->notes, "error-notes",
-    apr_pstrcat(r->pool, 
+    apr_pstrcat(r->pool,
         "The proxy server could not handle the request "
         "<em><a href=\"", ap_escape_uri(r->pool, r->uri),
         "\">", ap_escape_html(r->pool, r->method),
-        "&nbsp;", 
+        "&nbsp;",
         ap_escape_html(r->pool, r->uri), "</a></em>.<p>\n"
         "Reason: <strong>",
-        ap_escape_html(r->pool, message), 
+        ap_escape_html(r->pool, message),
         "</strong></p>", NULL));
 
     /* Allow "error-notes" string to be printed by ap_send_error_response() */
@@ -698,7 +698,7 @@
         != APR_SUCCESS) {
 #if DEBUGGING
         ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL,
-             "2)IP-NoMatch: hostname=%s msg=Host not found", 
+             "2)IP-NoMatch: hostname=%s msg=Host not found",
              host);
 #endif
         return 0;
@@ -711,7 +711,7 @@
         if (This->addr.s_addr == (ip->s_addr & This->mask.s_addr)) {
 #if DEBUGGING
         ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL,
-                 "3)IP-Match: %s[%s] <-> ", host, 
+                 "3)IP-Match: %s[%s] <-> ", host,
                  inet_ntoa(*ip));
         ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL,
                  "%s/", inet_ntoa(This->addr));
@@ -723,7 +723,7 @@
 #if DEBUGGING
         else {
                 ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL,
-                 "3)IP-NoMatch: %s[%s] <-> ", host, 
+                 "3)IP-NoMatch: %s[%s] <-> ", host,
                  inet_ntoa(*ip));
                 ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL,
                  "%s/", inet_ntoa(This->addr));
@@ -868,7 +868,7 @@
 }
 
 /* checks whether a host in uri_addr matches proxyblock */
-PROXY_DECLARE(int) ap_proxy_checkproxyblock(request_rec *r, proxy_server_conf *conf, 
+PROXY_DECLARE(int) ap_proxy_checkproxyblock(request_rec *r, proxy_server_conf *conf,
                              apr_sockaddr_t *uri_addr)
 {
     int j;
@@ -915,7 +915,7 @@
 }
 
 /*
- * converts a series of buckets into a string 
+ * converts a series of buckets into a string
  * XXX: BillS says this function performs essentially the same function as
  * ap_rgetline() in protocol.c. Deprecate this function and use ap_rgetline()
  * instead? I think ap_proxy_string_read() will not work properly on non ASCII
@@ -938,7 +938,7 @@
     /* loop through each brigade */
     while (!found) {
         /* get brigade from network one line at a time */
-        if (APR_SUCCESS != (rv = ap_get_brigade(c->input_filters, bb, 
+        if (APR_SUCCESS != (rv = ap_get_brigade(c->input_filters, bb,
                                                 AP_MODE_GETLINE,
                                                 APR_BLOCK_READ,
                                                 0))) {
@@ -1149,7 +1149,7 @@
     char *c, *uri = apr_pstrdup(p, url);
     int i;
 
-    c = strchr(uri, ':');   
+    c = strchr(uri, ':');
     if (c == NULL || c[1] != '/' || c[2] != '/' || c[3] == '\0')
        return NULL;
     /* remove path from uri */
@@ -1243,7 +1243,7 @@
     } else {
         ap_str_tolower(url_copy);
     }
-    
+
     worker = (proxy_worker *)conf->workers->elts;
 
     /*
@@ -1280,7 +1280,7 @@
     proxy_conn_pool *cp;
 
     /*
-     * Create a connection pool's subpool. 
+     * Create a connection pool's subpool.
      * This pool is used for connection recycling.
      * Once the worker is added it is never removed but
      * it can be disabled.
@@ -1288,10 +1288,10 @@
     apr_pool_create(&pool, p);
     /*
      * Alloc from the same pool as worker.
-     * proxy_conn_pool is permanently attached to the worker. 
+     * proxy_conn_pool is permanently attached to the worker.
      */
     cp = (proxy_conn_pool *)apr_pcalloc(p, sizeof(proxy_conn_pool));
-    cp->pool = pool;    
+    cp->pool = pool;
     worker->cp = cp;
 }
 
@@ -1345,7 +1345,7 @@
     return worker;
 }
 
-PROXY_DECLARE(void) 
+PROXY_DECLARE(void)
 ap_proxy_add_worker_to_balancer(apr_pool_t *pool, proxy_balancer *balancer,
                                 proxy_worker *worker)
 {
@@ -1562,7 +1562,7 @@
 {
     proxy_conn_rec *conn = (proxy_conn_rec *)resource;
 
-    /* Destroy the pool only if not called from reslist_destroy */    
+    /* Destroy the pool only if not called from reslist_destroy */
     if (conn->worker->cp->pool)
         apr_pool_destroy(conn->pool);
 
@@ -1645,7 +1645,7 @@
             worker->smax = worker->hmax;
         /* Set min to be lower then smax */
         if (worker->min > worker->smax)
-            worker->min = worker->smax; 
+            worker->min = worker->smax;
     }
     else {
         /* This will supress the apr_reslist creation */
@@ -1813,7 +1813,7 @@
                  uri->port);
 
     /*
-     * allocate these out of the specified connection pool 
+     * allocate these out of the specified connection pool
      * The scheme handler decides if this is permanent or
      * short living pool.
      */
@@ -1918,7 +1918,7 @@
 
 {
     apr_size_t buffer_len = 1;
-    char test_buffer[1]; 
+    char test_buffer[1];
     apr_status_t socket_status;
     apr_interval_time_t current_timeout;
 
@@ -1995,7 +1995,7 @@
         }
         /* Set a keepalive option */
         if (worker->keepalive) {
-            if ((rv = apr_socket_opt_set(newsock, 
+            if ((rv = apr_socket_opt_set(newsock,
                             APR_SO_KEEPALIVE, 1)) != APR_SUCCESS) {
                 ap_log_error(APLOG_MARK, APLOG_ERR, rv, s,
                              "apr_socket_opt_set(SO_KEEPALIVE): Failed to set"
@@ -2088,7 +2088,7 @@
         if (!ap_proxy_ssl_enable(conn->connection)) {
             ap_log_error(APLOG_MARK, APLOG_ERR, 0,
                          s, "proxy: %s: failed to enable ssl support "
-                         "for %pI (%s)", proxy_function, 
+                         "for %pI (%s)", proxy_function,
                          backend_addr, conn->hostname);
             return HTTP_INTERNAL_SERVER_ERROR;
         }

Modified: httpd/httpd/branches/2.2.x/modules/ssl/mod_ssl.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/mod_ssl.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/mod_ssl.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/mod_ssl.c Thu Nov 10 07:20:05 2005
@@ -146,7 +146,7 @@
     SSL_CMD_ALL(UserName, TAKE1,
                 "Set user name to SSL variable value")
 
-    /* 
+    /*
      * Proxy configuration for remote SSL connections
      */
     SSL_CMD_SRV(ProxyEngine, FLAG,
@@ -197,11 +197,11 @@
                "(arbitrary complex boolean expression - see manual)")
 
     /* Deprecated directives. */
-    AP_INIT_RAW_ARGS("SSLLog", ap_set_deprecated, NULL, OR_ALL, 
+    AP_INIT_RAW_ARGS("SSLLog", ap_set_deprecated, NULL, OR_ALL,
       "SSLLog directive is no longer supported - use ErrorLog."),
-    AP_INIT_RAW_ARGS("SSLLogLevel", ap_set_deprecated, NULL, OR_ALL, 
+    AP_INIT_RAW_ARGS("SSLLogLevel", ap_set_deprecated, NULL, OR_ALL,
       "SSLLogLevel directive is no longer supported - use LogLevel."),
-    
+
     AP_END_CMD
 };
 
@@ -238,8 +238,8 @@
      * actually load the error strings once per process due to static
      * variable abuse in OpenSSL. */
 
-    /* 
-     * TODO: determine somewhere we can safely shove out diagnostics 
+    /*
+     * TODO: determine somewhere we can safely shove out diagnostics
      *       (when enabled) at this late stage in the game:
      * CRYPTO_mem_leaks_fp(stderr);
      */
@@ -250,7 +250,7 @@
                                apr_pool_t *plog,
                                apr_pool_t *ptemp)
 {
-    /* We must register the library in full, to ensure our configuration 
+    /* We must register the library in full, to ensure our configuration
      * code can successfully test the SSL environment.
      */
     CRYPTO_malloc_init();
@@ -480,7 +480,7 @@
 static void ssl_register_hooks(apr_pool_t *p)
 {
     /* ssl_hook_ReadReq needs to use the BrowserMatch settings so must
-     * run after mod_setenvif's post_read_request hook. */ 
+     * run after mod_setenvif's post_read_request hook. */
     static const char *pre_prr[] = { "mod_setenvif.c", NULL };
 
     ssl_io_filter_register(p);

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_config.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_config.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_config.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_config.c Thu Nov 10 07:20:05 2005
@@ -345,7 +345,7 @@
             file = NULL;
         }
     }
-    
+
     if ((err = ap_check_cmd_context(cmd, GLOBAL_ONLY))) {
         return err;
     }
@@ -382,7 +382,7 @@
 #if APR_HAS_POSIXSEM_SERIALIZE
     else if (!strcasecmp(meth, "posixsem") || !strcasecmp(meth, "sem")) {
         mc->nMutexMech = APR_LOCK_POSIXSEM;
-        /* Posix/SysV semaphores aren't file based, use the literal name 
+        /* Posix/SysV semaphores aren't file based, use the literal name
          * if provided and fall back on APR's default if not.  Today, APR
          * will ignore it, but once supported it has an absurdly short limit.
          */
@@ -415,7 +415,7 @@
     if (file) {
         mc->szMutexFile = ap_server_root_relative(cmd->server->process->pool, file);
         if (!mc->szMutexFile) {
-            return apr_pstrcat(cmd->pool, "Invalid SSLMutex ", meth, 
+            return apr_pstrcat(cmd->pool, "Invalid SSLMutex ", meth,
                                ": filepath ", file, NULL);
         }
     }
@@ -493,10 +493,10 @@
     else {
         err = "SSLCryptoDevice: Invalid argument; must be one of: "
               "'builtin' (none)";
-        e = ENGINE_get_first(); 
+        e = ENGINE_get_first();
         while (e) {
             ENGINE *en;
-            err = apr_pstrcat(cmd->pool, err, ", '", ENGINE_get_id(e), 
+            err = apr_pstrcat(cmd->pool, err, ", '", ENGINE_get_id(e),
                                          "' (", ENGINE_get_name(e), ")", NULL);
             en = ENGINE_get_next(e);
             ENGINE_free(e);
@@ -511,7 +511,7 @@
 
 const char *ssl_cmd_SSLRandomSeed(cmd_parms *cmd,
                                   void *dcfg,
-                                  const char *arg1, 
+                                  const char *arg1,
                                   const char *arg2,
                                   const char *arg3)
 {
@@ -658,7 +658,7 @@
     }
 
     return apr_pstrcat(parms->pool, parms->cmd->name,
-                       ": file '", *file, 
+                       ": file '", *file,
                        "' does not exist or is empty", NULL);
 
 }
@@ -690,7 +690,7 @@
     }
 
     return apr_pstrcat(parms->pool, parms->cmd->name,
-                       ": directory '", *dir, 
+                       ": directory '", *dir,
                        "' does not exist", NULL);
 
 }
@@ -730,7 +730,7 @@
 
     return apr_psprintf(parms->pool,
                         "%s: only up to %d "
-                        "different %s per virtual host allowed", 
+                        "different %s per virtual host allowed",
                          parms->cmd->name, SSL_AIDX_MAX, desc);
 }
 
@@ -930,7 +930,7 @@
     if ((err = ssl_cmd_verify_parse(cmd, arg, &mode))) {
         return err;
     }
-    
+
     if (cmd->path) {
         dc->nVerifyClient = mode;
     }
@@ -1064,7 +1064,7 @@
         mc->nSessionCacheMode      = SSL_SCMODE_DC;
         mc->szSessionCacheDataFile = apr_pstrdup(mc->pPool, arg+3);
         if (!mc->szSessionCacheDataFile) {
-            return apr_pstrcat(cmd->pool, 
+            return apr_pstrcat(cmd->pool,
                                "SSLSessionCache: Invalid cache file path: ",
                                arg+3, NULL);
         }
@@ -1252,7 +1252,7 @@
     return NULL;
 }
 
-const char *ssl_cmd_SSLProxyProtocol(cmd_parms *cmd, 
+const char *ssl_cmd_SSLProxyProtocol(cmd_parms *cmd,
                                      void *dcfg,
                                      const char *arg)
 {
@@ -1403,7 +1403,7 @@
 }
 
 
-const char *ssl_cmd_SSLUserName(cmd_parms *cmd, void *dcfg, 
+const char *ssl_cmd_SSLUserName(cmd_parms *cmd, void *dcfg,
                                 const char *arg)
 {
     SSLDirConfigRec *dc = (SSLDirConfigRec *)dcfg;

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_dh.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_dh.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_dh.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_dh.c Thu Nov 10 07:20:05 2005
@@ -24,7 +24,7 @@
  * | | | | | | (_) | (_| |   \__ \__ \ |
  * |_| |_| |_|\___/ \__,_|___|___/___/_|
  *                      |_____|
- * ssl_engine_dh.c 
+ * ssl_engine_dh.c
  * Diffie-Hellman Built-in Temporary Parameters
  */
 
@@ -153,7 +153,7 @@
 #   generate the DH parameters
 print "1. Generate 512 and 1024 bit Diffie-Hellman parameters (p, g)\n";
 my $rand = '';
-foreach $file (qw(/var/log/messages /var/adm/messages 
+foreach $file (qw(/var/log/messages /var/adm/messages
                   /kernel /vmunix /vmlinuz /etc/hosts /etc/resolv.conf)) {
     if (-f $file) {
         $rand = $file     if ($rand eq '');
@@ -164,7 +164,7 @@
 system("openssl gendh $rand -out dh512.pem 512");
 system("openssl gendh $rand -out dh1024.pem 1024");
 
-#   generate DH param info 
+#   generate DH param info
 my $dhinfo = '';
 open(FP, "openssl dh -noout -text -in dh512.pem |") || die;
 $dhinfo .= $_ while (<FP>);

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_init.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_init.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_init.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_init.c Thu Nov 10 07:20:05 2005
@@ -171,7 +171,7 @@
      * but it should be initialized for startup before we
      * call ssl_rand_seed() below.
      */
-    mc->pid = getpid(); 
+    mc->pid = getpid();
 
     /*
      * Let us cleanup on restarts and exists
@@ -207,7 +207,7 @@
         sc->vhost_id = ssl_util_vhostid(p, s);
         sc->vhost_id_len = strlen(sc->vhost_id);
 
-        if (ap_get_server_protocol(s) && 
+        if (ap_get_server_protocol(s) &&
             strcmp("https", ap_get_server_protocol(s)) == 0) {
             sc->enabled = SSL_ENABLED_TRUE;
         }
@@ -451,7 +451,7 @@
     SSL_CTX_set_options(ctx, SSL_OP_SINGLE_DH_USE);
 
 #ifdef SSL_OP_NO_SESSION_RESUMPTION_ON_RENEGOTIATION
-    /* 
+    /*
      * Disallow a session from being resumed during a renegotiation,
      * so that an acceptable cipher suite can be negotiated.
      */
@@ -599,7 +599,7 @@
     }
 
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, s,
-                 "Configuring permitted SSL ciphers [%s]", 
+                 "Configuring permitted SSL ciphers [%s]",
                  suite);
 
     if (!SSL_CTX_set_cipher_list(ctx, MODSSL_PCHAR_CAST suite)) {
@@ -648,7 +648,7 @@
     int i, n;
     const char *chain = mctx->cert_chain;
 
-    /* 
+    /*
      * Optionally configure extra server certificate chain certificates.
      * This is usually done by OpenSSL automatically when one of the
      * server cert issuers are found under SSLCACertificatePath or in
@@ -674,7 +674,7 @@
     }
 
     n = SSL_CTX_use_certificate_chain(mctx->ssl_ctx,
-                                      (char *)chain, 
+                                      (char *)chain,
                                       skip_first, NULL);
     if (n < 0) {
         ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
@@ -824,7 +824,7 @@
     if (SSL_X509_isSGC(cert)) {
         ap_log_error(APLOG_MARK, APLOG_INFO, 0, s,
                      "%s server certificate enables "
-                     "Server Gated Cryptography (SGC)", 
+                     "Server Gated Cryptography (SGC)",
                      ssl_asn1_keystr(type));
     }
 
@@ -1010,7 +1010,7 @@
     BOOL conflict = FALSE;
 
     /*
-     * Give out warnings when a server has HTTPS configured 
+     * Give out warnings when a server has HTTPS configured
      * for the HTTP port or vice versa
      */
     for (s = base_server; s; s = s->next) {
@@ -1061,11 +1061,11 @@
                          base_server,
                          "Init: SSL server IP/port conflict: "
                          "%s (%s:%d) vs. %s (%s:%d)",
-                         ssl_util_vhostid(p, s), 
+                         ssl_util_vhostid(p, s),
                          (s->defn_name ? s->defn_name : "unknown"),
                          s->defn_line_number,
                          ssl_util_vhostid(p, ps),
-                         (ps->defn_name ? ps->defn_name : "unknown"), 
+                         (ps->defn_name ? ps->defn_name : "unknown"),
                          ps->defn_line_number);
             conflict = TRUE;
             continue;
@@ -1249,7 +1249,7 @@
      */
     ssl_scache_kill(base_server);
 
-    /* 
+    /*
      * Destroy the temporary keys and params
      */
     ssl_tmp_keys_free(base_server);

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_io.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_io.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_io.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_io.c Thu Nov 10 07:20:05 2005
@@ -64,10 +64,10 @@
  * - The char* is placed in a brigade and returned
  *
  * Since connection-level input filters in httpd need to be able to
- * handle AP_MODE_GETLINE calls (namely identifying LF-terminated strings), 
+ * handle AP_MODE_GETLINE calls (namely identifying LF-terminated strings),
  * ssl_io_input_getline which will handle this special case.
  *
- * Due to AP_MODE_GETLINE and AP_MODE_SPECULATIVE, we may sometimes have 
+ * Due to AP_MODE_GETLINE and AP_MODE_SPECULATIVE, we may sometimes have
  * 'leftover' decoded data which must be setaside for the next read.  That
  * is currently handled by the char_buffer_{read|write} functions.  So,
  * ssl_io_input_read may be able to fulfill reads without invoking
@@ -81,7 +81,7 @@
  *
  */
 
-/* this custom BIO allows us to hook SSL_write directly into 
+/* this custom BIO allows us to hook SSL_write directly into
  * an apr_bucket_brigade and use transient buckets with the SSL
  * malloc-ed buffer, rather than copying into a mem BIO.
  * also allows us to pass the brigade as data is being written
@@ -141,7 +141,7 @@
     if (outctx->blen) {
         e = apr_bucket_transient_create(outctx->buffer, outctx->blen,
                                         outctx->bb->bucket_alloc);
-        /* we filled this buffer first so add it to the 
+        /* we filled this buffer first so add it to the
          * head of the brigade
          */
         APR_BRIGADE_INSERT_HEAD(outctx->bb, e);
@@ -182,7 +182,7 @@
      */
     return 1;
 }
-        
+
 static int bio_filter_out_read(BIO *bio, char *out, int outl)
 {
     /* this is never called */
@@ -213,7 +213,7 @@
     }
     else {
         /* pass along the encrypted data
-         * need to flush since we're using SSL's malloc-ed buffer 
+         * need to flush since we're using SSL's malloc-ed buffer
          * which will be overwritten once we leave here
          */
         apr_bucket *bucket = apr_bucket_transient_create(in, inl,
@@ -375,7 +375,7 @@
 {
     apr_size_t actual = 0;
     apr_status_t status = APR_SUCCESS;
- 
+
     while (!APR_BRIGADE_EMPTY(bb)) {
         apr_bucket *b = APR_BRIGADE_FIRST(bb);
         const char *str;
@@ -398,11 +398,11 @@
          * this sort of case (caller provided buffer) it
          * would be much more trivial for apr_bucket_consume
          * to do all the work that follows, based on the
-         * particular characteristics of the bucket we are 
+         * particular characteristics of the bucket we are
          * consuming here.
          */
         status = apr_bucket_read(b, &str, &str_len, block);
-        
+
         if (status != APR_SUCCESS) {
             if (APR_STATUS_IS_EOF(status)) {
                 /* This stream bucket was consumed */
@@ -471,7 +471,7 @@
      */
     if ((SSL_version(inctx->ssl) == SSL2_VERSION) || sslconn->is_proxy) {
         if (bio_filter_out_flush(inctx->bio_out) < 0) {
-            bio_filter_out_ctx_t *outctx = 
+            bio_filter_out_ctx_t *outctx =
                    (bio_filter_out_ctx_t *)(inctx->bio_out->ptr);
             inctx->rc = outctx->rc;
             return -1;
@@ -488,7 +488,7 @@
     if (APR_BRIGADE_EMPTY(inctx->bb)) {
 
         inctx->rc = ap_get_brigade(inctx->f->next, inctx->bb,
-                                   AP_MODE_READBYTES, block, 
+                                   AP_MODE_READBYTES, block,
                                    inl);
 
         /* If the read returns EAGAIN or success with an empty
@@ -515,12 +515,12 @@
         return (int)inl;
     }
 
-    if (APR_STATUS_IS_EAGAIN(inctx->rc) 
+    if (APR_STATUS_IS_EAGAIN(inctx->rc)
             || APR_STATUS_IS_EINTR(inctx->rc)) {
         BIO_set_retry_read(bio);
         return (int)inl;
     }
-        
+
     /* Unexpected errors and APR_EOF clean out the brigade.
      * Subsequent calls will return APR_EOF.
      */
@@ -625,7 +625,7 @@
              */
             if (APR_STATUS_IS_EAGAIN(inctx->rc)
                     || APR_STATUS_IS_EINTR(inctx->rc)) {
-                /* Already read something, return APR_SUCCESS instead. 
+                /* Already read something, return APR_SUCCESS instead.
                  * On win32 in particular, but perhaps on other kernels,
                  * a blocking call isn't 'always' blocking.
                  */
@@ -725,7 +725,7 @@
 
     while (tmplen > 0) {
         status = ssl_io_input_read(inctx, buf + offset, &tmplen);
-        
+
         if (status != APR_SUCCESS) {
             return status;
         }
@@ -815,7 +815,7 @@
         }
 
         ap_log_cerror(APLOG_MARK, APLOG_INFO, outctx->rc, c,
-                      "failed to write %" APR_SSIZE_T_FMT 
+                      "failed to write %" APR_SSIZE_T_FMT
                       " of %" APR_SIZE_T_FMT " bytes (%s)",
                       len - (apr_size_t)res, len, reason);
 
@@ -887,7 +887,7 @@
 /*
  *  Close the SSL part of the socket connection
  *  (called immediately _before_ the socket is closed)
- *  or called with 
+ *  or called with
  */
 static apr_status_t ssl_filter_io_shutdown(ssl_filter_ctx_t *filter_ctx,
                                            conn_rec *c,
@@ -974,7 +974,7 @@
     if (c->base_server->loglevel >= APLOG_INFO) {
         ap_log_cerror(APLOG_MARK, APLOG_INFO, 0, c,
                       "Connection closed to child %ld with %s shutdown "
-                      "(server %s)", 
+                      "(server %s)",
                       c->id, type, ssl_util_vhostid(c->pool, c->base_server));
     }
 
@@ -1006,7 +1006,7 @@
         SSL_free(filter_ctx->pssl);
         sslconn->ssl = filter_ctx->pssl = NULL;
     }
-  
+
     return APR_SUCCESS;
 }
 
@@ -1051,7 +1051,7 @@
                                        (filter_ctx->pbioWrite->ptr);
         apr_status_t rc = inctx->rc ? inctx->rc : outctx->rc ;
         ssl_err = SSL_get_error(filter_ctx->pssl, n);
-        
+
         if (ssl_err == SSL_ERROR_ZERO_RETURN) {
             /*
              * The case where the connection was closed before any data
@@ -1063,7 +1063,7 @@
         }
         else if (ssl_err == SSL_ERROR_WANT_READ) {
             /*
-             * This is in addition to what was present earlier. It is 
+             * This is in addition to what was present earlier. It is
              * borrowed from openssl_state_machine.c [mod_tls].
              * TBD.
              */
@@ -1117,7 +1117,7 @@
             /* leaving this log message as an error for the moment,
              * according to the mod_ssl docs:
              * "level optional_no_ca is actually against the idea
-             *  of authentication (but can be used to establish 
+             *  of authentication (but can be used to establish
              * SSL test pages, etc.)"
              * optional_no_ca doesn't appear to work as advertised
              * in 1.x
@@ -1205,20 +1205,20 @@
 
     /* Send the interim 101 response. */
     upgradebb = apr_brigade_create(r->pool, f->c->bucket_alloc);
-    
+
     ap_fputstrs(f->next, upgradebb, SWITCH_STATUS_LINE, CRLF,
                 UPGRADE_HEADER, CRLF, CONNECTION_HEADER, CRLF, CRLF, NULL);
 
     b = apr_bucket_flush_create(f->c->bucket_alloc);
     APR_BRIGADE_INSERT_TAIL(upgradebb, b);
-    
+
     rv = ap_pass_brigade(f->next, upgradebb);
     if (rv) {
         ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
                       "could not send interim 101 Upgrade response");
         return AP_FILTER_ERROR;
     }
-    
+
     ssl_init_ssl_connection(f->c);
 
     ap_log_rerror(APLOG_MARK, APLOG_INFO, 0, r,
@@ -1228,7 +1228,7 @@
     ssl = sslconn->ssl;
 
     /* XXX: Should replace SSL_set_state with SSL_renegotiate(ssl);
-     * However, this causes failures in perl-framework currently, 
+     * However, this causes failures in perl-framework currently,
      * perhaps pre-test if we have already negotiated?
      */
     SSL_set_accept_state(ssl);
@@ -1242,8 +1242,8 @@
         return AP_FILTER_ERROR;
     }
 
-    /* Now that we have initialized the ssl connection which added the ssl_io_filter, 
-       pass the brigade off to the connection based output filters so that the 
+    /* Now that we have initialized the ssl connection which added the ssl_io_filter,
+       pass the brigade off to the connection based output filters so that the
        request can complete encrypted */
     return ap_pass_brigade(f->c->output_filters, bb);
 
@@ -1276,7 +1276,7 @@
     }
 
     /* XXX: we don't currently support anything other than these modes. */
-    if (mode != AP_MODE_READBYTES && mode != AP_MODE_GETLINE && 
+    if (mode != AP_MODE_READBYTES && mode != AP_MODE_GETLINE &&
         mode != AP_MODE_SPECULATIVE && mode != AP_MODE_INIT) {
         return APR_ENOTIMPL;
     }
@@ -1300,9 +1300,9 @@
         return APR_SUCCESS;
     }
 
-    if (inctx->mode == AP_MODE_READBYTES || 
+    if (inctx->mode == AP_MODE_READBYTES ||
         inctx->mode == AP_MODE_SPECULATIVE) {
-        /* Protected from truncation, readbytes < MAX_SIZE_T 
+        /* Protected from truncation, readbytes < MAX_SIZE_T
          * FIXME: No, it's *not* protected.  -- jre */
         if (readbytes < len) {
             len = (apr_size_t)readbytes;
@@ -1367,8 +1367,8 @@
     while (!APR_BRIGADE_EMPTY(bb)) {
         apr_bucket *bucket = APR_BRIGADE_FIRST(bb);
 
-        /* If it is a flush or EOS, we need to pass this down. 
-         * These types do not require translation by OpenSSL.  
+        /* If it is a flush or EOS, we need to pass this down.
+         * These types do not require translation by OpenSSL.
          */
         if (APR_BUCKET_IS_EOS(bucket) || APR_BUCKET_IS_FLUSH(bucket)) {
             if (bio_filter_out_flush(filter_ctx->pbioWrite) < 0) {
@@ -1416,7 +1416,7 @@
             /* filter output */
             const char *data;
             apr_size_t len;
-            
+
             status = apr_bucket_read(bucket, &data, &len, rblock);
 
             if (APR_STATUS_IS_EAGAIN(status)) {
@@ -1464,7 +1464,7 @@
     apr_bucket_brigade *tempb;
     apr_off_t total = 0; /* total length buffered */
     int eos = 0; /* non-zero once EOS is seen */
-    
+
     /* Create the context which will be passed to the input filter;
      * containing a setaside pool and a brigade which constrain the
      * lifetime of the buffered data. */
@@ -1493,10 +1493,10 @@
                           "could not read request body for SSL buffer");
             return HTTP_INTERNAL_SERVER_ERROR;
         }
-        
+
         /* Iterate through the returned brigade: setaside each bucket
          * into the context's pool and move it into the brigade. */
-        for (e = APR_BRIGADE_FIRST(tempb); 
+        for (e = APR_BRIGADE_FIRST(tempb);
              e != APR_BRIGADE_SENTINEL(tempb) && !eos; e = next) {
             const char *data;
             apr_size_t len;
@@ -1514,19 +1514,19 @@
                 }
                 total += len;
             }
-                
+
             rv = apr_bucket_setaside(e, ctx->pool);
             if (rv != APR_SUCCESS) {
                 ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
                               "could not setaside bucket for SSL buffer");
                 return HTTP_INTERNAL_SERVER_ERROR;
             }
-            
+
             APR_BUCKET_REMOVE(e);
             APR_BRIGADE_INSERT_TAIL(ctx->bb, e);
         }
 
-        ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c, 
+        ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c,
                       "total of %" APR_OFF_T_FMT " bytes in buffer, eos=%d",
                       total, eos);
 
@@ -1587,7 +1587,7 @@
             apr_bucket *d = APR_BRIGADE_FIRST(ctx->bb);
 
             e = APR_BUCKET_PREV(e);
-            
+
             /* Unsplice the partitioned segment and move it into the
              * passed-in brigade; no convenient way to do this with
              * the APR_BRIGADE_* macros. */
@@ -1612,7 +1612,7 @@
 
     if (APR_BRIGADE_EMPTY(ctx->bb)) {
         apr_bucket *e = APR_BRIGADE_LAST(bb);
-        
+
         /* Ensure that the brigade is terminated by an EOS if the
          * buffered request body has been entirely consumed. */
         if (e == APR_BRIGADE_SENTINEL(bb) || !APR_BUCKET_IS_EOS(e)) {
@@ -1690,7 +1690,7 @@
 
     ap_register_input_filter  (ssl_io_filter, ssl_io_filter_input,  NULL, AP_FTYPE_CONNECTION + 5);
     ap_register_output_filter (ssl_io_filter, ssl_io_filter_output, NULL, AP_FTYPE_CONNECTION + 5);
-    
+
     ap_register_input_filter  (ssl_io_buffer, ssl_io_filter_buffer, NULL, AP_FTYPE_PROTOCOL - 1);
 
     return;

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_kernel.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_kernel.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_kernel.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_kernel.c Thu Nov 10 07:20:05 2005
@@ -74,7 +74,7 @@
          * with using SSL on this request.
          */
         sslconn->non_ssl_request = 0;
-        
+
 
         return HTTP_BAD_REQUEST;
     }
@@ -191,7 +191,7 @@
             return HTTP_UPGRADE_REQUIRED;
         }
 
-        ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r, 
+        ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                       "access to %s failed, reason: %s",
                       r->filename, "SSL connection required");
 
@@ -214,8 +214,8 @@
      * reconfigured parameter suite. But Apache's internal API processing
      * makes our life very hard here, because when internal sub-requests occur
      * we nevertheless should avoid multiple unnecessary SSL handshakes (they
-     * require extra network I/O and especially time to perform). 
-     * 
+     * require extra network I/O and especially time to perform).
+     *
      * But the optimization for filtering out the unnecessary handshakes isn't
      * obvious and trivial.  Especially because while Apache is in its
      * sub-request processing the client could force additional handshakes,
@@ -369,7 +369,7 @@
      * override of SSLVerifyClient
      *
      * We force a renegotiation if the reconfigured/new verify type is
-     * stronger than the currently active verify type. 
+     * stronger than the currently active verify type.
      *
      * The order is: none << optional_no_ca << optional << require
      *
@@ -498,7 +498,7 @@
      * handshake immediately; once the SSL library moves to the
      * "accept" state, it will reject the SSL packets which the client
      * is sending for the request body.
-     * 
+     *
      * To allow authentication to complete in this auth hook, the
      * solution used here is to fill a (bounded) buffer with the
      * request body, and then to reinject that request body later.
@@ -633,7 +633,7 @@
                          "Awaiting re-negotiation handshake");
 
             /* XXX: Should replace SSL_set_state with SSL_renegotiate(ssl);
-             * However, this causes failures in perl-framework currently, 
+             * However, this causes failures in perl-framework currently,
              * perhaps pre-test if we have already negotiated?
              */
             SSL_set_state(ssl, SSL_ST_ACCEPT);
@@ -686,7 +686,7 @@
                 X509_free(peercert);
             }
         }
-        
+
         /*
          * Also check that SSLCipherSuite has been enforced as expected.
          */
@@ -715,7 +715,7 @@
                                    r, (char *)dc->szUserName);
         if (val && val[0])
             r->user = val;
-    } 
+    }
 
     /*
      * Check SSLRequire boolean expressions
@@ -733,7 +733,7 @@
                               "SSL requirement expression: %s",
                               ssl_expr_get_error());
 
-            ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r, 
+            ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                           "access to %s failed, reason: %s",
                           r->filename, cp);
 
@@ -752,7 +752,7 @@
             ap_log_error(APLOG_MARK, APLOG_INFO, 0, r->server,
                          "Failed expression: %s", req->cpExpr);
 
-            ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r, 
+            ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                           "access to %s failed, reason: %s",
                           r->filename,
                           "SSL requirement expression not fulfilled "
@@ -841,13 +841,13 @@
      * - ssl not enabled
      * - client did not present a certificate
      */
-    if (!((sc->enabled == SSL_ENABLED_TRUE || sc->enabled == SSL_ENABLED_OPTIONAL) 
+    if (!((sc->enabled == SSL_ENABLED_TRUE || sc->enabled == SSL_ENABLED_OPTIONAL)
           && sslconn && sslconn->ssl && sslconn->client_cert) ||
         !(dc->nOptions & SSL_OPT_FAKEBASICAUTH) || r->user)
     {
         return DECLINED;
     }
-    
+
     if (!sslconn->client_dn) {
         X509_NAME *name = X509_get_subject_name(sslconn->client_cert);
         char *cp = X509_NAME_oneline(name, NULL, 0);
@@ -868,9 +868,9 @@
      * adding the string "xxj31ZMTZzkVA" as the password in the user file.
      * This is just the crypted variant of the word "password" ;-)
      */
-    auth_line = apr_pstrcat(r->pool, "Basic ", 
-                            ap_pbase64encode(r->pool, 
-                                             apr_pstrcat(r->pool, clientdn, 
+    auth_line = apr_pstrcat(r->pool, "Basic ",
+                            ap_pbase64encode(r->pool,
+                                             apr_pstrcat(r->pool, clientdn,
                                                          ":password", NULL)),
                             NULL);
     apr_table_set(r->headers_in, "Authorization", auth_line);
@@ -1013,7 +1013,7 @@
      * Annotate the SSI/CGI environment with standard SSL information
      */
     /* the always present HTTPS (=HTTP over SSL) flag! */
-    apr_table_setn(env, "HTTPS", "on"); 
+    apr_table_setn(env, "HTTPS", "on");
 
     /* standard SSL environment variables */
     if (dc->nOptions & SSL_OPT_STDENVVARS) {
@@ -1128,7 +1128,7 @@
     return (RSA *)mc->pTmpKeys[idx];
 }
 
-/* 
+/*
  * Hand out the already generated DH parameters...
  */
 DH *ssl_callback_TmpDH(SSL *ssl, int export, int keylen)
@@ -1211,7 +1211,7 @@
     }
 
     if (verify == SSL_CVERIFY_NONE) {
-        /* 
+        /*
          * SSLProxyVerify is either not configured or set to "none".
          * (this callback doesn't happen in the server context if SSLVerify
          *  is not configured or set to "none")
@@ -1494,7 +1494,7 @@
     dn = X509_NAME_oneline(name, name_buf, sizeof(name_buf));
 
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, s,
-                 SSLPROXY_CERT_CB_LOG_FMT "%s, sending %s", 
+                 SSLPROXY_CERT_CB_LOG_FMT "%s, sending %s",
                  sc->vhost_id, msg, dn ? dn : "-uknown-");
 }
 
@@ -1509,7 +1509,7 @@
     *pkey = info->x_pkey->dec_pkey; \
     EVP_PKEY_reference_inc(*pkey)
 
-int ssl_callback_proxy_cert(SSL *ssl, MODSSL_CLIENT_CERT_CB_ARG_TYPE **x509, EVP_PKEY **pkey) 
+int ssl_callback_proxy_cert(SSL *ssl, MODSSL_CLIENT_CERT_CB_ARG_TYPE **x509, EVP_PKEY **pkey)
 {
     conn_rec *c = (conn_rec *)SSL_get_app_data(ssl);
     server_rec *s = c->base_server;
@@ -1519,8 +1519,8 @@
     STACK_OF(X509_NAME) *ca_list;
     STACK_OF(X509_INFO) *certs = sc->proxy->pkp->certs;
     int i, j;
-    
-    ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, s, 
+
+    ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, s,
                  SSLPROXY_CERT_CB_LOG_FMT "entered",
                  sc->vhost_id);
 
@@ -1530,23 +1530,23 @@
                      "downstream server wanted client certificate "
                      "but none are configured", sc->vhost_id);
         return FALSE;
-    }                                                                     
+    }
 
     ca_list = SSL_get_client_CA_list(ssl);
 
     if (!ca_list || (sk_X509_NAME_num(ca_list) <= 0)) {
-        /* 
-         * downstream server didn't send us a list of acceptable CA certs, 
+        /*
+         * downstream server didn't send us a list of acceptable CA certs,
          * so we send the first client cert in the list.
-         */   
+         */
         info = sk_X509_INFO_value(certs, 0);
-        
+
         modssl_proxy_info_log(s, info, "no acceptable CA list");
 
         modssl_set_cert_info(info, x509, pkey);
 
         return TRUE;
-    }         
+    }
 
     for (i = 0; i < sk_X509_NAME_num(ca_list); i++) {
         ca_name = sk_X509_NAME_value(ca_list, i);
@@ -1569,7 +1569,7 @@
                  SSLPROXY_CERT_CB_LOG_FMT
                  "no client certificate found!?", sc->vhost_id);
 
-    return FALSE; 
+    return FALSE;
 }
 
 static void ssl_session_log(server_rec *s,

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_log.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_log.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_log.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_log.c Thu Nov 10 07:20:05 2005
@@ -56,7 +56,7 @@
 {
     int i = 0;
 
-    while (ssl_log_annotate[i].cpPattern != NULL 
+    while (ssl_log_annotate[i].cpPattern != NULL
            && ap_strcmp_match(error, ssl_log_annotate[i].cpPattern) != 0)
         i++;
 
@@ -90,12 +90,12 @@
         if (annotation) {
             ap_log_error(file, line, level, 0, s,
                          "SSL Library Error: %lu %s %s",
-                         e, err, annotation); 
+                         e, err, annotation);
         }
         else {
             ap_log_error(file, line, level, 0, s,
                          "SSL Library Error: %lu %s",
-                         e, err); 
+                         e, err);
         }
     }
 }

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_mutex.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_mutex.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_mutex.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_mutex.c Thu Nov 10 07:20:05 2005
@@ -39,7 +39,7 @@
     SSLModConfigRec *mc = myModConfig(s);
     apr_status_t rv;
 
-    if (mc->nMutexMode == SSL_MUTEXMODE_NONE) 
+    if (mc->nMutexMode == SSL_MUTEXMODE_NONE)
         return TRUE;
 
     if (mc->pMutex) {

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_pphrase.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_pphrase.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_pphrase.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_pphrase.c Thu Nov 10 07:20:05 2005
@@ -324,9 +324,9 @@
                     for (i=0; i < SSL_AIDX_MAX; i++) {
                         const char *key_id =
                             ssl_asn1_table_keyfmt(p, cpVHostID, i);
-                        ssl_asn1_t *asn1 = 
+                        ssl_asn1_t *asn1 =
                             ssl_asn1_table_get(mc->tPrivateKey, key_id);
-                    
+
                         if (asn1 && (asn1->source_mtime == pkey_mtime)) {
                             ap_log_error(APLOG_MARK, APLOG_INFO,
                                          0, pServ,
@@ -466,20 +466,20 @@
              * Log the type of reading
              */
             if (nPassPhraseDialogCur == 0) {
-                ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, pServ, 
+                ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, pServ,
                              "unencrypted %s private key - pass phrase not "
                              "required", an);
             }
             else {
                 if (cpPassPhraseCur != NULL) {
                     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0,
-                                 pServ, 
+                                 pServ,
                                  "encrypted %s private key - pass phrase "
                                  "requested", an);
                 }
                 else {
                     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0,
-                                 pServ, 
+                                 pServ,
                                  "encrypted %s private key - pass phrase"
                                  " reused", an);
                 }
@@ -566,7 +566,7 @@
                                    APR_NO_PIPE)) == APR_SUCCESS)) {
         char **args;
         const char *pname;
-        
+
         apr_tokenize_to_argv(progname, &args, p);
         pname = apr_pstrdup(p, args[0]);
         procnew = (apr_proc_t *)apr_pcalloc(p, sizeof(*procnew));
@@ -594,7 +594,7 @@
     buf[0]='\0';
     rc = apr_file_gets(buf, length, readtty);
     apr_file_puts(APR_EOL_STR, writetty);
-    
+
     if (rc != APR_SUCCESS || apr_file_eof(readtty)) {
         memset(buf, 0, length);
         return 1;  /* failure */
@@ -689,7 +689,7 @@
             ap_log_error(APLOG_MARK, APLOG_INFO, 0, s,
                          "Init: Requesting pass phrase via piped dialog");
         }
-        else { /* sc->server->pphrase_dialog_type == SSL_PPTYPE_BUILTIN */ 
+        else { /* sc->server->pphrase_dialog_type == SSL_PPTYPE_BUILTIN */
 #ifdef WIN32
             PEMerr(PEM_F_DEF_CALLBACK,PEM_R_PROBLEMS_GETTING_PASSWORD);
             memset(buf, 0, (unsigned int)bufsize);
@@ -736,11 +736,11 @@
         for (;;) {
             apr_file_puts(prompt, writetty);
             if (sc->server->pphrase_dialog_type == SSL_PPTYPE_PIPE) {
-                i = pipe_get_passwd_cb(buf, bufsize, "", FALSE); 
-            }  
+                i = pipe_get_passwd_cb(buf, bufsize, "", FALSE);
+            }
             else { /* sc->server->pphrase_dialog_type == SSL_PPTYPE_BUILTIN */
-                i = EVP_read_pw_string(buf, bufsize, "", FALSE); 
-            }  
+                i = EVP_read_pw_string(buf, bufsize, "", FALSE);
+            }
             if (i != 0) {
                 PEMerr(PEM_F_DEF_CALLBACK,PEM_R_PROBLEMS_GETTING_PASSWORD);
                 memset(buf, 0, (unsigned int)bufsize);

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_rand.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_rand.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_rand.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_rand.c Thu Nov 10 07:20:05 2005
@@ -62,7 +62,7 @@
                 /*
                  * seed in contents of an external file
                  */
-                if (apr_file_open(&fp, pRandSeed->cpPath, 
+                if (apr_file_open(&fp, pRandSeed->cpPath,
                                   APR_READ, APR_OS_DEFAULT, p) != APR_SUCCESS)
                     continue;
                 nDone += ssl_rand_feedfp(p, fp, pRandSeed->nBytes);
@@ -113,7 +113,7 @@
                 l = sizeof(my_seed);
                 RAND_seed((unsigned char *)&my_seed, l);
                 nDone += l;
-                
+
                 /*
                  * seed in some current state of the run-time stack (128 bytes)
                  */

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_vars.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_vars.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_vars.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_engine_vars.c Thu Nov 10 07:20:05 2005
@@ -117,7 +117,7 @@
 
         case 'R':
         case 'r':
-            if (strcEQ(var, "REQUEST_METHOD")) 
+            if (strcEQ(var, "REQUEST_METHOD"))
                 result = r->method;
             else if (strcEQ(var, "REQUEST_SCHEME"))
                 result = ap_http_scheme(r);
@@ -126,7 +126,7 @@
             else if (strcEQ(var, "REQUEST_FILENAME"))
                 result = r->filename;
             else if (strcEQ(var, "REMOTE_HOST"))
-                result = ap_get_remote_host(r->connection, r->per_dir_config, 
+                result = ap_get_remote_host(r->connection, r->per_dir_config,
                                             REMOTE_NAME, NULL);
             else if (strcEQ(var, "REMOTE_IDENT"))
                 result = ap_get_remote_logname(r);
@@ -137,7 +137,7 @@
         case 'S':
         case 's':
             if (strcEQn(var, "SSL", 3)) break; /* shortcut common case */
-            
+
             if (strcEQ(var, "SERVER_ADMIN"))
                 result = r->server->server_admin;
             else if (strcEQ(var, "SERVER_NAME"))
@@ -149,7 +149,7 @@
             else if (strcEQ(var, "SCRIPT_FILENAME"))
                 result = r->filename;
             break;
-            
+
         default:
             if (strcEQ(var, "PATH_INFO"))
                 result = r->path_info;
@@ -172,7 +172,7 @@
      */
     if (result == NULL && c != NULL) {
         SSLConnRec *sslconn = myConnConfig(c);
-        if (strlen(var) > 4 && strcEQn(var, "SSL_", 4) 
+        if (strlen(var) > 4 && strcEQn(var, "SSL_", 4)
             && sslconn && sslconn->ssl)
             result = ssl_var_lookup_ssl(p, c, var+4);
         else if (strcEQ(var, "REMOTE_ADDR"))
@@ -357,7 +357,7 @@
     }
     else if (strcEQ(var, "A_SIG")) {
         nid = OBJ_obj2nid((ASN1_OBJECT *)X509_get_signature_algorithm(xs));
-        result = apr_pstrdup(p, 
+        result = apr_pstrdup(p,
                              (nid == NID_undef) ? "UNKNOWN" : OBJ_nid2ln(nid));
         resdup = FALSE;
     }
@@ -476,7 +476,7 @@
 
     /* Fail if the time isn't a valid ASN.1 UTCTIME; RFC3280 mandates
      * that the seconds digits are present even though ASN.1
-     * doesn't. */    
+     * doesn't. */
     if (tm->length < 11 || !ASN1_UTCTIME_check(tm)) {
         return apr_pstrdup(p, "0");
     }
@@ -493,7 +493,7 @@
     if (apr_time_exp_gmt_get(&then, &exp) != APR_SUCCESS) {
         return apr_pstrdup(p, "0");
     }
-    
+
     diff = (long)((apr_time_sec(then) - apr_time_sec(now)) / (60*60*24));
 
     return diff > 0 ? apr_ltoa(p, diff) : apr_pstrdup(p, "0");
@@ -589,7 +589,7 @@
 
 static char *ssl_var_lookup_ssl_cipher(apr_pool_t *p, conn_rec *c, char *var)
 {
-    SSLConnRec *sslconn = myConnConfig(c);    
+    SSLConnRec *sslconn = myConnConfig(c);
     char *result;
     BOOL resdup;
     int usekeysize, algkeysize;
@@ -670,7 +670,7 @@
     ASN1_OBJECT *oid;
     int count = 0, j;
     char *result = NULL;
-    
+
     if (!sslconn || !sslconn->ssl) {
         return NULL;
     }
@@ -686,7 +686,7 @@
     if (xs == NULL) {
         return NULL;
     }
-    
+
     count = X509_get_ext_count(xs);
 
     for (j = 0; j < count; j++) {

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_eval.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_eval.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_eval.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_eval.c Thu Nov 10 07:20:05 2005
@@ -285,7 +285,7 @@
     apr_size_t len;
     apr_finfo_t finfo;
 
-    if (apr_file_open(&fp, filename, APR_READ|APR_BUFFERED, 
+    if (apr_file_open(&fp, filename, APR_READ|APR_BUFFERED,
                       APR_OS_DEFAULT, r->pool) != APR_SUCCESS) {
         ssl_expr_error = "Cannot open file";
         return "";

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_parse.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_parse.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_parse.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_parse.c Thu Nov 10 07:20:05 2005
@@ -1,5 +1,5 @@
 #ifndef lint
-static char const 
+static char const
 ssl_expr_yyrcsid[] = "$FreeBSD: src/usr.bin/yacc/skeleton.c,v 1.28.2.1 2001/07/19 05:46:39 peter Exp $";
 #endif
 #include <stdlib.h>
@@ -530,9 +530,9 @@
 break;
 case 26:
 #line 121 "ssl_expr_parse.y"
-{ 
+{
                 ap_regex_t *regex;
-                if ((regex = ap_pregcomp(ssl_expr_info.pool, ssl_expr_yyvsp[0].cpVal, 
+                if ((regex = ap_pregcomp(ssl_expr_info.pool, ssl_expr_yyvsp[0].cpVal,
                                          AP_REG_EXTENDED|AP_REG_NOSUB)) == NULL) {
                     ssl_expr_error = "Failed to compile regular expression";
                     YYERROR;
@@ -544,7 +544,7 @@
 #line 130 "ssl_expr_parse.y"
 {
                 ap_regex_t *regex;
-                if ((regex = ap_pregcomp(ssl_expr_info.pool, ssl_expr_yyvsp[0].cpVal, 
+                if ((regex = ap_pregcomp(ssl_expr_info.pool, ssl_expr_yyvsp[0].cpVal,
                                          AP_REG_EXTENDED|AP_REG_NOSUB|AP_REG_ICASE)) == NULL) {
                     ssl_expr_error = "Failed to compile regular expression";
                     YYERROR;
@@ -554,7 +554,7 @@
 break;
 case 28:
 #line 141 "ssl_expr_parse.y"
-{ 
+{
                ssl_expr *args = ssl_expr_make(op_ListElement, ssl_expr_yyvsp[-1].cpVal, NULL);
                ssl_expr_yyval.exVal = ssl_expr_make(op_Func, "file", args);
             }

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_scan.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_scan.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_scan.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_expr_scan.c Thu Nov 10 07:20:05 2005
@@ -463,16 +463,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-/*                      _             _ 
- *  _ __ ___   ___   __| |    ___ ___| |  
- * | '_ ` _ \ / _ \ / _` |   / __/ __| |  
+/*                      _             _
+ *  _ __ ___   ___   __| |    ___ ___| |
+ * | '_ ` _ \ / _ \ / _` |   / __/ __| |
  * | | | | | | (_) | (_| |   \__ \__ \ | mod_ssl - Apache Interface to OpenSSL
  * |_| |_| |_|\___/ \__,_|___|___/___/_| http://www.modssl.org/
- *                      |_____|         
+ *                      |_____|
  *  ssl_expr_scan.l
  *  Expression Scanner
  */
-/* ``Killing for peace is 
+/* ``Killing for peace is
 like fucking for virginity.''
 -- Unknown  */
 /*  _________________________________________________________________
@@ -653,7 +653,7 @@
 
 #line 58 "ssl_expr_scan.l"
 
-  
+
   char  caStr[MAX_STR_LEN];
   char *cpStr = NULL;
   char  caRegex[MAX_STR_LEN];
@@ -745,7 +745,7 @@
 case 1:
 YY_RULE_SETUP
 #line 69 "ssl_expr_scan.l"
-{ 
+{
     /* NOP */
 }
         YY_BREAK
@@ -1059,7 +1059,7 @@
 case 46:
 YY_RULE_SETUP
 #line 208 "ssl_expr_scan.l"
-{ 
+{
     return yytext[0];
 }
         YY_BREAK
@@ -1965,7 +1965,7 @@
     int n;
 
     if ((n = MIN(max_size, ssl_expr_info.inputbuf
-                         + ssl_expr_info.inputlen 
+                         + ssl_expr_info.inputlen
                          - ssl_expr_info.inputptr)) <= 0)
         return YY_NULL;
     memcpy(buf, ssl_expr_info.inputptr, n);

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache.c Thu Nov 10 07:20:05 2005
@@ -162,7 +162,7 @@
     else if (sc->mc->nSessionCacheMode == SSL_SCMODE_DC)
         ssl_scache_dc_status(r, flags, r->pool);
 #endif
-    
+
     ap_rputs("</td></tr>\n", r);
     ap_rputs("</table>\n", r);
     return OK;

Modified: httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache_dbm.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache_dbm.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache_dbm.c (original)
+++ httpd/httpd/branches/2.2.x/modules/ssl/ssl_scache_dbm.c Thu Nov 10 07:20:05 2005
@@ -209,7 +209,7 @@
     dbmkey.dptr  = (char *)id;
     dbmkey.dsize = idlen;
 
-    /* and fetch it from the DBM file 
+    /* and fetch it from the DBM file
      * XXX: Should we open the dbm against r->pool so the cleanup will
      * do the apr_dbm_close? This would make the code a bit cleaner.
      */
@@ -244,7 +244,7 @@
         return NULL;
     }
     /* Cast needed, ucpData may be const */
-    memcpy((unsigned char *)ucpData, 
+    memcpy((unsigned char *)ucpData,
            (char *)dbmval.dptr + sizeof(time_t), nData);
     memcpy(&expiry, dbmval.dptr, sizeof(time_t));
 
@@ -347,7 +347,7 @@
 
         /* pass 1: scan DBM database */
         keyidx = 0;
-        if ((rv = apr_dbm_open(&dbm, mc->szSessionCacheDataFile, 
+        if ((rv = apr_dbm_open(&dbm, mc->szSessionCacheDataFile,
                                APR_DBM_RWCREATE,SSL_DBM_FILE_MODE,
                                p)) != APR_SUCCESS) {
             ap_log_error(APLOG_MARK, APLOG_ERR, rv, s,