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 2016/08/25 12:48:19 UTC

svn commit: r1757669 [2/2] - in /httpd/httpd/branches/2.4.x: ./ include/ modules/ modules/aaa/ modules/arch/netware/ modules/arch/win32/ modules/cache/ modules/cluster/ modules/core/ modules/dav/main/ modules/examples/ modules/http/ modules/http2/ modu...

Modified: httpd/httpd/branches/2.4.x/modules/proxy/mod_proxy_ajp.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/proxy/mod_proxy_ajp.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/proxy/mod_proxy_ajp.c (original)
+++ httpd/httpd/branches/2.4.x/modules/proxy/mod_proxy_ajp.c Thu Aug 25 12:48:18 2016
@@ -141,7 +141,7 @@ static apr_off_t get_content_length(requ
  * XXX: AJP Auto Flushing
  *
  * When processing CMD_AJP13_SEND_BODY_CHUNK AJP messages we will do a poll
- * with FLUSH_WAIT miliseconds timeout to determine if more data is currently
+ * with FLUSH_WAIT milliseconds timeout to determine if more data is currently
  * available at the backend. If there is no more data available, we flush
  * the data to the client by adding a flush bucket to the brigade we pass
  * up the filter chain.
@@ -358,7 +358,7 @@ static int ap_proxy_ajp_request(apr_pool
         }
         return HTTP_INTERNAL_SERVER_ERROR;
     }
-    /* parse the reponse */
+    /* parse the response */
     result = ajp_parse_type(r, conn->data);
     output_brigade = apr_brigade_create(p, r->connection->bucket_alloc);
 

Modified: httpd/httpd/branches/2.4.x/modules/proxy/proxy_util.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/proxy/proxy_util.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/proxy/proxy_util.c (original)
+++ httpd/httpd/branches/2.4.x/modules/proxy/proxy_util.c Thu Aug 25 12:48:18 2016
@@ -1798,13 +1798,13 @@ PROXY_DECLARE(apr_status_t) ap_proxy_ini
             if (worker->s->smax == -1 || worker->s->smax > worker->s->hmax) {
                 worker->s->smax = worker->s->hmax;
             }
-            /* Set min to be lower then smax */
+            /* Set min to be lower than smax */
             if (worker->s->min > worker->s->smax) {
                 worker->s->min = worker->s->smax;
             }
         }
         else {
-            /* This will supress the apr_reslist creation */
+            /* This will suppress the apr_reslist creation */
             worker->s->min = worker->s->smax = worker->s->hmax = 0;
         }
     }
@@ -2328,7 +2328,7 @@ ap_proxy_determine_connection(apr_pool_t
                 }
 
                 /*
-                 * Worker can have the single constant backend adress.
+                 * Worker can have the single constant backend address.
                  * The single DNS lookup is used once per worker.
                  * If dynamic change is needed then set the addr to NULL
                  * inside dynamic config to force the lookup.
@@ -3469,7 +3469,7 @@ PROXY_DECLARE(int) ap_proxy_create_hdrbr
      *
      * The HTTP/1.1 Via: header is designed for passing client
      * information through proxies to a server, and should be used in
-     * a forward proxy configuation instead of X-Forwarded-*. See the
+     * a forward proxy configuration instead of X-Forwarded-*. See the
      * ProxyVia option for details.
      */
     if (dconf->add_forwarded_headers) {

Modified: httpd/httpd/branches/2.4.x/modules/slotmem/mod_slotmem_shm.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/slotmem/mod_slotmem_shm.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/slotmem/mod_slotmem_shm.c (original)
+++ httpd/httpd/branches/2.4.x/modules/slotmem/mod_slotmem_shm.c Thu Aug 25 12:48:18 2016
@@ -753,7 +753,7 @@ static const ap_slotmem_provider_t stora
     &slotmem_fgrab
 };
 
-/* make the storage usuable from outside */
+/* make the storage usable from outside */
 static const ap_slotmem_provider_t *slotmem_shm_getstorage(void)
 {
     return (&storage);

Modified: httpd/httpd/branches/2.4.x/modules/ssl/README
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/ssl/README?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/ssl/README (original)
+++ httpd/httpd/branches/2.4.x/modules/ssl/README Thu Aug 25 12:48:18 2016
@@ -59,7 +59,7 @@ DATA STRUCTURES
  For an overview how these are related and chained together have a look at the
  page in README.dsov.{fig,ps}. It contains overview diagrams for those data
  structures. It's designed for DIN A4 paper size, but you can easily generate
- a smaller version inside XFig by specifing a magnification on the Export
+ a smaller version inside XFig by specifying a magnification on the Export
  panel.
 
 INCOMPATIBILITIES
@@ -81,7 +81,7 @@ MAJOR CHANGES
  o The DBM based session cache is now based on APR's DBM API only.
  o The shared memory based session cache is now based on APR's APIs.
  o SSL I/O is now implemented in terms of filters rather than BUFF
- o Eliminated ap_global_ctx. Storing Persistant information in 
+ o Eliminated ap_global_ctx. Storing Persistent information in 
    process_rec->pool->user_data. The ssl_pphrase_Handle_CB() and 
    ssl_config_global_* () functions have an extra parameter now - 
    "server_rec *" -  which is used to retrieve the SSLModConfigRec.

Modified: httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_init.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_init.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_init.c (original)
+++ httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_init.c Thu Aug 25 12:48:18 2016
@@ -924,7 +924,7 @@ static apr_status_t ssl_init_ctx_cert_ch
      * SSLCACertificateFile and also use client authentication mod_ssl
      * would accept all clients also issued by this CA. Obviously this
      * isn't what we want in this situation. So this feature here exists
-     * to allow one to explicity configure CA certificates which are
+     * to allow one to explicitly configure CA certificates which are
      * used only for the server certificate chain.
      */
     if (!chain) {

Modified: httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_io.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_io.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_io.c (original)
+++ httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_io.c Thu Aug 25 12:48:18 2016
@@ -218,7 +218,7 @@ static int bio_filter_out_write(BIO *bio
      *
      * Historically, this flush call was performed only for an SSLv2
      * connection or for a proxy connection.  Calling _out_flush can
-     * be expensive in cases where requests/reponses are pipelined,
+     * be expensive in cases where requests/responses are pipelined,
      * so limit the performance impact to handshake time.
      */
 #if OPENSSL_VERSION_NUMBER < 0x0009080df

Modified: httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_kernel.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_kernel.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_kernel.c (original)
+++ httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_kernel.c Thu Aug 25 12:48:18 2016
@@ -1017,7 +1017,7 @@ int ssl_hook_Access(request_rec *r)
                 return HTTP_FORBIDDEN;
             }
 
-            /* Full renegotiation successfull, we now have handshaken with
+            /* Full renegotiation successful, we now have handshaken with
              * this server's parameters.
              */
             sslconn->server = r->server;
@@ -1159,7 +1159,7 @@ int ssl_hook_Access(request_rec *r)
  *  Fake a Basic authentication from the X509 client certificate.
  *
  *  This must be run fairly early on to prevent a real authentication from
- *  occuring, in particular it must be run before anything else that
+ *  occurring, in particular it must be run before anything else that
  *  authenticates a user.  This means that the Module statement for this
  *  module should be LAST in the Configuration file.
  */

Modified: httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_vars.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_vars.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_vars.c (original)
+++ httpd/httpd/branches/2.4.x/modules/ssl/ssl_engine_vars.c Thu Aug 25 12:48:18 2016
@@ -1083,7 +1083,7 @@ apr_array_header_t *ssl_ext_list(apr_poo
     }
 
     count = X509_get_ext_count(xs);
-    /* Create an array large enough to accomodate every extension. This is
+    /* Create an array large enough to accommodate every extension. This is
      * likely overkill, but safe.
      */
     array = apr_array_make(p, count, sizeof(char *));

Modified: httpd/httpd/branches/2.4.x/os/bs2000/ebcdic.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/os/bs2000/ebcdic.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/os/bs2000/ebcdic.c (original)
+++ httpd/httpd/branches/2.4.x/os/bs2000/ebcdic.c Thu Aug 25 12:48:18 2016
@@ -25,7 +25,7 @@ Within the POSIX subsystem, the same cha
 "native BS2000", namely EBCDIC.
 
 EBCDIC Table. (Yes, in EBCDIC, the letters 'a'..'z' are not contiguous!)
-This apr_table_t is bijective, i.e. there are no ambigous or duplicate characters
+This apr_table_t is bijective, i.e. there are no ambiguous or duplicate characters
 00    00 01 02 03 85 09 86 7f  87 8d 8e 0b 0c 0d 0e 0f  *................*
 10    10 11 12 13 8f 0a 08 97  18 19 9c 9d 1c 1d 1e 1f  *................*
 20    80 81 82 83 84 92 17 1b  88 89 8a 8b 8c 05 06 07  *................*

Modified: httpd/httpd/branches/2.4.x/os/netware/pre_nw.h
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/os/netware/pre_nw.h?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/os/netware/pre_nw.h (original)
+++ httpd/httpd/branches/2.4.x/os/netware/pre_nw.h Thu Aug 25 12:48:18 2016
@@ -55,7 +55,7 @@
 #endif
 #endif
 
-/* C9X defintion used by MSL C++ library */
+/* C9X definition used by MSL C++ library */
 #define DECIMAL_DIG 17
 
 /* some code may want to use the MS convention for long long */

Modified: httpd/httpd/branches/2.4.x/os/win32/ap_regkey.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/os/win32/ap_regkey.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/os/win32/ap_regkey.c (original)
+++ httpd/httpd/branches/2.4.x/os/win32/ap_regkey.c Thu Aug 25 12:48:18 2016
@@ -488,7 +488,7 @@ AP_DECLARE(apr_status_t) ap_regkey_value
 #if APR_HAS_ANSI_FS
     ELSE_WIN_OS_IS_ANSI
     {
-        /* Small possiblity the array is either unterminated
+        /* Small possibility the array is either unterminated
          * or single NULL terminated.  Avert.
          */
         buf = (char *)value;

Modified: httpd/httpd/branches/2.4.x/server/config.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/config.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/config.c (original)
+++ httpd/httpd/branches/2.4.x/server/config.c Thu Aug 25 12:48:18 2016
@@ -15,7 +15,7 @@
  */
 
 /*
- * http_config.c: once was auxillary functions for reading httpd's config
+ * http_config.c: once was auxiliary functions for reading httpd's config
  * file and converting filenames into a namespace
  *
  * Rob McCool
@@ -737,7 +737,7 @@ AP_DECLARE(void) ap_remove_loaded_module
      *
      *  Note: 1. We cannot determine if the module was successfully
      *           removed by ap_remove_module().
-     *        2. We have not to complain explicity when the module
+     *        2. We have not to complain explicitly when the module
      *           is not found because ap_remove_module() did it
      *           for us already.
      */
@@ -1326,7 +1326,7 @@ static const char *ap_walk_config_sub(co
         if (retval != NULL && strcmp(retval, DECLINE_CMD) != 0) {
             /* If the directive in error has already been set, don't
              * replace it.  Otherwise, an error inside a container
-             * will be reported as occuring on the first line of the
+             * will be reported as occurring on the first line of the
              * container.
              */
             if (!parms->err_directive) {

Modified: httpd/httpd/branches/2.4.x/server/gen_test_char.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/gen_test_char.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/gen_test_char.c (original)
+++ httpd/httpd/branches/2.4.x/server/gen_test_char.c Thu Aug 25 12:48:18 2016
@@ -90,7 +90,7 @@ int main(int argc, char *argv[])
          * since Win32/OS2 use carets or doubled-double quotes,
          * and neither lf nor cr can be escaped.  We escape unix
          * specific as well, to assure that cross-compiled unix
-         * applications behave similiarly when invoked on win32/os2.
+         * applications behave similarly when invoked on win32/os2.
          *
          * Rem please keep in-sync with apr's list in win32/filesys.c
          */

Modified: httpd/httpd/branches/2.4.x/server/listen.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/listen.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/listen.c (original)
+++ httpd/httpd/branches/2.4.x/server/listen.c Thu Aug 25 12:48:18 2016
@@ -763,7 +763,7 @@ AP_DECLARE(void) ap_listen_pre_config(vo
     /* Check once whether or not SO_REUSEPORT is supported. */
     if (ap_have_so_reuseport < 0) {
         /* This is limited to Linux with defined SO_REUSEPORT (ie. 3.9+) for
-         * now since the implementation evenly distributes connections accross
+         * now since the implementation evenly distributes connections across
          * all the listening threads/processes.
          *
          * *BSDs have SO_REUSEPORT too but with a different semantic: the first

Modified: httpd/httpd/branches/2.4.x/server/mpm/event/event.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/mpm/event/event.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/mpm/event/event.c (original)
+++ httpd/httpd/branches/2.4.x/server/mpm/event/event.c Thu Aug 25 12:48:18 2016
@@ -347,7 +347,7 @@ typedef struct event_retained_data {
 #endif
     int hold_off_on_exponential_spawning;
     /*
-     * Current number of listeners buckets and maximum reached accross
+     * Current number of listeners buckets and maximum reached across
      * restarts (to size retained data according to dynamic num_buckets,
      * eg. idle_spawn_rate).
      */
@@ -2830,7 +2830,7 @@ static int event_run(apr_pool_t * _pconf
     if (ap_daemons_to_start < num_buckets)
         ap_daemons_to_start = num_buckets;
     /* We want to create as much children at a time as the number of buckets,
-     * so to optimally accept connections (evenly distributed accross buckets).
+     * so to optimally accept connections (evenly distributed across buckets).
      * Thus min_spare_threads should at least maintain num_buckets children,
      * and max_spare_threads allow num_buckets more children w/o triggering
      * immediately (e.g. num_buckets idle threads margin, one per bucket).

Modified: httpd/httpd/branches/2.4.x/server/mpm/prefork/prefork.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/mpm/prefork/prefork.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/mpm/prefork/prefork.c (original)
+++ httpd/httpd/branches/2.4.x/server/mpm/prefork/prefork.c Thu Aug 25 12:48:18 2016
@@ -703,7 +703,7 @@ static void child_main(int child_num_arg
         SAFE_ACCEPT(accept_mutex_off());      /* unlock after "accept" */
 
         if (status == APR_EGENERAL) {
-            /* resource shortage or should-not-occur occured */
+            /* resource shortage or should-not-occur occurred */
             clean_child_exit(APEXIT_CHILDSICK);
         }
         else if (status != APR_SUCCESS) {

Modified: httpd/httpd/branches/2.4.x/server/mpm/winnt/mpm_winnt.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/mpm/winnt/mpm_winnt.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/mpm/winnt/mpm_winnt.c (original)
+++ httpd/httpd/branches/2.4.x/server/mpm/winnt/mpm_winnt.c Thu Aug 25 12:48:18 2016
@@ -1004,7 +1004,7 @@ static void winnt_rewrite_args(process_r
      *   -k config
      *   -k uninstall
      *   -k stop
-     *   -k shutdown (same as -k stop). Maintained for backward compatability.
+     *   -k shutdown (same as -k stop). Maintained for backward compatibility.
      *
      * We can't leave this phase until we know our identity
      * and modify the command arguments appropriately.
@@ -1050,7 +1050,7 @@ static void winnt_rewrite_args(process_r
         my_pid = GetCurrentProcessId();
         parent_pid = (DWORD) atol(pid);
 
-        /* Prevent holding open the (nonexistant) console */
+        /* Prevent holding open the (nonexistent) console */
         ap_real_exit_code = 0;
 
         /* The parent gave us stdin, we need to remember this

Modified: httpd/httpd/branches/2.4.x/server/mpm/winnt/service.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/mpm/winnt/service.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/mpm/winnt/service.c (original)
+++ httpd/httpd/branches/2.4.x/server/mpm/winnt/service.c Thu Aug 25 12:48:18 2016
@@ -104,7 +104,7 @@ static APR_INLINE SC_HANDLE OpenSCManage
  *
  * If ap_real_exit_code is reset to 0, it will not be set or trigger this
  * behavior on exit.  All service and child processes are expected to
- * reset this flag to zero to avoid undesireable side effects.
+ * reset this flag to zero to avoid undesirable side effects.
  */
 AP_DECLARE_DATA int ap_real_exit_code = 1;
 

Modified: httpd/httpd/branches/2.4.x/server/mpm/worker/worker.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/mpm/worker/worker.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/mpm/worker/worker.c (original)
+++ httpd/httpd/branches/2.4.x/server/mpm/worker/worker.c Thu Aug 25 12:48:18 2016
@@ -168,7 +168,7 @@ typedef struct worker_retained_data {
 #endif
     int hold_off_on_exponential_spawning;
     /*
-     * Current number of listeners buckets and maximum reached accross
+     * Current number of listeners buckets and maximum reached across
      * restarts (to size retained data according to dynamic num_buckets,
      * eg. idle_spawn_rate).
      */
@@ -1837,7 +1837,7 @@ static int worker_run(apr_pool_t *_pconf
     if (ap_daemons_to_start < num_buckets)
         ap_daemons_to_start = num_buckets;
     /* We want to create as much children at a time as the number of buckets,
-     * so to optimally accept connections (evenly distributed accross buckets).
+     * so to optimally accept connections (evenly distributed across buckets).
      * Thus min_spare_threads should at least maintain num_buckets children,
      * and max_spare_threads allow num_buckets more children w/o triggering
      * immediately (e.g. num_buckets idle threads margin, one per bucket).

Modified: httpd/httpd/branches/2.4.x/server/vhost.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/server/vhost.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/server/vhost.c (original)
+++ httpd/httpd/branches/2.4.x/server/vhost.c Thu Aug 25 12:48:18 2016
@@ -228,7 +228,7 @@ const char *ap_parse_vhost_addrs(apr_poo
     server_addr_rec **addrs;
     const char *err;
 
-    /* start the list of addreses */
+    /* start the list of addresses */
     addrs = &s->addrs;
     while (hostname[0]) {
         err = get_addresses(p, ap_getword_conf(p, &hostname), &addrs, s->port);
@@ -574,7 +574,7 @@ AP_DECLARE(void) ap_fini_vhost_config(ap
 
     /* The next things to go into the hash table are the virtual hosts
      * themselves.  They're listed off of main_s->next in the reverse
-     * order they occured in the config file, so we insert them at
+     * order they occurred in the config file, so we insert them at
      * the iphash_table_tail but don't advance the tail.
      */
 

Modified: httpd/httpd/branches/2.4.x/support/checkgid.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/support/checkgid.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/support/checkgid.c (original)
+++ httpd/httpd/branches/2.4.x/support/checkgid.c Thu Aug 25 12:48:18 2016
@@ -15,7 +15,7 @@
  */
 
 /*
- * Given one or more group identifers on the command line (e.g.,
+ * Given one or more group identifiers on the command line (e.g.,
  * "httpd" or "#-1"), figure out whether they'll be valid for
  * the server to use at run-time.
  *

Modified: httpd/httpd/branches/2.4.x/support/htcacheclean.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/support/htcacheclean.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/support/htcacheclean.c (original)
+++ httpd/httpd/branches/2.4.x/support/htcacheclean.c Thu Aug 25 12:48:18 2016
@@ -1046,9 +1046,9 @@ static void purge(char *path, apr_pool_t
          return;
     }
 
-    /* process remaining entries oldest to newest, the check for an emtpy
+    /* process remaining entries oldest to newest, the check for an empty
      * ring actually isn't necessary except when the compiler does
-     * corrupt 64bit arithmetics which happend to me once, so better safe
+     * corrupt 64bit arithmetics which happened to me once, so better safe
      * than sorry
      */
     while (!((!s.max || s.sum <= s.max) && (!s.inodes || s.nodes <= s.inodes))

Modified: httpd/httpd/branches/2.4.x/support/logresolve.c
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/support/logresolve.c?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/support/logresolve.c (original)
+++ httpd/httpd/branches/2.4.x/support/logresolve.c Thu Aug 25 12:48:18 2016
@@ -258,7 +258,7 @@ int main(int argc, const char * const ar
         resolves++;
 
         /* From here on our we cache each result, even if it was not
-         * succesful
+         * successful
          */
         cachesize++;
 

Modified: httpd/httpd/branches/2.4.x/support/logresolve.pl.in
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/support/logresolve.pl.in?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/support/logresolve.pl.in (original)
+++ httpd/httpd/branches/2.4.x/support/logresolve.pl.in Thu Aug 25 12:48:18 2016
@@ -41,7 +41,7 @@
 # logfile lines processed per hour compared to ~45,000 per hour
 # with 'logresolve'.
 #
-# I haven't yet seen any noticable reduction in the percentage of IPs
+# I haven't yet seen any noticeable reduction in the percentage of IPs
 # that fail to get resolved. Your mileage will no doubt vary. 5s is long
 # enough to wait IMO.
 #
@@ -207,7 +207,7 @@ sub nslookup {
 
 	 # do the hostname lookup inside an eval. The eval will use the
 	 # already configured SIGnal handler and drop out of the {} block
-	 # regardless of whether the alarm occured or not.
+	 # regardless of whether the alarm occurred or not.
 	eval {
 		alarm($TIMEOUT);
 		$hostname = gethostbyaddr(gethostbyname($ip), AF_INET);

Modified: httpd/httpd/branches/2.4.x/test/make_sni.sh
URL: http://svn.apache.org/viewvc/httpd/httpd/branches/2.4.x/test/make_sni.sh?rev=1757669&r1=1757668&r2=1757669&view=diff
==============================================================================
--- httpd/httpd/branches/2.4.x/test/make_sni.sh (original)
+++ httpd/httpd/branches/2.4.x/test/make_sni.sh Thu Aug 25 12:48:18 2016
@@ -82,7 +82,7 @@ do
 done
 
 if [ $# = 1 ]; then
-    echo "Aborted - just specifing one vhost makes no sense for SNI testing. Go wild !"
+    echo "Aborted - just specifying one vhost makes no sense for SNI testing. Go wild !"
     exit 1
 fi