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 [3/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/proxy/balancers/mod_lbmethod_heartbeat.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_heartbeat.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_heartbeat.c (original)
+++ httpd/httpd/trunk/modules/proxy/balancers/mod_lbmethod_heartbeat.c Fri Sep 23 13:39:32 2011
@@ -64,7 +64,7 @@ argstr_to_table(apr_pool_t *p, char *str
     char *key;
     char *value;
     char *strtok_state;
-    
+
     key = apr_strtok(str, "&", &strtok_state);
     while (key) {
         value = strchr(key, '=');
@@ -158,12 +158,12 @@ static apr_status_t readfile_heartbeats(
             if (!t) {
                 continue;
             }
-            
+
             ip = apr_pstrndup(pool, buf, t - buf);
             t++;
 
             server = apr_hash_get(servers, ip, APR_HASH_KEY_STRING);
-            
+
             if (server == NULL) {
                 server = apr_pcalloc(pool, sizeof(hb_server_t));
                 server->ip = ip;
@@ -172,7 +172,7 @@ static apr_status_t readfile_heartbeats(
 
                 apr_hash_set(servers, server->ip, APR_HASH_KEY_STRING, server);
             }
-            
+
             apr_table_clear(hbt);
 
             argstr_to_table(pool, apr_pstrdup(pool, t), hbt);
@@ -194,9 +194,9 @@ static apr_status_t readfile_heartbeats(
             }
 
             if (server->busy == 0 && server->ready != 0) {
-                /* Server has zero threads active, but lots of them ready, 
-                 * it likely just started up, so lets /4 the number ready, 
-                 * to prevent us from completely flooding it with all new 
+                /* Server has zero threads active, but lots of them ready,
+                 * it likely just started up, so lets /4 the number ready,
+                 * to prevent us from completely flooding it with all new
                  * requests.
                  */
                 server->ready = server->ready / 4;
@@ -266,7 +266,7 @@ static proxy_worker *find_best_hb(proxy_
     apr_pool_t *tpool;
     apr_hash_t *servers;
 
-    lb_hb_ctx_t *ctx = 
+    lb_hb_ctx_t *ctx =
         ap_get_module_config(r->server->module_config,
                              &lbmethod_heartbeat_module);
 
@@ -354,7 +354,7 @@ static int lb_hb_init(apr_pool_t *p, apr
     unsigned int num;
     lb_hb_ctx_t *ctx = ap_get_module_config(s->module_config,
                                             &lbmethod_heartbeat_module);
-    
+
     /* do nothing on first call */
     if (ap_state_query(AP_SQ_MAIN_STATE) == AP_SQ_MS_CREATE_PRE_CONFIG)
         return OK;
@@ -389,9 +389,9 @@ static void register_hooks(apr_pool_t *p
 static void *lb_hb_create_config(apr_pool_t *p, server_rec *s)
 {
     lb_hb_ctx_t *ctx = (lb_hb_ctx_t *) apr_palloc(p, sizeof(lb_hb_ctx_t));
-    
+
     ctx->path = ap_server_root_relative(p, "logs/hb.dat");
-    
+
     return ctx;
 }
 
@@ -420,7 +420,7 @@ static const char *cmd_lb_hb_storage(cmd
                                          &lbmethod_heartbeat_module);
 
     const char *err = ap_check_cmd_context(cmd, GLOBAL_ONLY);
-    
+
     if (err != NULL) {
         return err;
     }

Modified: httpd/httpd/trunk/modules/proxy/examples/mod_lbmethod_rr.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/examples/mod_lbmethod_rr.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/examples/mod_lbmethod_rr.c (original)
+++ httpd/httpd/trunk/modules/proxy/examples/mod_lbmethod_rr.c Fri Sep 23 13:39:32 2011
@@ -52,7 +52,7 @@ static proxy_worker *find_best_roundrobi
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy: Entering roundrobin for BALANCER %s (%d)",
                  balancer->name, (int)getpid());
-    
+
     /* The index of the candidate last chosen is stored in ctx->index */
     if (!balancer->context) {
         /* UGLY */

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy.c Fri Sep 23 13:39:32 2011
@@ -281,7 +281,7 @@ static const char *set_balancer_param(pr
             return "stickysession length must be < 64 characters";
         PROXY_STRNCPY(balancer->s->sticky_path, val);
         PROXY_STRNCPY(balancer->s->sticky, val);
-        
+
         if ((path = strchr((char *)balancer->s->sticky, '|'))) {
             *path++ = '\0';
             PROXY_STRNCPY(balancer->s->sticky_path, path);
@@ -369,7 +369,7 @@ static const char *set_balancer_param(pr
     else if (!strcasecmp(key, "nonce")) {
         if (!strcasecmp(val, "None")) {
             *balancer->s->nonce = '\0';
-        } 
+        }
         else {
             if (strlen(val) > sizeof(balancer->s->nonce)-1) {
                 return "Provided nonce is too large";

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_ajp.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_ajp.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_ajp.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_ajp.c Fri Sep 23 13:39:32 2011
@@ -482,7 +482,7 @@ static int ap_proxy_ajp_request(apr_pool
                         }
                         else {
                             apr_status_t rv;
-    
+
                             /* Handle the case where the error document is itself reverse
                              * proxied and was successful. We must maintain any previous
                              * error status so that an underlying error (eg HTTP_NOT_FOUND)
@@ -493,11 +493,11 @@ static int ap_proxy_ajp_request(apr_pool
                                 r->status = original_status;
                                 r->status_line = original_status_line;
                             }
-    
+
                             e = apr_bucket_transient_create(send_body_chunk_buff, size,
                                                         r->connection->bucket_alloc);
                             APR_BRIGADE_INSERT_TAIL(output_brigade, e);
-    
+
                             if ((conn->worker->s->flush_packets == flush_on) ||
                                 ((conn->worker->s->flush_packets == flush_auto) &&
                                 ((rv = apr_poll(conn_poll, 1, &conn_poll_fd,

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_balancer.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_balancer.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_balancer.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_balancer.c Fri Sep 23 13:39:32 2011
@@ -846,7 +846,7 @@ static void push2table(const char *input
     char *args;
     char *tok, *val;
     char *key;
-    
+
     if (input == NULL) {
         return;
     }
@@ -943,7 +943,7 @@ static int balancer_handler(request_rec 
         apr_bucket_brigade *ib;
         apr_size_t len = 1024;
         char *buf = apr_pcalloc(r->pool, len+1);
-        
+
         ib = apr_brigade_create(r->connection->pool, r->connection->bucket_alloc);
         rv = ap_get_brigade(r->input_filters, ib, AP_MODE_READBYTES,
                                 APR_BLOCK_READ, len);

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_connect.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_connect.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_connect.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_connect.c Fri Sep 23 13:39:32 2011
@@ -71,7 +71,7 @@ static void *merge_config(apr_pool_t *p,
     c->allowed_connect_ports = apr_array_append(p,
                                                 base->allowed_connect_ports,
                                                 overrides->allowed_connect_ports);
-    
+
     return c;
 }
 
@@ -118,7 +118,7 @@ static int allowed_port(connect_conf *co
 {
     int i;
     port_range *list = (port_range *) conf->allowed_connect_ports->elts;
-    
+
     if (apr_is_empty_array(conf->allowed_connect_ports)){
         return port == APR_URI_HTTPS_DEFAULT_PORT
                || port == APR_URI_SNEWS_DEFAULT_PORT;
@@ -400,7 +400,7 @@ static int proxy_connect_handler(request
         nbytes = apr_snprintf(buffer, sizeof(buffer),
                               "HTTP/1.0 200 Connection Established" CRLF);
         ap_xlate_proto_to_ascii(buffer, nbytes);
-        ap_fwrite(c->output_filters, bb, buffer, nbytes); 
+        ap_fwrite(c->output_filters, bb, buffer, nbytes);
         nbytes = apr_snprintf(buffer, sizeof(buffer),
                               "Proxy-agent: %s" CRLF CRLF,
                               ap_get_server_banner());
@@ -439,7 +439,7 @@ static int proxy_connect_handler(request
     while (1) { /* Infinite loop until error (one side closes the connection) */
         if ((rv = apr_pollset_poll(pollset, -1, &pollcnt, &signalled))
             != APR_SUCCESS) {
-            if (APR_STATUS_IS_EINTR(rv)) { 
+            if (APR_STATUS_IS_EINTR(rv)) {
                 continue;
             }
             apr_socket_close(sock);

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_express.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_express.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_express.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_express.c Fri Sep 23 13:39:32 2011
@@ -44,7 +44,7 @@ static const char *set_dbmfile(cmd_parms
 static const char *set_dbmtype(cmd_parms *cmd,
                                void *dconf,
                                const char *arg)
-{    
+{
     express_server_conf *sconf;
     sconf = ap_get_module_config(cmd->server->module_config, &proxy_express_module);
 
@@ -58,7 +58,7 @@ static const char *set_enabled(cmd_parms
 {
     express_server_conf *sconf;
     sconf = ap_get_module_config(cmd->server->module_config, &proxy_express_module);
-    
+
     sconf->enabled = flag;
 
     return NULL;
@@ -67,20 +67,20 @@ static const char *set_enabled(cmd_parms
 static void *server_create(apr_pool_t *p, server_rec *s)
 {
     express_server_conf *a;
-    
+
     a = (express_server_conf *)apr_pcalloc(p, sizeof(express_server_conf));
-    
+
     a->dbmfile = NULL;
     a->dbmtype = "default";
     a->enabled = 0;
-    
+
     return (void *)a;
 }
 
 static void *server_merge(apr_pool_t *p, void *basev, void *overridesv)
 {
     express_server_conf *a, *base, *overrides;
-    
+
     a         = (express_server_conf *)apr_pcalloc(p,
                                                    sizeof(express_server_conf));
     base      = (express_server_conf *)basev;
@@ -137,7 +137,7 @@ static int xlate_name(request_rec *r)
     if (rv != APR_SUCCESS) {
         return DECLINED;
     }
- 
+
     name = ap_get_server_name(r);
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy_express: looking for %s", name);

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_fcgi.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_fcgi.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_fcgi.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_fcgi.c Fri Sep 23 13:39:32 2011
@@ -85,7 +85,7 @@ static int proxy_fcgi_canon(request_rec 
     else {
         return DECLINED;
     }
-    
+
     ap_log_error(APLOG_MARK, APLOG_TRACE1, 0, r->server,
                  "proxy: FCGI: canonicalising URL %s", url);
 
@@ -95,9 +95,9 @@ static int proxy_fcgi_canon(request_rec 
                       "error parsing URL %s: %s", url, err);
         return HTTP_BAD_REQUEST;
     }
-        
+
     apr_snprintf(sport, sizeof(sport), ":%d", port);
-        
+
     if (ap_strchr_c(host, ':')) {
         /* if literal IPv6 address */
         host = apr_pstrcat(r->pool, "[", host, "]", NULL);
@@ -246,7 +246,7 @@ static apr_status_t send_begin_request(p
     fill_in_header(&header, FCGI_BEGIN_REQUEST, request_id, sizeof(abrb), 0);
 
     brb.roleB1 = ((FCGI_RESPONDER >> 8) & 0xff);
-    brb.roleB0 = ((FCGI_RESPONDER) & 0xff); 
+    brb.roleB0 = ((FCGI_RESPONDER) & 0xff);
     brb.flags = FCGI_KEEP_CONN;
     brb.reserved[0] = 0;
     brb.reserved[1] = 0;
@@ -265,7 +265,7 @@ static apr_status_t send_begin_request(p
     return send_data(conn, vec, 2, &len, 1);
 }
 
-static apr_status_t send_environment(proxy_conn_rec *conn, request_rec *r, 
+static apr_status_t send_environment(proxy_conn_rec *conn, request_rec *r,
                                      int request_id)
 {
     const apr_array_header_t *envarr;
@@ -350,7 +350,7 @@ static apr_status_t send_environment(pro
 
     for (i = 0; i < numenv; ++i) {
         apr_size_t keylen, vallen;
-       
+
         if (! elts[i].key) {
             continue;
         }
@@ -494,7 +494,7 @@ static void dump_header_to_log(request_r
     memset(hex_line, 0, sizeof(hex_line));
 
     while (posn < length) {
-        unsigned char c = fheader[posn]; 
+        unsigned char c = fheader[posn];
 
         if (i >= 20) {
             i = 0;
@@ -669,11 +669,11 @@ static apr_status_t dispatch(proxy_conn_
             }
 
             dump_header_to_log(r, farray, readbuflen);
-            
+
             if (readbuflen != FCGI_HEADER_LEN) {
                 ap_log_error(APLOG_MARK, APLOG_ERR, 0, r->server,
                              "proxy: FCGI: Failed to read entire header "
-                             "got %" APR_SIZE_T_FMT " wanted %d", 
+                             "got %" APR_SIZE_T_FMT " wanted %d",
                              readbuflen, FCGI_HEADER_LEN);
                 rv = APR_EINVAL;
                 break;
@@ -881,13 +881,13 @@ static int fcgi_do_request(apr_pool_t *p
                            char *url, char *server_portstr)
 {
     /* Request IDs are arbitrary numbers that we assign to a
-     * single request. This would allow multiplex/pipelinig of 
-     * multiple requests to the same FastCGI connection, but 
+     * single request. This would allow multiplex/pipelinig of
+     * multiple requests to the same FastCGI connection, but
      * we don't support that, and always use a value of '1' to
      * keep things simple. */
-    int request_id = 1; 
+    int request_id = 1;
     apr_status_t rv;
-   
+
     /* Step 1: Send FCGI_BEGIN_REQUEST */
     rv = send_begin_request(conn, request_id);
     if (rv != APR_SUCCESS) {
@@ -897,7 +897,7 @@ static int fcgi_do_request(apr_pool_t *p
         conn->close = 1;
         return HTTP_SERVICE_UNAVAILABLE;
     }
-    
+
     /* Step 2: Send Environment via FCGI_PARAMS */
     rv = send_environment(conn, r, request_id);
     if (rv != APR_SUCCESS) {
@@ -955,7 +955,7 @@ static int proxy_fcgi_handler(request_re
                      "proxy: FCGI: declining URL %s", url);
         return DECLINED;
     }
-    
+
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                  "proxy: FCGI: serving URL %s", url);
 

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_fdpass.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_fdpass.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_fdpass.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_fdpass.c Fri Sep 23 13:39:32 2011
@@ -44,7 +44,7 @@ static int proxy_fdpass_canon(request_re
     else {
         return DECLINED;
     }
-    
+
     path = ap_server_root_relative(r->pool, url);
 
     r->filename = apr_pstrcat(r->pool, "proxy:fd://", path, NULL);
@@ -89,7 +89,7 @@ static apr_status_t socket_connect_un(ap
             return rv;
         }
     }
-    
+
     if (rv == -1 && errno != EISCONN) {
         return errno;
     }
@@ -137,7 +137,7 @@ static apr_status_t send_socket(apr_pool
     struct cmsghdr *cmsg;
     struct iovec iov;
     char b = '\0';
-    
+
     rv = apr_os_sock_get(&rawsock, outbound);
     if (rv != APR_SUCCESS) {
         return rv;
@@ -147,7 +147,7 @@ static apr_status_t send_socket(apr_pool
     if (rv != APR_SUCCESS) {
         return rv;
     }
-    
+
     memset(&msg, 0, sizeof(msg));
 
     msg.msg_iov = &iov;
@@ -172,7 +172,7 @@ static apr_status_t send_socket(apr_pool
         return errno;
     }
 
-    
+
     return APR_SUCCESS;
 }
 
@@ -232,8 +232,8 @@ static int proxy_fdpass_handler(request_
 
     {
         apr_socket_t *dummy;
-        /* Create a dummy unconnected socket, and set it as the one we were 
-         * connected to, so that when the core closes it, it doesn't close 
+        /* Create a dummy unconnected socket, and set it as the one we were
+         * connected to, so that when the core closes it, it doesn't close
          * the tcp connection to the client.
          */
         rv = apr_socket_create(&dummy, APR_INET, SOCK_STREAM, APR_PROTO_TCP,
@@ -245,8 +245,8 @@ static int proxy_fdpass_handler(request_
         }
         ap_set_core_module_config(r->connection->conn_config, dummy);
     }
-    
-    
+
+
     return OK;
 }
 
@@ -260,7 +260,7 @@ static int standard_flush(request_rec *r
 
     bb = apr_brigade_create(r->pool, r->connection->bucket_alloc);
     e = apr_bucket_flush_create(r->connection->bucket_alloc);
-    
+
     APR_BRIGADE_INSERT_TAIL(bb, e);
 
     status = ap_pass_brigade(r->output_filters, bb);

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_ftp.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_ftp.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_ftp.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_ftp.c Fri Sep 23 13:39:32 2011
@@ -146,7 +146,7 @@ static const char *ftp_escape_globbingch
 {
     char *ret;
     char *d;
-    
+
     if (!dconf->ftp_escape_wildcards) {
         return path;
     }
@@ -1008,9 +1008,9 @@ static int proxy_ftp_handler(request_rec
         && (password = ap_pbase64decode(r->pool, password))[0] != ':') {
         /* Check the decoded string for special characters. */
         if (!ftp_check_string(password)) {
-            return ap_proxyerror(r, HTTP_BAD_REQUEST, 
+            return ap_proxyerror(r, HTTP_BAD_REQUEST,
                                  "user credentials contained invalid character");
-        } 
+        }
         /*
          * Note that this allocation has to be made from r->connection->pool
          * because it has the lifetime of the connection.  The other

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_http.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_http.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_http.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_http.c Fri Sep 23 13:39:32 2011
@@ -283,7 +283,7 @@ static int pass_brigade(apr_bucket_alloc
             return APR_STATUS_IS_TIMEUP(status) ? HTTP_GATEWAY_TIME_OUT : HTTP_BAD_GATEWAY;
         }
         else {
-            return HTTP_BAD_REQUEST; 
+            return HTTP_BAD_REQUEST;
         }
     }
     apr_brigade_cleanup(bb);
@@ -439,7 +439,7 @@ static int stream_reqbody_cl(apr_pool_t 
 
         add_cl(p, bucket_alloc, header_brigade, old_cl_val);
         status = apr_strtoff(&cl_val, old_cl_val, &endstr, 10);
-        
+
         if (status || *endstr || endstr == old_cl_val || cl_val < 0) {
             ap_log_rerror(APLOG_MARK, APLOG_ERR, status, r,
                           "proxy: could not parse request Content-Length (%s)",
@@ -719,7 +719,7 @@ int ap_proxy_http_request(apr_pool_t *p,
     proxy_dir_conf *dconf;
     conn_rec *origin = p_conn->connection;
     int do_100_continue;
-    
+
     dconf = ap_get_module_config(r->per_dir_config, &proxy_module);
     header_brigade = apr_brigade_create(p, origin->bucket_alloc);
 
@@ -735,7 +735,7 @@ int ap_proxy_http_request(apr_pool_t *p,
                        && ap_request_has_body(r)
                        && (PROXYREQ_REVERSE == r->proxyreq)
                        && !(apr_table_get(r->subprocess_env, "force-proxy-request-1.0")));
-    
+
     if (apr_table_get(r->subprocess_env, "force-proxy-request-1.0")) {
         /*
          * According to RFC 2616 8.2.3 we are not allowed to forward an
@@ -762,14 +762,14 @@ int ap_proxy_http_request(apr_pool_t *p,
     if (dconf->preserve_host == 0) {
         if (ap_strchr_c(uri->hostname, ':')) { /* if literal IPv6 address */
             if (uri->port_str && uri->port != DEFAULT_HTTP_PORT) {
-                buf = apr_pstrcat(p, "Host: [", uri->hostname, "]:", 
+                buf = apr_pstrcat(p, "Host: [", uri->hostname, "]:",
                                   uri->port_str, CRLF, NULL);
             } else {
                 buf = apr_pstrcat(p, "Host: [", uri->hostname, "]", CRLF, NULL);
             }
         } else {
             if (uri->port_str && uri->port != DEFAULT_HTTP_PORT) {
-                buf = apr_pstrcat(p, "Host: ", uri->hostname, ":", 
+                buf = apr_pstrcat(p, "Host: ", uri->hostname, ":",
                                   uri->port_str, CRLF, NULL);
             } else {
                 buf = apr_pstrcat(p, "Host: ", uri->hostname, CRLF, NULL);
@@ -966,7 +966,7 @@ int ap_proxy_http_request(apr_pool_t *p,
      * input_brigade and jump past all of the request body logic...
      * Reading anything with ap_get_brigade is likely to consume the
      * main request's body or read beyond EOS - which would be unplesant.
-     * 
+     *
      * An exception: when a kept_body is present, then subrequest CAN use
      * pass request bodies, and we DONT skip the body.
      */
@@ -1429,10 +1429,10 @@ apr_status_t ap_proxy_http_process_respo
                        && ap_request_has_body(r)
                        && (PROXYREQ_REVERSE == r->proxyreq)
                        && !(apr_table_get(r->subprocess_env, "force-proxy-request-1.0")));
-    
+
     bb = apr_brigade_create(p, c->bucket_alloc);
     pass_bb = apr_brigade_create(p, c->bucket_alloc);
-    
+
     /* Setup for 100-Continue timeout if appropriate */
     if (do_100_continue) {
         apr_socket_timeout_get(backend->sock, &old_timeout);
@@ -1497,7 +1497,7 @@ apr_status_t ap_proxy_http_process_respo
                 ap_log_rerror(APLOG_MARK, APLOG_DEBUG, 0, r,
                               "proxy: Closing connection to client because"
                               " reading from backend server %s:%d failed."
-                              " Number of keepalives %i", backend->hostname, 
+                              " Number of keepalives %i", backend->hostname,
                               backend->port, c->keepalives);
                 ap_proxy_backend_broke(r, bb);
                 /*
@@ -2000,7 +2000,7 @@ apr_status_t ap_proxy_http_process_respo
     /* See define of AP_MAX_INTERIM_RESPONSES for why */
     if (interim_response >= AP_MAX_INTERIM_RESPONSES) {
         return ap_proxyerror(r, HTTP_BAD_GATEWAY,
-                             apr_psprintf(p, 
+                             apr_psprintf(p,
                              "Too many (%d) interim responses from origin server",
                              interim_response));
     }

Modified: httpd/httpd/trunk/modules/proxy/mod_proxy_scgi.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_proxy_scgi.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_proxy_scgi.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_proxy_scgi.c Fri Sep 23 13:39:32 2011
@@ -143,7 +143,7 @@ static const apr_bucket_type_t bucket_ty
     "SOCKET_EX", 5, APR_BUCKET_DATA,
     apr_bucket_destroy_noop,
     bucket_socket_ex_read,
-    apr_bucket_setaside_notimpl, 
+    apr_bucket_setaside_notimpl,
     apr_bucket_split_notimpl,
     apr_bucket_copy_notimpl
 };
@@ -189,9 +189,9 @@ static int scgi_canon(request_rec *r, ch
                       "error parsing URL %s: %s", url, err);
         return HTTP_BAD_REQUEST;
     }
-        
+
     apr_snprintf(sport, sizeof(sport), ":%u", port);
-        
+
     if (ap_strchr(host, ':')) { /* if literal IPv6 address */
         host = apr_pstrcat(r->pool, "[", host, "]", NULL);
     }

Modified: httpd/httpd/trunk/modules/proxy/mod_serf.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/proxy/mod_serf.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/proxy/mod_serf.c (original)
+++ httpd/httpd/trunk/modules/proxy/mod_serf.c Fri Sep 23 13:39:32 2011
@@ -76,7 +76,7 @@ typedef struct {
 static void timed_cleanup_callback(void *baton)
 {
     s_baton_t *ctx = baton;
-    
+
     /* Causes all serf connections to unregister from the event mpm */
     if (ctx->rstatus) {
         ap_log_rerror(APLOG_MARK, APLOG_ERR, ctx->rstatus, ctx->r,
@@ -95,7 +95,7 @@ static void timed_cleanup_callback(void 
 
         /* TODO: return code? bleh */
         ap_pass_brigade(ctx->r->output_filters, ctx->tmpbb);
-        
+
         apr_pool_destroy(ctx->serf_pool);
 
         ap_finalize_request_protocol(ctx->r);
@@ -144,7 +144,7 @@ static int copy_headers_in(void *vbaton,
 {
     serf_bucket_t *hdrs_bkt = (serf_bucket_t *)vbaton;
 
-    /* XXXXX: List of headers not to copy to serf. serf's serf_bucket_headers_setn, 
+    /* XXXXX: List of headers not to copy to serf. serf's serf_bucket_headers_setn,
      * doesn't actually overwrite a header if we set it once, so we need to ignore anything
      * we might want to toggle or combine.
      */
@@ -292,9 +292,9 @@ static apr_status_t handle_response(serf
 
         return rv;
     }
-    
+
     /**
-     * XXXXX: If I understood serf buckets better, it might be possible to not 
+     * XXXXX: If I understood serf buckets better, it might be possible to not
      * copy all of the data here, and better stream it to the client.
      **/
 
@@ -314,7 +314,7 @@ static apr_status_t handle_response(serf
             /* TODO: improve */
             serf_bucket_response_status(response, &line);
             ctx->r->status = line.code;
-            
+
             hdrs = serf_bucket_response_get_headers(response);
             serf_bucket_headers_do(hdrs, copy_headers_out, ctx);
             ctx->done_headers = 1;
@@ -390,7 +390,7 @@ static apr_status_t setup_request(serf_r
                                                       ctx->bkt_alloc);
         }
     }
-    
+
     *acceptor = accept_response;
     *acceptor_baton = ctx;
     *handler = handle_response;
@@ -409,7 +409,7 @@ static int drive_serf(request_rec *r, se
     /* XXXXX: make persistent/per-process or something.*/
     serf_context_t *serfme;
     serf_connection_t *conn;
-    serf_server_config_t *ctx = 
+    serf_server_config_t *ctx =
         (serf_server_config_t *)ap_get_module_config(r->server->module_config,
                                                      &serf_module);
 
@@ -426,7 +426,7 @@ static int drive_serf(request_rec *r, se
         apr_uint32_t pick = 0;
         ap_serf_server_t *choice;
 
-        /* TODO: could this be optimized in post-config to pre-setup the 
+        /* TODO: could this be optimized in post-config to pre-setup the
          * pointers to the right cluster inside the conf structure?
          */
         cluster = apr_hash_get(ctx->clusters,
@@ -439,7 +439,7 @@ static int drive_serf(request_rec *r, se
         }
 
         cp = ap_lookup_provider(AP_SERF_CLUSTER_PROVIDER, cluster->provider, "0");
-        
+
         if (cp == NULL) {
             ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
                           "SerfCluster: unable to find provider %s", cluster->provider);
@@ -451,7 +451,7 @@ static int drive_serf(request_rec *r, se
                           "SerfCluster: %s is missing list servers provider.", cluster->provider);
             return HTTP_INTERNAL_SERVER_ERROR;
         }
-        
+
         rc = cp->list_servers(cp->baton,
                               r,
                               cluster->params,
@@ -557,7 +557,7 @@ static int drive_serf(request_rec *r, se
         apr_file_seek(fp, APR_SET, &flen);
         baton->body_bkt = serf_bucket_file_create(fp, baton->bkt_alloc);
     }
-    
+
     conn = serf_connection_create(serfme, address,
                                   conn_setup, baton,
                                   closed_connection, baton,
@@ -572,20 +572,20 @@ static int drive_serf(request_rec *r, se
     else {
         do {
             rv = serf_context_run(serfme, SERF_DURATION_FOREVER, pool);
-            
+
             /* XXXX: Handle timeouts */
             if (APR_STATUS_IS_TIMEUP(rv)) {
                 continue;
             }
-            
+
             if (rv != APR_SUCCESS) {
                 ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r, "serf_context_run() for %pI", address);
-                return HTTP_INTERNAL_SERVER_ERROR;       
+                return HTTP_INTERNAL_SERVER_ERROR;
             }
-            
+
             serf_debug__closed_conn(baton->bkt_alloc);
         } while (baton->keep_reading);
-        
+
         return baton->rstatus;
     }
 }
@@ -645,7 +645,7 @@ static const char *add_pass(cmd_parms *c
     for (i = 1; i < argc; i++) {
         const char *p = argv[i];
         const char *x = ap_strchr_c(p, '=');
-        
+
         if (x) {
             if (strncmp(p, "preservehost", x-p) == 0) {
                 conf->preservehost = is_true(x+1);
@@ -654,7 +654,7 @@ static const char *add_pass(cmd_parms *c
     }
 
     conf->on = 1;
-    
+
     return NULL;
 }
 
@@ -667,12 +667,12 @@ static const char *add_cluster(cmd_parms
     ap_serf_cluster_provider_t *backend;
     int i;
     serf_cluster_t *cluster = NULL;
-    serf_server_config_t *ctx = 
+    serf_server_config_t *ctx =
         (serf_server_config_t *)ap_get_module_config(cmd->server->module_config,
                                                      &serf_module);
 
     const char *err = ap_check_cmd_context(cmd, GLOBAL_ONLY);
-  
+
     if (err != NULL) {
         return err;
     }
@@ -680,14 +680,14 @@ static const char *add_cluster(cmd_parms
     if (argc < 2) {
         return "SerfCluster must have at least a name and provider.";
     }
-    
+
     cluster = apr_palloc(cmd->pool, sizeof(serf_cluster_t));
     cluster->name = apr_pstrdup(cmd->pool, argv[0]);
     cluster->provider = apr_pstrdup(cmd->pool, argv[1]);
     cluster->params = apr_table_make(cmd->pool, 6);
 
     backend = ap_lookup_provider(AP_SERF_CLUSTER_PROVIDER, cluster->provider, "0");
-    
+
     if (backend == NULL) {
         return apr_psprintf(cmd->pool, "SerfCluster: unable to find "
                             "provider '%s'", cluster->provider);
@@ -703,7 +703,7 @@ static const char *add_cluster(cmd_parms
                            x+1);
         }
         else {
-            apr_table_addn(cluster->params, 
+            apr_table_addn(cluster->params,
                            apr_pstrdup(cmd->pool, p),
                            "");
         }
@@ -716,7 +716,7 @@ static const char *add_cluster(cmd_parms
     }
 
     rv = backend->check_config(backend->baton, cmd, cluster->params);
-    
+
     if (rv) {
         return rv;
     }
@@ -736,7 +736,7 @@ static void *create_dir_config(apr_pool_
 
 static void *create_server_config(apr_pool_t *p, server_rec *s)
 {
-    serf_server_config_t *ctx = 
+    serf_server_config_t *ctx =
         (serf_server_config_t *) apr_pcalloc(p, sizeof(serf_server_config_t));
 
     ctx->clusters = apr_hash_make(p);
@@ -749,10 +749,10 @@ static void * merge_server_config(apr_po
     serf_server_config_t *ctx = apr_pcalloc(p, sizeof(serf_server_config_t));
     serf_server_config_t *base = (serf_server_config_t *) basev;
     serf_server_config_t *overrides = (serf_server_config_t *) overridesv;
-    
+
     ctx->clusters = apr_hash_overlay(p, base->clusters, overrides->clusters);
     return ctx;
-}    
+}
 
 static const command_rec serf_cmds[] =
 {
@@ -790,12 +790,12 @@ static const char* hb_config_check(void 
     if (apr_is_empty_table(params)) {
         return "SerfCluster Heartbeat requires a path to the heartbat information.";
     }
-    
+
     b.p = cmd->pool;
     b.msg = NULL;
 
     apr_table_do(hb_table_check, &b, params, NULL);
-    
+
     if (b.msg) {
         return b.msg;
     }
@@ -817,7 +817,7 @@ argstr_to_table(apr_pool_t *p, char *str
     char *key;
     char *value;
     char *strtok_state;
-    
+
     key = apr_strtok(str, "&", &strtok_state);
     while (key) {
         value = strchr(key, '=');
@@ -842,24 +842,24 @@ static apr_status_t read_heartbeats(cons
     apr_finfo_t fi;
     apr_status_t rv;
     apr_file_t *fp;
-    
+
     if (!path) {
         return APR_SUCCESS;
     }
-    
+
     rv = apr_file_open(&fp, path, APR_READ|APR_BINARY|APR_BUFFERED,
                        APR_OS_DEFAULT, pool);
-    
+
     if (rv) {
         return rv;
     }
-    
+
     rv = apr_file_info_get(&fi, APR_FINFO_SIZE, fp);
-    
+
     if (rv) {
         return rv;
     }
-    
+
     {
         char *t;
         int lineno = 0;
@@ -875,14 +875,14 @@ static apr_status_t read_heartbeats(cons
             if (buf[0] == '#') {
                 continue;
             }
-            
-            
+
+
             /* line format: <IP> <query_string>\n */
             t = strchr(buf, ' ');
             if (!t) {
                 continue;
             }
-            
+
             ip = apr_pstrndup(pool, buf, t - buf);
             t++;
             server = apr_pcalloc(pool, sizeof(hb_server_t));
@@ -890,29 +890,29 @@ static apr_status_t read_heartbeats(cons
             server->port = 80;
             server->seen = -1;
             apr_table_clear(hbt);
-            
+
             argstr_to_table(pool, apr_pstrdup(pool, t), hbt);
-            
+
             if (apr_table_get(hbt, "busy")) {
                 server->busy = atoi(apr_table_get(hbt, "busy"));
             }
-            
+
             if (apr_table_get(hbt, "ready")) {
                 server->ready = atoi(apr_table_get(hbt, "ready"));
             }
-            
+
             if (apr_table_get(hbt, "lastseen")) {
                 server->seen = atoi(apr_table_get(hbt, "lastseen"));
             }
-            
+
             if (apr_table_get(hbt, "port")) {
                 server->port = atoi(apr_table_get(hbt, "port"));
             }
-            
+
             if (server->busy == 0 && server->ready != 0) {
-                /* Server has zero threads active, but lots of them ready, 
-                 * it likely just started up, so lets /4 the number ready, 
-                 * to prevent us from completely flooding it with all new 
+                /* Server has zero threads active, but lots of them ready,
+                 * it likely just started up, so lets /4 the number ready,
+                 * to prevent us from completely flooding it with all new
                  * requests.
                  */
                 server->ready = server->ready / 4;
@@ -921,7 +921,7 @@ static apr_status_t read_heartbeats(cons
             APR_ARRAY_PUSH(servers, hb_server_t *) = server;
         }
     }
-    
+
     return APR_SUCCESS;
 }
 
@@ -966,7 +966,7 @@ static int hb_list_servers(void *baton,
         apr_pool_destroy(tpool);
         return HTTP_INTERNAL_SERVER_ERROR;
     }
-    
+
     qsort(tmpservers->elts, tmpservers->nelts, sizeof(hb_server_t *),
           hb_server_sort);
 
@@ -1011,7 +1011,7 @@ static int static_table_check(void *rec,
                               key);
         return 1;
     }
-    
+
     return 0;
 }
 
@@ -1020,20 +1020,20 @@ static const char* static_config_check(v
                                    apr_table_t *params)
 {
     hb_table_baton_t b;
-    
+
     if (apr_is_empty_table(params)) {
         return "SerfCluster Static requires at least a host list.";
     }
-    
+
     b.p = cmd->pool;
     b.msg = NULL;
-    
+
     apr_table_do(static_table_check, &b, params, NULL);
-    
+
     if (b.msg) {
         return b.msg;
     }
-    
+
     if (apr_table_get(params, "hosts") == NULL) {
         return "SerfCluster Static requires at least a hosts parameter";
     }
@@ -1053,13 +1053,13 @@ static int static_list_servers(void *bat
     const char *order = apr_table_get(params, "order");
 
     servers = apr_array_make(r->pool, 10, sizeof(ap_serf_server_t *));
-    
+
     ip = apr_strtok(apr_pstrdup(r->pool, hosts), ",", &strtok_state);
     while (ip) {
         char *host_str;
         char *scope_id;
         apr_port_t port = 0;
-        
+
         rv = apr_parse_addr_port(&host_str, &scope_id, &port, ip, r->pool);
         if (!rv) {
             ap_serf_server_t *s = apr_palloc(r->pool, sizeof(ap_serf_server_t));
@@ -1097,8 +1097,8 @@ static int serf_post_config(apr_pool_t *
     if (rv != APR_SUCCESS) {
         mpm_supprts_serf = 0;
     }
-    
-    return OK; 
+
+    return OK;
 }
 
 static void register_hooks(apr_pool_t *p)

Modified: httpd/httpd/trunk/modules/slotmem/mod_slotmem_plain.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/slotmem/mod_slotmem_plain.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/slotmem/mod_slotmem_plain.c (original)
+++ httpd/httpd/trunk/modules/slotmem/mod_slotmem_plain.c Fri Sep 23 13:39:32 2011
@@ -44,7 +44,7 @@ static apr_status_t slotmem_do(ap_slotme
     char *ptr;
     char *inuse;
     apr_status_t retval = APR_SUCCESS;
-    
+
 
     if (!mem)
         return APR_ENOSHMAVAIL;

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_config.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_config.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_config.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_config.c Fri Sep 23 13:39:32 2011
@@ -808,7 +808,7 @@ const char *ssl_cmd_SSLCACertificatePath
     if ((err = ssl_cmd_check_dir(cmd, &arg))) {
         return err;
     }
-    
+
     if (cmd->path) {
         return NO_PER_DIR_SSL_CA;
     }
@@ -1066,7 +1066,7 @@ const char *ssl_cmd_SSLSessionCache(cmd_
         if (mc->sesscache) {
             /* Cache found; create it, passing anything beyond the colon. */
             mc->sesscache_mode = enabled_flags;
-            err = mc->sesscache->create(&mc->sesscache_context, sep, 
+            err = mc->sesscache->create(&mc->sesscache_context, sep,
                                         cmd->temp_pool, cmd->pool);
         }
         else {
@@ -1075,7 +1075,7 @@ const char *ssl_cmd_SSLSessionCache(cmd_
 
             /* Build a comma-separated list of all registered provider
              * names: */
-            name_list = ap_list_provider_names(cmd->pool, 
+            name_list = ap_list_provider_names(cmd->pool,
                                                AP_SOCACHE_PROVIDER_GROUP,
                                                AP_SOCACHE_PROVIDER_VERSION);
             all_names = apr_array_pstrcat(cmd->pool, name_list, ',');
@@ -1088,7 +1088,7 @@ const char *ssl_cmd_SSLSessionCache(cmd_
     if (err) {
         return apr_psprintf(cmd->pool, "SSLSessionCache: %s", err);
     }
-    
+
     return NULL;
 }
 
@@ -1414,12 +1414,12 @@ const char *ssl_cmd_SSLProxyCARevocation
 const char *ssl_cmd_SSLProxyCARevocationCheck(cmd_parms *cmd,
                                               void *dcfg,
                                               const char *arg)
-{   
+{
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
 
     return ssl_cmd_crlcheck_parse(cmd, arg, &sc->proxy->crl_check_mode);
 }
-        
+
 const char *ssl_cmd_SSLProxyMachineCertificateFile(cmd_parms *cmd,
                                                    void *dcfg,
                                                    const char *arg)
@@ -1477,7 +1477,7 @@ const char *ssl_cmd_SSLUserName(cmd_parm
 }
 
 const char *ssl_cmd_SSLOCSPEnable(cmd_parms *cmd, void *dcfg, int flag)
-{   
+{
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
 
     sc->server->ocsp_enabled = flag ? TRUE : FALSE;
@@ -1487,11 +1487,11 @@ const char *ssl_cmd_SSLOCSPEnable(cmd_pa
         return "OCSP support disabled in SSL library; cannot enable "
             "OCSP validation";
     }
-#endif    
+#endif
 
     return NULL;
 }
-        
+
 const char *ssl_cmd_SSLOCSPOverrideResponder(cmd_parms *cmd, void *dcfg, int flag)
 {
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
@@ -1502,7 +1502,7 @@ const char *ssl_cmd_SSLOCSPOverrideRespo
 }
 
 const char *ssl_cmd_SSLOCSPDefaultResponder(cmd_parms *cmd, void *dcfg, const char *arg)
-{   
+{
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
 
     sc->server->ocsp_responder = arg;
@@ -1603,20 +1603,20 @@ const char *ssl_cmd_SSLStaplingCache(cmd
     if (mc->stapling_cache) {
         /* Cache found; create it, passing anything beyond the colon. */
         err = mc->stapling_cache->create(&mc->stapling_cache_context,
-                                         sep, cmd->temp_pool, 
+                                         sep, cmd->temp_pool,
                                          cmd->pool);
     }
     else {
         apr_array_header_t *name_list;
         const char *all_names;
-        
+
         /* Build a comma-separated list of all registered provider
          * names: */
-        name_list = ap_list_provider_names(cmd->pool, 
+        name_list = ap_list_provider_names(cmd->pool,
                                            AP_SOCACHE_PROVIDER_GROUP,
                                            AP_SOCACHE_PROVIDER_VERSION);
         all_names = apr_array_pstrcat(cmd->pool, name_list, ',');
-        
+
         err = apr_psprintf(cmd->pool, "'%s' stapling cache not supported "
                            "(known names: %s)", name, all_names);
     }
@@ -1624,12 +1624,12 @@ const char *ssl_cmd_SSLStaplingCache(cmd
     if (err) {
         return apr_psprintf(cmd->pool, "SSLStaplingCache: %s", err);
     }
-    
+
     return NULL;
 }
 
 const char *ssl_cmd_SSLUseStapling(cmd_parms *cmd, void *dcfg, int flag)
-{   
+{
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
     sc->server->stapling_enabled = flag ? TRUE : FALSE;
     return NULL;
@@ -1681,7 +1681,7 @@ const char *ssl_cmd_SSLStaplingErrorCach
 
 const char *ssl_cmd_SSLStaplingReturnResponderErrors(cmd_parms *cmd,
                                                      void *dcfg, int flag)
-{   
+{
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
     sc->server->stapling_return_errors = flag ? TRUE : FALSE;
     return NULL;
@@ -1689,7 +1689,7 @@ const char *ssl_cmd_SSLStaplingReturnRes
 
 const char *ssl_cmd_SSLStaplingFakeTryLater(cmd_parms *cmd,
                                             void *dcfg, int flag)
-{   
+{
     SSLSrvConfigRec *sc = mySrvConfig(cmd->server);
     sc->server->stapling_fake_trylater = flag ? TRUE : FALSE;
     return NULL;

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_init.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_init.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_init.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_init.c Fri Sep 23 13:39:32 2011
@@ -40,7 +40,7 @@ static void ssl_add_version_components(a
 {
     char *modver = ssl_var_lookup(p, s, NULL, NULL, "SSL_VERSION_INTERFACE");
     char *libver = ssl_var_lookup(p, s, NULL, NULL, "SSL_VERSION_LIBRARY");
-    char *incver = ssl_var_lookup(p, s, NULL, NULL, 
+    char *incver = ssl_var_lookup(p, s, NULL, NULL,
                                   "SSL_VERSION_LIBRARY_INTERFACE");
 
     ap_add_version_component(p, modver);
@@ -401,8 +401,8 @@ void ssl_init_Engine(server_rec *s, apr_
             ssl_log_ssl_error(SSLLOG_MARK, APLOG_EMERG, s);
             ssl_die();
         }
-        ap_log_error(APLOG_MARK, APLOG_INFO, 0, s, 
-                     "Init: loaded Crypto Device API `%s'", 
+        ap_log_error(APLOG_MARK, APLOG_INFO, 0, s,
+                     "Init: loaded Crypto Device API `%s'",
                      mc->szCryptoDevice);
 
         ENGINE_free(e);
@@ -901,7 +901,7 @@ static int ssl_server_import_cert(server
         ssl_log_ssl_error(SSLLOG_MARK, APLOG_EMERG, s);
         ssl_die();
     }
-  
+
 #ifdef HAVE_OCSP_STAPLING
     if ((mctx->pkp == FALSE) && (mctx->stapling_enabled == TRUE)) {
         if (!ssl_stapling_init_cert(s, mctx, cert)) {
@@ -1338,11 +1338,11 @@ void ssl_init_CheckServers(server_rec *b
         klen = strlen(key);
 
         if ((ps = (server_rec *)apr_hash_get(table, key, klen))) {
-            ap_log_error(APLOG_MARK, 
+            ap_log_error(APLOG_MARK,
 #ifdef OPENSSL_NO_TLSEXT
-                         APLOG_WARNING, 
+                         APLOG_WARNING,
 #else
-                         APLOG_DEBUG, 
+                         APLOG_DEBUG,
 #endif
                          0,
                          base_server,
@@ -1378,7 +1378,7 @@ void ssl_init_CheckServers(server_rec *b
     }
 }
 
-static int ssl_init_FindCAList_X509NameCmp(const X509_NAME * const *a, 
+static int ssl_init_FindCAList_X509NameCmp(const X509_NAME * const *a,
                                            const X509_NAME * const *b)
 {
     return(X509_NAME_cmp(*a, *b));

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_io.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_io.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_io.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_io.c Fri Sep 23 13:39:32 2011
@@ -147,7 +147,7 @@ static int bio_filter_out_flush(BIO *bio
     apr_bucket *e;
 
     AP_DEBUG_ASSERT(APR_BRIGADE_EMPTY(outctx->bb));
-    
+
     e = apr_bucket_flush_create(outctx->bb->bucket_alloc);
     APR_BRIGADE_INSERT_TAIL(outctx->bb, e);
 
@@ -192,7 +192,7 @@ static int bio_filter_out_write(BIO *bio
         outctx->rc = APR_ECONNABORTED;
         return -1;
     }
-    
+
     /* when handshaking we'll have a small number of bytes.
      * max size SSL will pass us here is about 16k.
      * (16413 bytes to be exact)
@@ -203,7 +203,7 @@ static int bio_filter_out_write(BIO *bio
      * filter must setaside if necessary. */
     e = apr_bucket_transient_create(in, inl, outctx->bb->bucket_alloc);
     APR_BRIGADE_INSERT_TAIL(outctx->bb, e);
-    
+
     if (bio_filter_out_pass(outctx) < 0) {
         return -1;
     }
@@ -863,10 +863,10 @@ static apr_status_t ssl_io_filter_error(
             /* fake the request line */
             bucket = HTTP_ON_HTTPS_PORT_BUCKET(f->c->bucket_alloc);
             break;
-            
+
     case MODSSL_ERROR_BAD_GATEWAY:
         bucket = ap_bucket_error_create(HTTP_BAD_REQUEST, NULL,
-                                        f->c->pool, 
+                                        f->c->pool,
                                         f->c->bucket_alloc);
         ap_log_cerror(APLOG_MARK, APLOG_INFO, 0, f->c,
                       "SSL handshake failed: sending 502");
@@ -1292,8 +1292,8 @@ static apr_status_t ssl_io_filter_input(
         /* Satisfy the read directly out of the buffer if possible;
          * invoking ssl_io_input_getline will mean the entire buffer
          * is copied once (unnecessarily) for each GETLINE call. */
-        if (inctx->cbuf.length 
-            && (pos = memchr(inctx->cbuf.value, APR_ASCII_LF, 
+        if (inctx->cbuf.length
+            && (pos = memchr(inctx->cbuf.value, APR_ASCII_LF,
                              inctx->cbuf.length)) != NULL) {
             start = inctx->cbuf.value;
             len = 1 + pos - start; /* +1 to include LF */
@@ -1340,7 +1340,7 @@ static apr_status_t ssl_io_filter_input(
  * overhead (network packets) for any output comprising many small
  * buckets.  SSI page applied through the HTTP chunk filter, for
  * example, may produce many brigades containing small buckets -
- * [chunk-size CRLF] [chunk-data] [CRLF]. 
+ * [chunk-size CRLF] [chunk-data] [CRLF].
  *
  * The coalescing filter merges many small buckets into larger buckets
  * where possible, allowing the SSL I/O output filter to handle them
@@ -1363,7 +1363,7 @@ static apr_status_t ssl_io_filter_coales
 
     /* The brigade consists of zero-or-more small data buckets which
      * can be coalesced (the prefix), followed by the remainder of the
-     * brigade.  
+     * brigade.
      *
      * Find the last bucket - if any - of that prefix.  count gives
      * the number of buckets in the prefix.  The "prefix" must contain
@@ -1389,9 +1389,9 @@ static apr_status_t ssl_io_filter_coales
     }
 
     /* Coalesce the prefix, if:
-     * a) more than one bucket is found to coalesce, or 
+     * a) more than one bucket is found to coalesce, or
      * b) the brigade contains only a single data bucket, or
-     * c) 
+     * c)
      */
     if (bytes > 0
         && (count > 1
@@ -1411,7 +1411,7 @@ static apr_status_t ssl_io_filter_coales
          * in this loop it is safe to break out and fall back to the
          * normal path of sending the buffer + remaining buckets in
          * brigade.  */
-        e = APR_BRIGADE_FIRST(bb); 
+        e = APR_BRIGADE_FIRST(bb);
         while (e != last) {
             apr_size_t len;
             const char *data;
@@ -1422,7 +1422,7 @@ static apr_status_t ssl_io_filter_coales
                 ap_log_cerror(APLOG_MARK, APLOG_ERR, 0, f->c,
                               "unexpected bucket type during coalesce");
                 break; /* non-fatal error; break out */
-            }                
+            }
 
             if (e->length) {
                 apr_status_t rv;
@@ -1438,7 +1438,7 @@ static apr_status_t ssl_io_filter_coales
                 }
 
                 /* Be paranoid. */
-                if (len > sizeof ctx->buffer 
+                if (len > sizeof ctx->buffer
                     || (len + ctx->bytes > sizeof ctx->buffer)) {
                     ap_log_cerror(APLOG_MARK, APLOG_ERR, 0, f->c,
                                   "unexpected coalesced bucket data length");
@@ -1468,13 +1468,13 @@ static apr_status_t ssl_io_filter_coales
 
         ap_log_cerror(APLOG_MARK, APLOG_TRACE4, 0, f->c,
                       "coalesce: passing on %" APR_SIZE_T_FMT " bytes", ctx->bytes);
-        
+
         e = apr_bucket_transient_create(ctx->buffer, ctx->bytes, bb->bucket_alloc);
         APR_BRIGADE_INSERT_HEAD(bb, e);
         ctx->bytes = 0; /* buffer now emptied. */
     }
-    
-    return ap_pass_brigade(f->next, bb);    
+
+    return ap_pass_brigade(f->next, bb);
 }
 
 static apr_status_t ssl_io_filter_output(ap_filter_t *f,
@@ -1666,7 +1666,7 @@ int ssl_io_buffer_fill(request_rec *r, a
         /* Fail if this exceeds the maximum buffer size. */
         if (total > maxlen) {
             ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
-                          "request body exceeds maximum size (%" APR_SIZE_T_FMT 
+                          "request body exceeds maximum size (%" APR_SIZE_T_FMT
                           ") for SSL buffer", maxlen);
             return HTTP_REQUEST_ENTITY_TOO_LARGE;
         }
@@ -1677,7 +1677,7 @@ int ssl_io_buffer_fill(request_rec *r, a
 
     /* After consuming all protocol-level input, remove all protocol-level
      * filters.  It should strictly only be necessary to remove filters
-     * at exactly ftype == AP_FTYPE_PROTOCOL, since this filter will 
+     * at exactly ftype == AP_FTYPE_PROTOCOL, since this filter will
      * precede all > AP_FTYPE_PROTOCOL anyway. */
     while (r->proto_input_filters->frec->ftype < AP_FTYPE_CONNECTION) {
         ap_remove_input_filter(r->proto_input_filters);

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_kernel.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_kernel.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_kernel.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_kernel.c Fri Sep 23 13:39:32 2011
@@ -48,7 +48,7 @@ static apr_status_t upgrade_connection(r
     apr_status_t rv;
     SSL *ssl;
 
-    ap_log_rerror(APLOG_MARK, APLOG_INFO, 0, r, 
+    ap_log_rerror(APLOG_MARK, APLOG_INFO, 0, r,
                   "upgrading connection to TLS");
 
     bb = apr_brigade_create(r->pool, conn->bucket_alloc);
@@ -69,10 +69,10 @@ static apr_status_t upgrade_connection(r
     }
 
     ssl_init_ssl_connection(conn, r);
-    
+
     sslconn = myConnConfig(conn);
     ssl = sslconn->ssl;
-    
+
     /* Perform initial SSL handshake. */
     SSL_set_accept_state(ssl);
     SSL_do_handshake(ssl);
@@ -80,7 +80,7 @@ static apr_status_t upgrade_connection(r
     if (SSL_get_state(ssl) != SSL_ST_OK) {
         ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                       "TLS upgrade handshake failed: not accepted by client!?");
-        
+
         return APR_ECONNABORTED;
     }
 
@@ -90,23 +90,23 @@ static apr_status_t upgrade_connection(r
 /* Perform a speculative (and non-blocking) read from the connection
  * filters for the given request, to determine whether there is any
  * pending data to read.  Return non-zero if there is, else zero. */
-static int has_buffered_data(request_rec *r) 
+static int has_buffered_data(request_rec *r)
 {
     apr_bucket_brigade *bb;
     apr_off_t len;
     apr_status_t rv;
     int result;
-    
+
     bb = apr_brigade_create(r->pool, r->connection->bucket_alloc);
-    
+
     rv = ap_get_brigade(r->connection->input_filters, bb, AP_MODE_SPECULATIVE,
-                        APR_NONBLOCK_READ, 1); 
+                        APR_NONBLOCK_READ, 1);
     result = rv == APR_SUCCESS
         && apr_brigade_length(bb, 1, &len) == APR_SUCCESS
         && len > 0;
-    
+
     apr_brigade_destroy(bb);
-    
+
     return result;
 }
 
@@ -122,7 +122,7 @@ int ssl_hook_ReadReq(request_rec *r)
     const char *servername;
 #endif
     SSL *ssl;
-    
+
     /* Perform TLS upgrade here if "SSLEngine optional" is configured,
      * SSL is not already set up for this connection, and the client
      * has sent a suitable Upgrade header. */
@@ -768,7 +768,7 @@ int ssl_hook_Access(request_rec *r)
                           "Performing full renegotiation: complete handshake "
                           "protocol (%s support secure renegotiation)",
 #if defined(SSL_get_secure_renegotiation_support)
-                          SSL_get_secure_renegotiation_support(ssl) ? 
+                          SSL_get_secure_renegotiation_support(ssl) ?
                           "client does" : "client does not"
 #else
                           "server does not"
@@ -782,7 +782,7 @@ int ssl_hook_Access(request_rec *r)
             /* Toggle the renegotiation state to allow the new
              * handshake to proceed. */
             sslconn->reneg_state = RENEG_ALLOW;
-            
+
             SSL_renegotiate(ssl);
             SSL_do_handshake(ssl);
 
@@ -1190,7 +1190,7 @@ int ssl_hook_Fixup(request_rec *r)
 
 
 #ifdef SSL_get_secure_renegotiation_support
-    apr_table_setn(r->notes, "ssl-secure-reneg", 
+    apr_table_setn(r->notes, "ssl-secure-reneg",
                    SSL_get_secure_renegotiation_support(ssl) ? "1" : "0");
 #endif
 
@@ -1391,12 +1391,12 @@ EC_KEY *ssl_callback_TmpECDH(SSL *ssl, i
         ecdh = EC_KEY_new();
         if (ecdh != NULL) {
             /* ecdh->group = EC_GROUP_new_by_nid(NID_secp160r2); */
-            EC_KEY_set_group(ecdh, 
+            EC_KEY_set_group(ecdh,
               EC_GROUP_new_by_curve_name(NID_X9_62_prime256v1));
         }
         init = 1;
     }
-    
+
     return ecdh;
 }
 #endif
@@ -1819,7 +1819,7 @@ void ssl_callback_DelSessionCacheEntry(S
 }
 
 /* Dump debugginfo trace to the log file. */
-static void log_tracing_state(const SSL *ssl, conn_rec *c, 
+static void log_tracing_state(const SSL *ssl, conn_rec *c,
                               server_rec *s, int where, int rc)
 {
     /*
@@ -1912,8 +1912,8 @@ void ssl_callback_Info(const SSL *ssl, i
      * read. */
     if ((where & SSL_CB_ACCEPT_LOOP) && scr->reneg_state == RENEG_REJECT) {
         int state = SSL_get_state((SSL *)ssl);
-        
-        if (state == SSL3_ST_SR_CLNT_HELLO_A 
+
+        if (state == SSL3_ST_SR_CLNT_HELLO_A
             || state == SSL23_ST_SR_CLNT_HELLO_A) {
             scr->reneg_state = RENEG_ABORT;
             ap_log_cerror(APLOG_MARK, APLOG_ERR, 0, c,
@@ -1970,7 +1970,7 @@ int ssl_callback_ServerNameIndication(SS
  * or one of the ServerAliases matches the supplied name (to be used
  * with ap_vhost_iterate_given_conn())
  */
-static int ssl_find_vhost(void *servername, conn_rec *c, server_rec *s) 
+static int ssl_find_vhost(void *servername, conn_rec *c, server_rec *s)
 {
     SSLSrvConfigRec *sc;
     SSL *ssl;
@@ -1984,7 +1984,7 @@ static int ssl_find_vhost(void *serverna
         found = TRUE;
     }
 
-    /* 
+    /*
      * if not matched yet, check ServerAlias entries
      * (adapted from vhost.c:matches_aliases())
      */

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_log.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_log.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_log.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_log.c Fri Sep 23 13:39:32 2011
@@ -96,9 +96,9 @@ void ssl_log_ssl_error(const char *file,
         ap_log_error(file, line, APLOG_MODULE_INDEX, level, 0, s,
                      "SSL Library Error: %s%s%s%s%s%s",
                      /* %s */
-                     err, 
+                     err,
                      /* %s%s%s */
-                     data ? " (" : "", data ? data : "", data ? ")" : "", 
+                     data ? " (" : "", data ? data : "", data ? ")" : "",
                      /* %s%s */
                      annotation ? " -- " : "",
                      annotation ? annotation : "");
@@ -108,7 +108,7 @@ void ssl_log_ssl_error(const char *file,
     }
 }
 
-static void ssl_log_cert_error(const char *file, int line, int level, 
+static void ssl_log_cert_error(const char *file, int line, int level,
                                apr_status_t rv, const server_rec *s,
                                const conn_rec *c, const request_rec *r,
                                apr_pool_t *p, X509 *cert, const char *format,
@@ -117,7 +117,7 @@ static void ssl_log_cert_error(const cha
     char buf[HUGE_STRING_LEN];
     int msglen, n;
     char *name;
-    
+
     apr_vsnprintf(buf, sizeof buf, format, ap);
 
     msglen = strlen(buf);

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_ocsp.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_ocsp.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_ocsp.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_ocsp.c Fri Sep 23 13:39:32 2011
@@ -34,7 +34,7 @@ static const char *extract_responder_uri
 
     for (j = 0; j < sk_ACCESS_DESCRIPTION_num(values) && !result; j++) {
         ACCESS_DESCRIPTION *value = sk_ACCESS_DESCRIPTION_value(values, j);
-        
+
         /* Name found in extension, and is a URI: */
         if (OBJ_obj2nid(value->method) == NID_ad_OCSP
             && value->location->type == GEN_URI) {
@@ -42,7 +42,7 @@ static const char *extract_responder_uri
                                  (char *)value->location->d.uniformResourceIdentifier->data);
         }
     }
-    
+
     AUTHORITY_INFO_ACCESS_free(values);
 
     return result;
@@ -51,7 +51,7 @@ static const char *extract_responder_uri
 /* Return the responder URI object which should be used in the given
  * configuration for the given certificate, or NULL if none can be
  * determined. */
-static apr_uri_t *determine_responder_uri(SSLSrvConfigRec *sc, X509 *cert, 
+static apr_uri_t *determine_responder_uri(SSLSrvConfigRec *sc, X509 *cert,
                                           conn_rec *c, apr_pool_t *p)
 {
     apr_uri_t *u = apr_palloc(p, sizeof *u);
@@ -65,7 +65,7 @@ static apr_uri_t *determine_responder_ur
         s = sc->server->ocsp_responder;
     }
     else {
-        s = extract_responder_uri(cert, p); 
+        s = extract_responder_uri(cert, p);
 
         if (s == NULL && sc->server->ocsp_responder) {
             s = sc->server->ocsp_responder;
@@ -80,14 +80,14 @@ static apr_uri_t *determine_responder_ur
     }
 
     rv = apr_uri_parse(p, s, u);
-    if (rv || !u->hostname) {    
-        ap_log_cerror(APLOG_MARK, APLOG_DEBUG, rv, c, 
+    if (rv || !u->hostname) {
+        ap_log_cerror(APLOG_MARK, APLOG_DEBUG, rv, c,
                       "failed to parse OCSP responder URI '%s'", s);
         return NULL;
     }
 
     if (strcasecmp(u->scheme, "http") != 0) {
-        ap_log_cerror(APLOG_MARK, APLOG_DEBUG, rv, c, 
+        ap_log_cerror(APLOG_MARK, APLOG_DEBUG, rv, c,
                       "cannot handle OCSP responder URI '%s'", s);
         return NULL;
     }
@@ -102,8 +102,8 @@ static apr_uri_t *determine_responder_ur
 /* Create an OCSP request for the given certificate; returning the
  * certificate ID in *certid and *issuer on success.  Returns the
  * request object on success, or NULL on error. */
-static OCSP_REQUEST *create_request(X509_STORE_CTX *ctx, X509 *cert, 
-                                    OCSP_CERTID **certid, 
+static OCSP_REQUEST *create_request(X509_STORE_CTX *ctx, X509 *cert,
+                                    OCSP_CERTID **certid,
                                     server_rec *s, apr_pool_t *p)
 {
     OCSP_REQUEST *req = OCSP_REQUEST_new();
@@ -115,17 +115,17 @@ static OCSP_REQUEST *create_request(X509
                      "could not retrieve certificate id");
         return NULL;
     }
-    
+
     OCSP_request_add1_nonce(req, 0, -1);
-    
+
     return req;
 }
-        
+
 /* Verify the OCSP status of given certificate.  Returns
  * V_OCSP_CERTSTATUS_* result code. */
-static int verify_ocsp_status(X509 *cert, X509_STORE_CTX *ctx, conn_rec *c, 
+static int verify_ocsp_status(X509 *cert, X509_STORE_CTX *ctx, conn_rec *c,
                               SSLSrvConfigRec *sc, server_rec *s,
-                              apr_pool_t *pool) 
+                              apr_pool_t *pool)
 {
     int rc = V_OCSP_CERTSTATUS_GOOD;
     OCSP_RESPONSE *response = NULL;
@@ -133,7 +133,7 @@ static int verify_ocsp_status(X509 *cert
     OCSP_REQUEST *request = NULL;
     OCSP_CERTID *certID = NULL;
     apr_uri_t *ruri;
-   
+
     ruri = determine_responder_uri(sc, cert, c, pool);
     if (!ruri) {
         return V_OCSP_CERTSTATUS_UNKNOWN;
@@ -150,7 +150,7 @@ static int verify_ocsp_status(X509 *cert
     if (!request || !response) {
         rc = V_OCSP_CERTSTATUS_UNKNOWN;
     }
-    
+
     if (rc == V_OCSP_CERTSTATUS_GOOD) {
         int r = OCSP_response_status(response);
 
@@ -160,7 +160,7 @@ static int verify_ocsp_status(X509 *cert
             rc = V_OCSP_CERTSTATUS_UNKNOWN;
         }
     }
-    
+
     if (rc == V_OCSP_CERTSTATUS_GOOD) {
         basicResponse = OCSP_response_get1_basic(response);
         if (!basicResponse) {
@@ -170,7 +170,7 @@ static int verify_ocsp_status(X509 *cert
             rc = V_OCSP_CERTSTATUS_UNKNOWN;
         }
     }
-    
+
     if (rc == V_OCSP_CERTSTATUS_GOOD) {
         if (OCSP_check_nonce(request, basicResponse) != 1) {
             ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
@@ -178,7 +178,7 @@ static int verify_ocsp_status(X509 *cert
             rc = V_OCSP_CERTSTATUS_UNKNOWN;
         }
     }
-    
+
     if (rc == V_OCSP_CERTSTATUS_GOOD) {
         /* TODO: allow flags configuration. */
         if (OCSP_basic_verify(basicResponse, NULL, ctx->ctx, 0) != 1) {
@@ -188,7 +188,7 @@ static int verify_ocsp_status(X509 *cert
             rc = V_OCSP_CERTSTATUS_UNKNOWN;
         }
     }
-    
+
     if (rc == V_OCSP_CERTSTATUS_GOOD) {
         int reason = -1, status;
         ASN1_GENERALIZEDTIME *thisup = NULL, *nextup = NULL;
@@ -224,10 +224,10 @@ static int verify_ocsp_status(X509 *cert
         }
 
         {
-            int level = 
+            int level =
                 (status == V_OCSP_CERTSTATUS_GOOD) ? APLOG_INFO : APLOG_ERR;
-            const char *result = 
-                status == V_OCSP_CERTSTATUS_GOOD ? "good" : 
+            const char *result =
+                status == V_OCSP_CERTSTATUS_GOOD ? "good" :
                 (status == V_OCSP_CERTSTATUS_REVOKED ? "revoked" : "unknown");
 
             ssl_log_cxerror(SSLLOG_MARK, level, 0, c, cert,
@@ -236,7 +236,7 @@ static int verify_ocsp_status(X509 *cert
                             result, status, reason);
         }
     }
-    
+
     if (request) OCSP_REQUEST_free(request);
     if (response) OCSP_RESPONSE_free(response);
     if (basicResponse) OCSP_BASICRESP_free(basicResponse);
@@ -245,8 +245,8 @@ static int verify_ocsp_status(X509 *cert
     return rc;
 }
 
-int modssl_verify_ocsp(X509_STORE_CTX *ctx, SSLSrvConfigRec *sc, 
-                       server_rec *s, conn_rec *c, apr_pool_t *pool) 
+int modssl_verify_ocsp(X509_STORE_CTX *ctx, SSLSrvConfigRec *sc,
+                       server_rec *s, conn_rec *c, apr_pool_t *pool)
 {
     X509 *cert = X509_STORE_CTX_get_current_cert(ctx);
     apr_pool_t *vpool;
@@ -272,7 +272,7 @@ int modssl_verify_ocsp(X509_STORE_CTX *c
     apr_pool_create(&vpool, pool);
 
     rv = verify_ocsp_status(cert, ctx, c, sc, s, vpool);
-    
+
     apr_pool_destroy(vpool);
 
     /* Propagate the verification status back to the passed-in
@@ -281,11 +281,11 @@ int modssl_verify_ocsp(X509_STORE_CTX *c
     case V_OCSP_CERTSTATUS_GOOD:
         X509_STORE_CTX_set_error(ctx, X509_V_OK);
         break;
-        
+
     case V_OCSP_CERTSTATUS_REVOKED:
         X509_STORE_CTX_set_error(ctx, X509_V_ERR_CERT_REVOKED);
         break;
-        
+
     case V_OCSP_CERTSTATUS_UNKNOWN:
         /* correct error code for application errors? */
         X509_STORE_CTX_set_error(ctx, X509_V_ERR_APPLICATION_VERIFICATION);
@@ -293,5 +293,5 @@ int modssl_verify_ocsp(X509_STORE_CTX *c
     }
 
     return rv == V_OCSP_CERTSTATUS_GOOD;
-} 
+}
 #endif /* HAVE_OCSP */

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_pphrase.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_pphrase.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_pphrase.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_pphrase.c Fri Sep 23 13:39:32 2011
@@ -354,7 +354,7 @@ void ssl_pphrase_Handle(server_rec *s, a
                 if (pkey_mtime) {
                     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,

Modified: httpd/httpd/trunk/modules/ssl/ssl_engine_vars.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_engine_vars.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_engine_vars.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_engine_vars.c Fri Sep 23 13:39:32 2011
@@ -112,7 +112,7 @@ void ssl_var_register(apr_pool_t *p)
 
     /* Perform once-per-process library version determination: */
     var_library = apr_pstrdup(p, SSL_LIBRARY_DYNTEXT);
-    
+
     if ((cp = strchr(var_library, ' ')) != NULL) {
         *cp = '/';
         if ((cp2 = strchr(cp, ' ')) != NULL)
@@ -342,7 +342,7 @@ static char *ssl_var_lookup_ssl(apr_pool
         }
     }
     else if(ssl != NULL && strcEQ(var, "SESSION_RESUMED")) {
-        if (SSL_session_reused(ssl) == 1) 
+        if (SSL_session_reused(ssl) == 1)
             result = "Resumed";
         else
             result = "Initial";
@@ -386,7 +386,7 @@ static char *ssl_var_lookup_ssl(apr_pool
         flag = SSL_get_secure_renegotiation_support(ssl);
 #endif
         result = apr_pstrdup(p, flag ? "true" : "false");
-    }                             
+    }
 
     return result;
 }
@@ -769,10 +769,10 @@ static char *ssl_var_lookup_ssl_version(
     }
     return NULL;
 }
-  
+
 /* Add each RDN in 'xn' to the table 't' where the NID is present in
  * 'nids', using key prefix 'pfx'.  */
-static void extract_dn(apr_table_t *t, apr_hash_t *nids, const char *pfx, 
+static void extract_dn(apr_table_t *t, apr_hash_t *nids, const char *pfx,
                        X509_NAME *xn, apr_pool_t *p)
 {
     STACK_OF(X509_NAME_ENTRY) *ents = xn->entries;
@@ -834,7 +834,7 @@ void modssl_var_extract_dns(apr_table_t 
                          ssl_var_lookup_ssl_cert_dn_rec[n].name);
         }
     }
-    
+
     /* Extract the server cert DNS -- note that the refcount does NOT
      * increase: */
     xs = SSL_get_certificate(ssl);
@@ -842,7 +842,7 @@ void modssl_var_extract_dns(apr_table_t 
         extract_dn(t, nids, "SSL_SERVER_S_DN_", X509_get_subject_name(xs), p);
         extract_dn(t, nids, "SSL_SERVER_I_DN_", X509_get_issuer_name(xs), p);
     }
-    
+
     /* Extract the client cert DNs -- note that the refcount DOES
      * increase: */
     xs = SSL_get_peer_certificate(ssl);
@@ -862,7 +862,7 @@ static int dump_extn_value(BIO *bio, ASN
     MODSSL_D2I_ASN1_type_bytes_CONST unsigned char *pp = str->data;
     ASN1_STRING *ret = ASN1_STRING_new();
     int rv = 0;
-    
+
     /* This allows UTF8String, IA5String, VisibleString, or BMPString;
      * conversion to UTF-8 is forced. */
     if (d2i_DISPLAYTEXT(&ret, &pp, str->length)) {

Modified: httpd/httpd/trunk/modules/ssl/ssl_scache.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_scache.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_scache.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_scache.c Fri Sep 23 13:39:32 2011
@@ -42,7 +42,7 @@ void ssl_scache_init(server_rec *s, apr_
     SSLModConfigRec *mc = myModConfig(s);
     apr_status_t rv;
     struct ap_socache_hints hints;
-    
+
     /* The very first invocation of this function will be the
      * post_config invocation during server startup; do nothing for
      * this first (and only the first) time through, since the pool
@@ -57,7 +57,7 @@ void ssl_scache_init(server_rec *s, apr_
         hints.avg_obj_size = 1500;
         hints.avg_id_len = 20;
         hints.expiry_interval = 300;
-    
+
         rv = mc->stapling_cache->init(mc->stapling_cache_context,
                                      "mod_ssl-stapling", &hints, s, p);
         if (rv) {
@@ -83,7 +83,7 @@ void ssl_scache_init(server_rec *s, apr_
     hints.avg_obj_size = 150;
     hints.avg_id_len = 30;
     hints.expiry_interval = 30;
-    
+
     rv = mc->sesscache->init(mc->sesscache_context, "mod_ssl-session", &hints, s, p);
     if (rv) {
         ap_log_error(APLOG_MARK, APLOG_EMERG, 0, s,
@@ -95,7 +95,7 @@ void ssl_scache_init(server_rec *s, apr_
 void ssl_scache_kill(server_rec *s)
 {
     SSLModConfigRec *mc = myModConfig(s);
-    
+
     if (mc->sesscache) {
         mc->sesscache->destroy(mc->sesscache_context, s);
     }
@@ -131,8 +131,8 @@ BOOL ssl_scache_store(server_rec *s, UCH
     if (mc->sesscache->flags & AP_SOCACHE_FLAG_NOTMPSAFE) {
         ssl_mutex_on(s);
     }
-    
-    rv = mc->sesscache->store(mc->sesscache_context, s, id, idlen, 
+
+    rv = mc->sesscache->store(mc->sesscache_context, s, id, idlen,
                               expiry, encoded, len, p);
 
     if (mc->sesscache->flags & AP_SOCACHE_FLAG_NOTMPSAFE) {
@@ -155,7 +155,7 @@ SSL_SESSION *ssl_scache_retrieve(server_
         ssl_mutex_on(s);
     }
 
-    rv = mc->sesscache->retrieve(mc->sesscache_context, s, id, idlen, 
+    rv = mc->sesscache->retrieve(mc->sesscache_context, s, id, idlen,
                                  dest, &destlen, p);
 
     if (mc->sesscache->flags & AP_SOCACHE_FLAG_NOTMPSAFE) {

Modified: httpd/httpd/trunk/modules/ssl/ssl_util.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_util.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_util.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_util.c Fri Sep 23 13:39:32 2011
@@ -154,7 +154,7 @@ ssl_algo_t ssl_util_algotypeof(X509 *pCe
             case EVP_PKEY_EC:
                 t = SSL_ALGO_ECC;
                 break;
-#endif 
+#endif
             default:
                 break;
         }
@@ -351,7 +351,7 @@ static void ssl_util_thr_lock(int mode, 
 /* Dynamic lock structure */
 struct CRYPTO_dynlock_value {
     apr_pool_t *pool;
-    const char* file; 
+    const char* file;
     int line;
     apr_thread_mutex_t *mutex;
 };
@@ -362,17 +362,17 @@ apr_pool_t *dynlockpool = NULL;
 /*
  * Dynamic lock creation callback
  */
-static struct CRYPTO_dynlock_value *ssl_dyn_create_function(const char *file, 
+static struct CRYPTO_dynlock_value *ssl_dyn_create_function(const char *file,
                                                      int line)
 {
     struct CRYPTO_dynlock_value *value;
     apr_pool_t *p;
     apr_status_t rv;
 
-    /* 
+    /*
      * We need a pool to allocate our mutex.  Since we can't clear
      * allocated memory from a pool, create a subpool that we can blow
-     * away in the destruction callback. 
+     * away in the destruction callback.
      */
     rv = apr_pool_create(&p, dynlockpool);
     if (rv != APR_SUCCESS) {
@@ -383,21 +383,21 @@ static struct CRYPTO_dynlock_value *ssl_
 
     ap_log_perror(file, line, APLOG_MODULE_INDEX, APLOG_DEBUG, 0, p,
                   "Creating dynamic lock");
-    
-    value = (struct CRYPTO_dynlock_value *)apr_palloc(p, 
+
+    value = (struct CRYPTO_dynlock_value *)apr_palloc(p,
                                                       sizeof(struct CRYPTO_dynlock_value));
     if (!value) {
         ap_log_perror(file, line, APLOG_MODULE_INDEX, APLOG_ERR, 0, p,
                       "Failed to allocate dynamic lock structure");
         return NULL;
     }
-    
+
     value->pool = p;
     /* Keep our own copy of the place from which we were created,
        using our own pool. */
     value->file = apr_pstrdup(p, file);
     value->line = line;
-    rv = apr_thread_mutex_create(&(value->mutex), APR_THREAD_MUTEX_DEFAULT, 
+    rv = apr_thread_mutex_create(&(value->mutex), APR_THREAD_MUTEX_DEFAULT,
                                 p);
     if (rv != APR_SUCCESS) {
         ap_log_perror(file, line, APLOG_MODULE_INDEX, APLOG_ERR, rv, p,
@@ -436,7 +436,7 @@ static void ssl_dyn_lock_function(int mo
 /*
  * Dynamic lock destruction callback
  */
-static void ssl_dyn_destroy_function(struct CRYPTO_dynlock_value *l, 
+static void ssl_dyn_destroy_function(struct CRYPTO_dynlock_value *l,
                           const char *file, int line)
 {
     apr_status_t rv;
@@ -446,7 +446,7 @@ static void ssl_dyn_destroy_function(str
     rv = apr_thread_mutex_destroy(l->mutex);
     if (rv != APR_SUCCESS) {
         ap_log_perror(file, line, APLOG_MODULE_INDEX, APLOG_ERR, rv, l->pool,
-                      "Failed to destroy mutex for dynamic lock %s:%d", 
+                      "Failed to destroy mutex for dynamic lock %s:%d",
                       l->file, l->line);
     }
 
@@ -478,11 +478,11 @@ static apr_status_t ssl_util_thread_clea
 {
     CRYPTO_set_locking_callback(NULL);
     CRYPTO_set_id_callback(NULL);
-    
+
     CRYPTO_set_dynlock_create_callback(NULL);
     CRYPTO_set_dynlock_lock_callback(NULL);
     CRYPTO_set_dynlock_destroy_callback(NULL);
-    
+
     dynlockpool = NULL;
 
     /* Let the registered mutex cleanups do their own thing
@@ -504,9 +504,9 @@ void ssl_util_thread_setup(apr_pool_t *p
     CRYPTO_set_id_callback(ssl_util_thr_id);
 
     CRYPTO_set_locking_callback(ssl_util_thr_lock);
-    
+
     /* Set up dynamic locking scaffolding for OpenSSL to use at its
-     * convenience. 
+     * convenience.
      */
     dynlockpool = p;
     CRYPTO_set_dynlock_create_callback(ssl_dyn_create_function);

Modified: httpd/httpd/trunk/modules/ssl/ssl_util_ocsp.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_util_ocsp.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_util_ocsp.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_util_ocsp.c Fri Sep 23 13:39:32 2011
@@ -40,7 +40,7 @@ static BIO *serialize_request(OCSP_REQUE
                "Host: %s:%d\r\n"
                "Content-Type: application/ocsp-request\r\n"
                "Content-Length: %d\r\n"
-               "\r\n", 
+               "\r\n",
                uri->path ? uri->path : "/",
                uri->query ? "?" : "", uri->query ? uri->query : "",
                uri->hostname, uri->port, len);
@@ -56,7 +56,7 @@ static BIO *serialize_request(OCSP_REQUE
 /* Send the OCSP request serialized into BIO 'request' to the
  * responder at given server given by URI.  Returns socket object or
  * NULL on error. */
-static apr_socket_t *send_request(BIO *request, const apr_uri_t *uri, 
+static apr_socket_t *send_request(BIO *request, const apr_uri_t *uri,
                                   apr_interval_time_t timeout,
                                   conn_rec *c, apr_pool_t *p)
 {
@@ -69,13 +69,13 @@ static apr_socket_t *send_request(BIO *r
     rv = apr_sockaddr_info_get(&sa, uri->hostname, APR_UNSPEC, uri->port, 0, p);
     if (rv) {
         ap_log_cerror(APLOG_MARK, APLOG_ERR, rv, c,
-                      "could not resolve address of OCSP responder %s", 
+                      "could not resolve address of OCSP responder %s",
                       uri->hostinfo);
         return NULL;
     }
-    
-    /* establish a connection to the OCSP responder */ 
-    ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c, 
+
+    /* establish a connection to the OCSP responder */
+    ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c,
                   "connecting to OCSP responder '%s'", uri->hostinfo);
 
     /* Cycle through address until a connect() succeeds. */
@@ -100,14 +100,14 @@ static apr_socket_t *send_request(BIO *r
         return NULL;
     }
 
-    /* send the request and get a response */ 
-    ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c, 
+    /* send the request and get a response */
+    ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c,
                  "sending request to OCSP responder");
 
     while ((len = BIO_read(request, buf, sizeof buf)) > 0) {
         char *wbuf = buf;
         apr_size_t remain = len;
-        
+
         do {
             apr_size_t wlen = remain;
 
@@ -145,7 +145,7 @@ static char *get_line(apr_bucket_brigade
                       "failed reading line from OCSP server");
         return NULL;
     }
-    
+
     rv = apr_brigade_pflatten(bbout, &line, &len, p);
     if (rv) {
         ap_log_cerror(APLOG_MARK, APLOG_ERR, rv, c,
@@ -248,7 +248,7 @@ static OCSP_RESPONSE *read_response(apr_
             return NULL;
         }
         ap_log_cerror(APLOG_MARK, APLOG_DEBUG, 0, c,
-                      "OCSP response: got %" APR_SIZE_T_FMT 
+                      "OCSP response: got %" APR_SIZE_T_FMT
                       " bytes, %" APR_SIZE_T_FMT " total", len, count);
 
         BIO_write(bio, data, (int)len);
@@ -273,7 +273,7 @@ static OCSP_RESPONSE *read_response(apr_
 OCSP_RESPONSE *modssl_dispatch_ocsp_request(const apr_uri_t *uri,
                                             apr_interval_time_t timeout,
                                             OCSP_REQUEST *request,
-                                            conn_rec *c, apr_pool_t *p) 
+                                            conn_rec *c, apr_pool_t *p)
 {
     OCSP_RESPONSE *response = NULL;
     apr_socket_t *sd;
@@ -286,7 +286,7 @@ OCSP_RESPONSE *modssl_dispatch_ocsp_requ
                       "could not serialize OCSP request");
         return NULL;
     }
-    
+
     sd = send_request(bio, uri, timeout, c, p);
     if (sd == NULL) {
         /* Errors already logged. */

Modified: httpd/httpd/trunk/modules/ssl/ssl_util_ssl.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_util_ssl.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_util_ssl.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_util_ssl.c Fri Sep 23 13:39:32 2011
@@ -297,7 +297,7 @@ char *SSL_X509_NAME_ENTRY_to_string(apr_
     return result;
 }
 
-/* 
+/*
  * convert an X509_NAME to an RFC 2253 formatted string, optionally truncated
  * to maxlen characters (specify a maxlen of 0 for no length limit)
  */

Modified: httpd/httpd/trunk/modules/ssl/ssl_util_stapling.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/ssl/ssl_util_stapling.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/ssl/ssl_util_stapling.c (original)
+++ httpd/httpd/trunk/modules/ssl/ssl_util_stapling.c Fri Sep 23 13:39:32 2011
@@ -206,7 +206,7 @@ static BOOL stapling_cache_response(serv
     if (ok == TRUE) {
         *p++ = 1;
         expiry = apr_time_from_sec(mctx->stapling_cache_timeout);
-    } 
+    }
     else {
         *p++ = 0;
         expiry = apr_time_from_sec(mctx->stapling_errcache_timeout);
@@ -322,7 +322,7 @@ static int stapling_check_response(serve
         /* If ID not present just pass back to client */
         ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
                      "stapling_check_response: certificate ID not present in response!");
-    } 
+    }
     else {
         if (OCSP_check_validity(thisupd, nextupd,
                                 mctx->stapling_resptime_skew,
@@ -338,7 +338,7 @@ static int stapling_check_response(serve
             if (pok) {
                 ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
                              "stapling_check_response: response times invalid");
-            } 
+            }
             else {
                 ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, s,
                              "stapling_check_response: cached response expired");
@@ -406,7 +406,7 @@ static BOOL stapling_renew_response(serv
                       ocspuri);
         rv = FALSE;
         goto done;
-    } 
+    }
     else if (strcmp(uri.scheme, "http")) {
         ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
                      "stapling_renew_response: Unsupported uri %s", ocspuri);
@@ -432,7 +432,7 @@ static BOOL stapling_renew_response(serv
         else {
             goto done;
         }
-    } 
+    }
     else {
         int response_status = OCSP_response_status(*prsp);
 
@@ -444,7 +444,7 @@ static BOOL stapling_renew_response(serv
                 ap_log_error(APLOG_MARK, APLOG_ERR, 0, s,
                              "stapling_renew_response: error in retreived response!");
             }
-        } 
+        }
         else {
             ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, s,
                          "stapling_renew_response: responder error %s",

Modified: httpd/httpd/trunk/modules/test/mod_dialup.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/modules/test/mod_dialup.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/modules/test/mod_dialup.c (original)
+++ httpd/httpd/trunk/modules/test/mod_dialup.c Fri Sep 23 13:39:32 2011
@@ -49,14 +49,14 @@ dialup_send_pulse(dialup_baton_t *db)
     int status;
     apr_off_t len = 0;
     apr_size_t bytes_sent = 0;
-    
+
     while (!APR_BRIGADE_EMPTY(db->bb) && bytes_sent < db->bytes_per_second) {
         apr_bucket *e;
 
         if (db->r->connection->aborted) {
             return HTTP_INTERNAL_SERVER_ERROR;
         }
-        
+
         status = apr_brigade_partition(db->bb, db->bytes_per_second, &e);
 
         if (status != APR_SUCCESS && status != APR_INCOMPLETE) {
@@ -74,9 +74,9 @@ dialup_send_pulse(dialup_baton_t *db)
         else {
             APR_BRIGADE_CONCAT(db->tmpbb, db->bb);
         }
-        
+
         e = apr_bucket_flush_create(db->r->connection->bucket_alloc);
-        
+
         APR_BRIGADE_INSERT_TAIL(db->tmpbb, e);
 
         apr_brigade_length(db->tmpbb, 1, &len);
@@ -100,7 +100,7 @@ dialup_send_pulse(dialup_baton_t *db)
     }
 }
 
-static void 
+static void
 dialup_callback(void *baton)
 {
     int status;
@@ -142,8 +142,8 @@ dialup_handler(request_rec *r)
 
 
     /* See core.c, default handler for all of the cases we just decline. */
-    if (r->method_number != M_GET || 
-        r->finfo.filetype == APR_NOFILE || 
+    if (r->method_number != M_GET ||
+        r->finfo.filetype == APR_NOFILE ||
         r->finfo.filetype == APR_DIR) {
         return DECLINED;
     }
@@ -183,7 +183,7 @@ dialup_handler(request_rec *r)
     }
 
     db = apr_palloc(r->pool, sizeof(dialup_baton_t));
-    
+
     db->bb = apr_brigade_create(r->pool, r->connection->bucket_alloc);
     db->tmpbb = apr_brigade_create(r->pool, r->connection->bucket_alloc);
 
@@ -194,8 +194,8 @@ dialup_handler(request_rec *r)
         apr_bucket_file_enable_mmap(e, 0);
     }
 #endif
-    
-    
+
+
     db->bytes_per_second = dcfg->bytes_per_second;
     db->r = r;
     db->fd = fd;
@@ -256,7 +256,7 @@ cmd_modem_standard(cmd_parms *cmd,
     const modem_speed_t *standard;
     int i = 0;
     dialup_dcfg_t *dcfg = (dialup_dcfg_t*)dconf;
-    
+
     dcfg->bytes_per_second = 0;
 
     while (modem_bitrates[i].name != NULL) {
@@ -279,7 +279,7 @@ static void *
 dialup_dcfg_create(apr_pool_t *p, char *dummy)
 {
     dialup_dcfg_t *cfg = apr_palloc(p, sizeof(dialup_dcfg_t));
-    
+
     cfg->bytes_per_second = 0;
 
     return cfg;

Modified: httpd/httpd/trunk/server/config.c
URL: http://svn.apache.org/viewvc/httpd/httpd/trunk/server/config.c?rev=1174751&r1=1174750&r2=1174751&view=diff
==============================================================================
--- httpd/httpd/trunk/server/config.c (original)
+++ httpd/httpd/trunk/server/config.c Fri Sep 23 13:39:32 2011
@@ -2083,7 +2083,7 @@ AP_CORE_DECLARE(int) ap_parse_htaccess(a
                 && !APR_STATUS_IS_ENOTDIR(status)) {
                 ap_log_rerror(APLOG_MARK, APLOG_CRIT, status, r,
                               "%s pcfg_openfile: unable to check htaccess file, "
-                              "ensure it is readable and that '%s' " 
+                              "ensure it is readable and that '%s' "
                               "is executable",
                               filename, d);
                 apr_table_setn(r->notes, "error-notes",