You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@httpd.apache.org by ji...@apache.org on 2005/11/10 16:16:24 UTC

svn commit: r332307 [5/5] - in /httpd/httpd/branches/2.2.x: modules/aaa/ modules/arch/netware/ modules/arch/win32/ modules/cache/ modules/dav/fs/ modules/dav/main/ modules/debug/ modules/experimental/ modules/filters/ modules/generators/ modules/http/ ...

Modified: httpd/httpd/branches/2.2.x/server/core.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/core.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/core.c (original)
+++ httpd/httpd/branches/2.2.x/server/core.c Thu Nov 10 07:15:41 2005
@@ -260,7 +260,7 @@
     }
 
     if (!(new->override_opts & OPT_UNSET)) {
-	conf->override_opts = new->override_opts;
+        conf->override_opts = new->override_opts;
     }
 
     if (new->ap_default_type) {
@@ -750,7 +750,7 @@
                                                       &core_module);
 
     if (dirconf->response_code_strings == NULL) {
-	return NULL;
+        return NULL;
     }
 
     if (dirconf->response_code_strings[error_index] == &errordocument_default) {
@@ -1343,21 +1343,21 @@
     while (l[0]) {
         w = ap_getword_conf(cmd->pool, &l);
 
-	k = w;
-	v = strchr(k, '=');
-	if (v) {
-		*v++ = '\0';
-	}
+        k = w;
+        v = strchr(k, '=');
+        if (v) {
+                *v++ = '\0';
+        }
 
         if (!strcasecmp(w, "Limit")) {
             d->override |= OR_LIMIT;
         }
         else if (!strcasecmp(k, "Options")) {
             d->override |= OR_OPTIONS;
-	    if (v) 
+            if (v) 
                 set_allow_opts(cmd, &(d->override_opts), v);
-	    else
-	        d->override_opts = OPT_ALL;
+            else
+                d->override_opts = OPT_ALL;
         }
         else if (!strcasecmp(w, "FileInfo")) {
             d->override |= OR_FILEINFO;
@@ -1437,8 +1437,8 @@
             return apr_pstrcat(cmd->pool, "Illegal option ", w, NULL);
         }
 
-	if (!(cmd->override_opts & opt) && opt != OPT_NONE) {
-	    return apr_pstrcat(cmd->pool, "Option ", w, " not allowed here", NULL);
+        if (!(cmd->override_opts & opt) && opt != OPT_NONE) {
+            return apr_pstrcat(cmd->pool, "Option ", w, " not allowed here", NULL);
         }
         else if (action == '-') {
             /* we ensure the invariant (d->opts_add & d->opts_remove) == 0 */

Modified: httpd/httpd/branches/2.2.x/server/mpm/beos/beos.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/beos/beos.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/beos/beos.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/beos/beos.c Thu Nov 10 07:15:41 2005
@@ -296,7 +296,7 @@
     if (APR_STATUS_IS_EINTR(status)) {
         return status;
     }
-	/* This switch statement provides us with better error details. */
+        /* This switch statement provides us with better error details. */
     switch (status) {
 #ifdef ECONNABORTED
         case ECONNABORTED:
@@ -376,7 +376,7 @@
     /* These next two are handled by sig_term */
     sa.sa_handler = sig_term;
     if (sigaction(SIGTERM, &sa, NULL) < 0)
-	    ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGTERM)");
+            ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGTERM)");
     if (sigaction(SIGINT, &sa, NULL) < 0)
         ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGINT)");
     
@@ -393,7 +393,7 @@
     if (sigaction(SIGHUP, &sa, NULL) < 0)
     	ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGHUP)");
     if (sigaction(AP_SIG_GRACEFUL, &sa, NULL) < 0)
-	    ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(" AP_SIG_GRACEFUL_STRING ")");
+            ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(" AP_SIG_GRACEFUL_STRING ")");
 }
 
 /*****************************************************************
@@ -489,7 +489,7 @@
 
     mpm_state = AP_MPMQ_RUNNING;
 
-	while (!this_worker_should_exit) {
+        while (!this_worker_should_exit) {
         conn_rec *current_conn;
         void *csd;
 
@@ -603,7 +603,7 @@
     thread_id tid;
 
     if (slot + 1 > ap_max_child_assigned)
-	    ap_max_child_assigned = slot + 1;
+            ap_max_child_assigned = slot + 1;
 
     (void) ap_update_child_status_from_indexes(0, slot, SERVER_STARTING, (request_rec*)NULL);
 
@@ -663,7 +663,7 @@
             continue;
 
         if (make_worker(i) < 0)
-	        break;
+                break;
 
         --number_to_start;
     }
@@ -704,23 +704,23 @@
         }
 
     	if (i >= ap_max_child_assigned && free_length >= spawn_rate) {
-	         break;
-	    }
+                 break;
+            }
     }
     ap_max_child_assigned = last_non_dead + 1;
 
     if (free_length > 0) {
     	for (i = 0; i < free_length; ++i) {
-	        make_worker(free_slots[i]);
-	    }
-	    /* the next time around we want to spawn twice as many if this
-	     * wasn't good enough, but not if we've just done a graceful
-	     */
-	    if (hold_off_on_exponential_spawning) {
-	        --hold_off_on_exponential_spawning;
-	    } else if (spawn_rate < MAX_SPAWN_RATE) {
-	        spawn_rate *= 2;
-	    }
+                make_worker(free_slots[i]);
+            }
+            /* the next time around we want to spawn twice as many if this
+             * wasn't good enough, but not if we've just done a graceful
+             */
+            if (hold_off_on_exponential_spawning) {
+                --hold_off_on_exponential_spawning;
+            } else if (spawn_rate < MAX_SPAWN_RATE) {
+                spawn_rate *= 2;
+            }
     } else {
         spawn_rate = 1;
     }
@@ -759,13 +759,13 @@
                                                            (request_rec*)NULL);
                 
                 if (remaining_threads_to_start
-		            && child_slot < ap_thread_limit) {
+                            && child_slot < ap_thread_limit) {
                     /* we're still doing a 1-for-1 replacement of dead
                      * children with new children
                      */
                     make_worker(child_slot);
                     --remaining_threads_to_start;
-		        }
+                        }
 /* TODO
 #if APR_HAS_OTHER_CHILD
             }
@@ -779,9 +779,9 @@
                  * child.
                  */
                  ap_log_error(APLOG_MARK, APLOG_WARNING, 0, ap_server_conf,
-			                  "long lost child came home! (pid %ld)", pid.pid);
+                                          "long lost child came home! (pid %ld)", pid.pid);
             }
-	    
+            
             /* Don't perform idle maintenance when a child dies,
              * only do it when there's a timeout.  Remember only a
              * finite number of children can die, and it's pretty
@@ -789,7 +789,7 @@
              */
              continue;
          }
-	     else if (remaining_threads_to_start) {
+             else if (remaining_threads_to_start) {
              /* we hit a 1 second timeout in which none of the previous
               * generation of children needed to be reaped... so assume
               * they're all done, and pick up the slack if any is left.
@@ -913,7 +913,7 @@
     remaining_threads_to_start = ap_threads_to_start;
     /* sanity check on the number to start... */
     if (remaining_threads_to_start > ap_thread_limit) {
-	    remaining_threads_to_start = ap_thread_limit;
+            remaining_threads_to_start = ap_thread_limit;
     }
 
     /* If we're doing the single process thing or we're in a graceful_restart
@@ -922,11 +922,11 @@
      * do we??
      */
     if (!is_graceful && !one_process) {
-	    startup_threads(remaining_threads_to_start);
-	    remaining_threads_to_start = 0;
+            startup_threads(remaining_threads_to_start);
+            remaining_threads_to_start = 0;
     } else {
-	    /* give the system some time to recover before kicking into
-	     * exponential mode */
+            /* give the system some time to recover before kicking into
+             * exponential mode */
         hold_off_on_exponential_spawning = 10;
     }
 
@@ -934,11 +934,11 @@
      * record that we've entered the world !
      */
     ap_log_error(APLOG_MARK, APLOG_NOTICE, 0, ap_server_conf,
-		"%s configured -- resuming normal operations",
-		ap_get_server_version());
+                "%s configured -- resuming normal operations",
+                ap_get_server_version());
 
     ap_log_error(APLOG_MARK, APLOG_INFO, 0, ap_server_conf,
-		"Server built: %s", ap_get_server_built());
+                "Server built: %s", ap_get_server_built());
 
     restart_pending = shutdown_pending = 0;
 
@@ -1003,16 +1003,16 @@
 
     if (is_graceful) {
         ap_log_error(APLOG_MARK, APLOG_NOTICE, 0, ap_server_conf,
-		    AP_SIG_GRACEFUL_STRING " received.  Doing graceful restart");
+                    AP_SIG_GRACEFUL_STRING " received.  Doing graceful restart");
     } else {
         /* Kill 'em all.  Since the child acts the same on the parents SIGTERM 
          * and a SIGHUP, we may as well use the same signal, because some user
          * pthreads are stealing signals from us left and right.
          */
-	    
+            
         ap_reclaim_child_processes(1);		/* Start with SIGTERM */
-	    ap_log_error(APLOG_MARK, APLOG_NOTICE, 0, ap_server_conf,
-		    "SIGHUP received.  Attempting to restart");
+            ap_log_error(APLOG_MARK, APLOG_NOTICE, 0, ap_server_conf,
+                    "SIGHUP received.  Attempting to restart");
     }
     
     /* just before we go, tidy up the lock we created to prevent a 
@@ -1070,7 +1070,7 @@
     ap_pid_fname = DEFAULT_PIDLOG;
     ap_max_requests_per_thread = DEFAULT_MAX_REQUESTS_PER_THREAD;
 #ifdef AP_MPM_WANT_SET_MAX_MEM_FREE
-	ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
+        ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
 #endif
 
     apr_cpystrn(ap_coredump_dir, ap_server_root, sizeof(ap_coredump_dir));

Modified: httpd/httpd/branches/2.2.x/server/mpm/experimental/event/fdqueue.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/experimental/event/fdqueue.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/experimental/event/fdqueue.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/experimental/event/fdqueue.c Thu Nov 10 07:15:41 2005
@@ -26,7 +26,7 @@
 struct fd_queue_info_t
 {
     apr_int32_t idlers;      /**
-	                          * 0 or positive: number of idle worker threads
+                                  * 0 or positive: number of idle worker threads
                               * negative: number of threads blocked waiting
                               *           for an idle worker
                               */

Modified: httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2.c Thu Nov 10 07:15:41 2005
@@ -269,15 +269,15 @@
 
     ap_scoreboard_image->global->restart_time = apr_time_now();
     ap_log_error(APLOG_MARK, APLOG_NOTICE, 0, ap_server_conf,
-		"%s configured -- resuming normal operations",
-		ap_get_server_version());
+                "%s configured -- resuming normal operations",
+                ap_get_server_version());
     ap_log_error(APLOG_MARK, APLOG_INFO, 0, ap_server_conf,
-		"Server built: %s", ap_get_server_built());
+                "Server built: %s", ap_get_server_built());
 #ifdef AP_MPM_WANT_SET_ACCEPT_LOCK_MECH
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, ap_server_conf,
-		"AcceptMutex: %s (default: %s)",
-		apr_proc_mutex_name(accept_mutex),
-		apr_proc_mutex_defname());
+                "AcceptMutex: %s (default: %s)",
+                apr_proc_mutex_name(accept_mutex),
+                apr_proc_mutex_defname());
 #endif
     if (one_process) {
         ap_scoreboard_image->parent[0].pid = getpid();
@@ -398,7 +398,7 @@
     sa.sa_handler = sig_term;
 
     if (sigaction(SIGTERM, &sa, NULL) < 0)
-	ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGTERM)");
+        ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGTERM)");
 
     if (sigaction(SIGINT, &sa, NULL) < 0)
         ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGINT)");
@@ -471,7 +471,7 @@
     ap_min_spare_threads = DEFAULT_MIN_SPARE_THREAD;
     ap_max_spare_threads = DEFAULT_MAX_SPARE_THREAD;
 #ifdef AP_MPM_WANT_SET_MAX_MEM_FREE
-	ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
+        ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
 #endif
 
     return OK;
@@ -501,7 +501,7 @@
 
 
 static const char *set_min_spare_threads(cmd_parms *cmd, void *dummy,
-					 const char *arg)
+                                         const char *arg)
 {
     const char *err = ap_check_cmd_context(cmd, GLOBAL_ONLY);
 
@@ -527,7 +527,7 @@
 
 
 static const char *set_max_spare_threads(cmd_parms *cmd, void *dummy,
-					 const char *arg)
+                                         const char *arg)
 {
     const char *err = ap_check_cmd_context(cmd, GLOBAL_ONLY);
 

Modified: httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2_child.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2_child.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2_child.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/mpmt_os2/mpmt_os2_child.c Thu Nov 10 07:15:41 2005
@@ -81,7 +81,7 @@
 static void clean_child_exit(int code)
 {
     if (pchild) {
-	apr_pool_destroy(pchild);
+        apr_pool_destroy(pchild);
     }
 
     exit(code);
@@ -471,10 +471,10 @@
     sa.sa_handler = sig_term;
 
     if (sigaction(SIGTERM, &sa, NULL) < 0)
-	ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGTERM)");
+        ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGTERM)");
 
     sa.sa_handler = sig_hup;
 
     if (sigaction(SIGHUP, &sa, NULL) < 0)
-	ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGHUP)");
+        ap_log_error(APLOG_MARK, APLOG_WARNING, errno, ap_server_conf, "sigaction(SIGHUP)");
 }

Modified: httpd/httpd/branches/2.2.x/server/mpm/netware/mpm_netware.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/netware/mpm_netware.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/netware/mpm_netware.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/netware/mpm_netware.c Thu Nov 10 07:15:41 2005
@@ -1127,7 +1127,7 @@
     	    ap_show_modules();
         }
         else if (!strnicmp("DIRECTIVES",&szcommandLine[iCommandLen],3)) {
-	        ap_show_directives();
+                ap_show_directives();
         }
         else if (!strnicmp("SHUTDOWN",&szcommandLine[iCommandLen],3)) {
             printf("Shutdown Requested...\n");

Modified: httpd/httpd/branches/2.2.x/server/mpm/winnt/child.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/winnt/child.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/winnt/child.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/winnt/child.c Thu Nov 10 07:15:41 2005
@@ -276,7 +276,7 @@
 
     new_job = (joblist *) malloc(sizeof(joblist));
     if (new_job == NULL) {
-	ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
+        ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
                      "Ouch!  Out of memory in add_job()!");
         return;
     }
@@ -286,10 +286,10 @@
     apr_thread_mutex_lock(allowed_globals.jobmutex);
 
     if (allowed_globals.jobtail != NULL)
-	allowed_globals.jobtail->next = new_job;
+        allowed_globals.jobtail->next = new_job;
     allowed_globals.jobtail = new_job;
     if (!allowed_globals.jobhead)
-	allowed_globals.jobhead = new_job;
+        allowed_globals.jobhead = new_job;
     allowed_globals.jobcount++;
     ReleaseSemaphore(allowed_globals.jobsemaphore, 1, NULL);
 
@@ -307,13 +307,13 @@
 
     if (shutdown_in_progress && !allowed_globals.jobhead) {
         apr_thread_mutex_unlock(allowed_globals.jobmutex);
-	return (INVALID_SOCKET);
+        return (INVALID_SOCKET);
     }
     job = allowed_globals.jobhead;
     ap_assert(job);
     allowed_globals.jobhead = job->next;
     if (allowed_globals.jobhead == NULL)
-	allowed_globals.jobtail = NULL;
+        allowed_globals.jobtail = NULL;
     apr_thread_mutex_unlock(allowed_globals.jobmutex);
     sock = job->sock;
     free(job);
@@ -356,9 +356,9 @@
     head_listener = ap_listeners;
 
     while (!shutdown_in_progress) {
-	tv.tv_sec = wait_time;
-	tv.tv_usec = 0;
-	memcpy(&main_fds, &listenfds, sizeof(fd_set));
+        tv.tv_sec = wait_time;
+        tv.tv_usec = 0;
+        memcpy(&main_fds, &listenfds, sizeof(fd_set));
 
         /* First parameter of select() is ignored on Windows */
         rc = select(0, &main_fds, NULL, NULL, &tv);
@@ -381,30 +381,30 @@
                              "Too many errors in select loop. Child process exiting.");
                 break;
             }
-	} else {
-	    ap_listen_rec *lr;
+        } else {
+            ap_listen_rec *lr;
 
-	    lr = find_ready_listener(&main_fds);
-	    if (lr != NULL) {
+            lr = find_ready_listener(&main_fds);
+            if (lr != NULL) {
                 /* fetch the native socket descriptor */
                 apr_os_sock_get(&nsd, lr->sd);
-	    }
-	}
+            }
+        }
 
-	do {
+        do {
             clen = sizeof(sa_client);
             csd = accept(nsd, (struct sockaddr *) &sa_client, &clen);
         } while (csd < 0 && APR_STATUS_IS_EINTR(apr_get_netos_error()));
 
-	if (csd < 0) {
+        if (csd < 0) {
             if (APR_STATUS_IS_ECONNABORTED(apr_get_netos_error())) {
-		ap_log_error(APLOG_MARK, APLOG_ERR, apr_get_netos_error(), ap_server_conf,
-			    "accept: (client socket)");
+                ap_log_error(APLOG_MARK, APLOG_ERR, apr_get_netos_error(), ap_server_conf,
+                            "accept: (client socket)");
             }
-	}
-	else {
-	    add_job(csd);
-	}
+        }
+        else {
+            add_job(csd);
+        }
     }
     SetEvent(exit_event);
     return 0;
@@ -809,7 +809,7 @@
 
     CloseHandle(handles[thread_to_clean]);
     for (i = thread_to_clean; i < ((*thread_cnt) - 1); i++)
-	handles[i] = handles[i + 1];
+        handles[i] = handles[i + 1];
     (*thread_cnt)--;
 }
 

Modified: httpd/httpd/branches/2.2.x/server/mpm/winnt/mpm_winnt.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/winnt/mpm_winnt.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/winnt/mpm_winnt.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/winnt/mpm_winnt.c Thu Nov 10 07:15:41 2005
@@ -132,9 +132,9 @@
         ap_threads_per_child = thread_limit;
     }
     else if (ap_threads_per_child < 1) {
-	ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
+        ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
                      "WARNING: Require ThreadsPerChild > 0, setting to 1");
-	ap_threads_per_child = 1;
+        ap_threads_per_child = 1;
     }
     return NULL;
 }
@@ -171,9 +171,9 @@
        thread_limit = MAX_THREAD_LIMIT;
     } 
     else if (thread_limit < 1) {
-	ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
+        ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
                      "WARNING: Require ThreadLimit > 0, setting to 1");
-	thread_limit = 1;
+        thread_limit = 1;
     }
     return NULL;
 }
@@ -244,9 +244,9 @@
 {
     apr_snprintf(signal_name_prefix, sizeof(signal_name_prefix), prefix);    
     apr_snprintf(signal_shutdown_name, sizeof(signal_shutdown_name), 
-	"%s_shutdown", signal_name_prefix);    
+        "%s_shutdown", signal_name_prefix);    
     apr_snprintf(signal_restart_name, sizeof(signal_restart_name), 
-	"%s_restart", signal_name_prefix);    
+        "%s_restart", signal_name_prefix);    
 }
 
 int volatile is_graceful = 0;
@@ -277,7 +277,7 @@
                break;
            }
         }
-	return;
+        return;
     }
 
     switch(type) {
@@ -300,19 +300,19 @@
 
     e = OpenEvent(EVENT_MODIFY_STATE, FALSE, signal_name);
     if (!e) {
-	/* Um, problem, can't signal the parent, which means we can't
-	 * signal ourselves to die. Ignore for now...
-	 */
-	ap_log_error(APLOG_MARK, APLOG_EMERG, apr_get_os_error(), ap_server_conf,
+        /* Um, problem, can't signal the parent, which means we can't
+         * signal ourselves to die. Ignore for now...
+         */
+        ap_log_error(APLOG_MARK, APLOG_EMERG, apr_get_os_error(), ap_server_conf,
                      "OpenEvent on %s event", signal_name);
-	return;
+        return;
     }
     if (SetEvent(e) == 0) {
-	/* Same problem as above */
-	ap_log_error(APLOG_MARK, APLOG_EMERG, apr_get_os_error(), ap_server_conf,
+        /* Same problem as above */
+        ap_log_error(APLOG_MARK, APLOG_EMERG, apr_get_os_error(), ap_server_conf,
                      "SetEvent on %s event", signal_name);
-	CloseHandle(e);
-	return;
+        CloseHandle(e);
+        return;
     }
     CloseHandle(e);
 }
@@ -390,7 +390,7 @@
 
     rv = ap_reopen_scoreboard(s->process->pool, scoreboard_shm, 1);
     if (rv || !(sb_shared = apr_shm_baseaddr_get(*scoreboard_shm))) {
-	ap_log_error(APLOG_MARK, APLOG_CRIT, rv, NULL, 
+        ap_log_error(APLOG_MARK, APLOG_CRIT, rv, NULL, 
                      "Child %d: Unable to reopen the scoreboard from the parent", my_pid);
         exit(APEXIT_CHILDINIT);
     }
@@ -1402,7 +1402,7 @@
     ap_pid_fname = DEFAULT_PIDLOG;
     ap_max_requests_per_child = DEFAULT_MAX_REQUESTS_PER_CHILD;
 #ifdef AP_MPM_WANT_SET_MAX_MEM_FREE
-	ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
+        ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
 #endif
     /* use_acceptex which is enabled by default is not available on Win9x.
      */

Modified: httpd/httpd/branches/2.2.x/server/mpm/winnt/service.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/winnt/service.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/winnt/service.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/winnt/service.c Thu Nov 10 07:15:41 2005
@@ -181,9 +181,9 @@
             && (die_on_logoff || (lParam != ENDSESSION_LOGOFF)))
     {
         ap_signal_parent(SIGNAL_PARENT_SHUTDOWN);
-	if (wParam)
+        if (wParam)
             /* Don't leave this message until we are dead! */
-	    WaitForSingleObject(globdat.mpm_thread, 30000);
+            WaitForSingleObject(globdat.mpm_thread, 30000);
         return 0;
     }
     return (DefWindowProc(hWnd, msg, wParam, lParam));
@@ -214,9 +214,9 @@
     wc.hbrBackground = NULL;
     wc.lpszMenuName  = NULL;
     if (service_name)
-	wc.lpszClassName = "ApacheWin95ServiceMonitor";
+        wc.lpszClassName = "ApacheWin95ServiceMonitor";
     else
-	wc.lpszClassName = "ApacheWin95SystemMonitor";
+        wc.lpszClassName = "ApacheWin95SystemMonitor";
  
     die_on_logoff = service_name ? FALSE : TRUE;
 
@@ -255,8 +255,8 @@
         if (msg.message == WM_CLOSE)
             DestroyWindow(hwndMain); 
         else {
-	    TranslateMessage(&msg);
-	    DispatchMessage(&msg);
+            TranslateMessage(&msg);
+            DispatchMessage(&msg);
         }
     }
     globdat.service_thread_id = 0;
@@ -397,7 +397,7 @@
         }
         else {
             globdat.ssStatus.dwCheckPoint = ++checkPoint;
-	    globdat.ssStatus.dwControlsAccepted = 0;
+            globdat.ssStatus.dwControlsAccepted = 0;
             if(waitHint)
                 globdat.ssStatus.dwWaitHint = waitHint;
         }
@@ -797,7 +797,7 @@
     apr_status_t rv;
     
     fprintf(stderr,reconfig ? "Reconfiguring the %s service\n"
-		   : "Installing the %s service\n", mpm_display_name);
+                   : "Installing the %s service\n", mpm_display_name);
 
     /* ###: utf-ize */
     if (GetModuleFileName(NULL, exe_path, sizeof(exe_path)) == 0)
@@ -844,10 +844,10 @@
                 ap_log_error(APLOG_MARK, APLOG_ERR|APLOG_ERR, 
                              apr_get_os_error(), NULL,
                              "ChangeServiceConfig failed");
-	        /* !schService aborts configuration below */
-	        CloseServiceHandle(schService);
-	        schService = NULL;
-	    }
+                /* !schService aborts configuration below */
+                CloseServiceHandle(schService);
+                schService = NULL;
+            }
         }
         else {
             /* RPCSS is the Remote Procedure Call (RPC) Locator required 
@@ -880,7 +880,7 @@
                 return (rv);
             }
         }
-	
+        
         CloseServiceHandle(schService);
         CloseServiceHandle(schSCManager);
     }
@@ -980,7 +980,7 @@
         if (!schService) {
            rv = apr_get_os_error();
            ap_log_error(APLOG_MARK, APLOG_ERR | APLOG_STARTUP, rv, NULL,
-			"%s: OpenService failed", mpm_display_name);
+                        "%s: OpenService failed", mpm_display_name);
            return (rv);
         }
         
@@ -996,7 +996,7 @@
 
         if (DeleteService(schService) == 0) {
             rv = apr_get_os_error();
-	    ap_log_error(APLOG_MARK, APLOG_ERR | APLOG_STARTUP, rv, NULL,
+            ap_log_error(APLOG_MARK, APLOG_ERR | APLOG_STARTUP, rv, NULL,
                          "%s: Failed to delete the service.", mpm_display_name);
             return (rv);
         }
@@ -1019,7 +1019,7 @@
             ap_regkey_close(key);
         }
         if (rv != APR_SUCCESS) {
-	    ap_log_error(APLOG_MARK, APLOG_ERR | APLOG_STARTUP, rv, NULL,
+            ap_log_error(APLOG_MARK, APLOG_ERR | APLOG_STARTUP, rv, NULL,
                          "%s: Failed to remove the RunServices registry "
                          "entry.", mpm_display_name);
         }

Modified: httpd/httpd/branches/2.2.x/server/mpm/worker/worker.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm/worker/worker.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm/worker/worker.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm/worker/worker.c Thu Nov 10 07:15:41 2005
@@ -1713,9 +1713,9 @@
                 "Server built: %s", ap_get_server_built());
 #ifdef AP_MPM_WANT_SET_ACCEPT_LOCK_MECH
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, ap_server_conf,
-		"AcceptMutex: %s (default: %s)",
-		apr_proc_mutex_name(accept_mutex),
-		apr_proc_mutex_defname());
+                "AcceptMutex: %s (default: %s)",
+                apr_proc_mutex_name(accept_mutex),
+                apr_proc_mutex_defname());
 #endif
     restart_pending = shutdown_pending = 0;
     mpm_state = AP_MPMQ_RUNNING;
@@ -1958,7 +1958,7 @@
     ap_max_requests_per_child = DEFAULT_MAX_REQUESTS_PER_CHILD;
     ap_extended_status = 0;
 #ifdef AP_MPM_WANT_SET_MAX_MEM_FREE
-	ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
+        ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
 #endif
 
     apr_cpystrn(ap_coredump_dir, ap_server_root, sizeof(ap_coredump_dir));
@@ -2150,9 +2150,9 @@
        server_limit = MAX_SERVER_LIMIT;
     } 
     else if (server_limit < 1) {
-	ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
+        ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
                      "WARNING: Require ServerLimit > 0, setting to 1");
-	server_limit = 1;
+        server_limit = 1;
     }
     return NULL;
 }
@@ -2190,9 +2190,9 @@
        thread_limit = MAX_THREAD_LIMIT;
     } 
     else if (thread_limit < 1) {
-	ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
+        ap_log_error(APLOG_MARK, APLOG_STARTUP, 0, NULL, 
                      "WARNING: Require ThreadLimit > 0, setting to 1");
-	thread_limit = 1;
+        thread_limit = 1;
     }
     return NULL;
 }

Modified: httpd/httpd/branches/2.2.x/server/mpm_common.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/mpm_common.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/mpm_common.c (original)
+++ httpd/httpd/branches/2.2.x/server/mpm_common.c Thu Nov 10 07:15:41 2005
@@ -1049,7 +1049,7 @@
 apr_uint32_t ap_max_mem_free = APR_ALLOCATOR_MAX_FREE_UNLIMITED;
 
 const char *ap_mpm_set_max_mem_free(cmd_parms *cmd, void *dummy,
-	                            const char *arg)
+                                    const char *arg)
 {
     long value;
     const char *err = ap_check_cmd_context(cmd, GLOBAL_ONLY);
@@ -1111,7 +1111,7 @@
     }
 
     if (cmd->server->is_virtual) {
-	return "EnableExceptionHook directive not allowed in <VirtualHost>";
+        return "EnableExceptionHook directive not allowed in <VirtualHost>";
     }
 
     if (strcasecmp(arg, "on") == 0) {

Modified: httpd/httpd/branches/2.2.x/server/request.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/request.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/request.c (original)
+++ httpd/httpd/branches/2.2.x/server/request.c Thu Nov 10 07:15:41 2005
@@ -825,7 +825,7 @@
                 }
 
                 res = ap_parse_htaccess(&htaccess_conf, r, opts.override,
-					opts.override_opts,
+                                        opts.override_opts,
                                         apr_pstrdup(r->pool, r->filename),
                                         sconf->access_name);
                 if (res) {

Modified: httpd/httpd/branches/2.2.x/server/util_filter.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/util_filter.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/util_filter.c (original)
+++ httpd/httpd/branches/2.2.x/server/util_filter.c Thu Nov 10 07:15:41 2005
@@ -343,7 +343,7 @@
             fscan = fscan->next;
 
         f->next = fscan->next;
-	fscan->next = f;
+        fscan->next = f;
     }
 
     if (frec->ftype < AP_FTYPE_CONNECTION && (*r_filters == *c_filters)) {

Modified: httpd/httpd/branches/2.2.x/server/util_md5.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/util_md5.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/util_md5.c (original)
+++ httpd/httpd/branches/2.2.x/server/util_md5.c Thu Nov 10 07:15:41 2005
@@ -70,8 +70,8 @@
     apr_md5_final(hash, &my_md5);
 
     for (i = 0, r = result; i < APR_MD5_DIGESTSIZE; i++) {
-	*r++ = hex[hash[i] >> 4];
-	*r++ = hex[hash[i] & 0xF];
+        *r++ = hex[hash[i] >> 4];
+        *r++ = hex[hash[i] & 0xF];
     }
     *r = '\0';
 
@@ -142,10 +142,10 @@
 
     p = encodedDigest;
     for (i = 0; i < sizeof(digest); i += 3) {
-	*p++ = basis_64[digest[i] >> 2];
-	*p++ = basis_64[((digest[i] & 0x3) << 4) | ((int) (digest[i + 1] & 0xF0) >> 4)];
-	*p++ = basis_64[((digest[i + 1] & 0xF) << 2) | ((int) (digest[i + 2] & 0xC0) >> 6)];
-	*p++ = basis_64[digest[i + 2] & 0x3F];
+        *p++ = basis_64[digest[i] >> 2];
+        *p++ = basis_64[((digest[i] & 0x3) << 4) | ((int) (digest[i + 1] & 0xF0) >> 4)];
+        *p++ = basis_64[((digest[i + 1] & 0xF) << 2) | ((int) (digest[i + 2] & 0xC0) >> 6)];
+        *p++ = basis_64[digest[i + 2] & 0x3F];
     }
     *p-- = '\0';
     *p-- = '=';
@@ -163,7 +163,7 @@
     apr_md5_init(&context);
     nbytes = sizeof(buf);
     while (apr_file_read(infile, buf, &nbytes) == APR_SUCCESS) {
-	apr_md5_update(&context, buf, nbytes);
+        apr_md5_update(&context, buf, nbytes);
         nbytes = sizeof(buf);
     }
     apr_file_seek(infile, APR_SET, &offset);

Modified: httpd/httpd/branches/2.2.x/server/vhost.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/server/vhost.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/server/vhost.c (original)
+++ httpd/httpd/branches/2.2.x/server/vhost.c Thu Nov 10 07:15:41 2005
@@ -726,12 +726,12 @@
     }
     else if (port) {
         /* Don't throw the Host: header's port number away:
-	   save it in parsed_uri -- ap_get_server_port() needs it! */
+           save it in parsed_uri -- ap_get_server_port() needs it! */
         /* @@@ XXX there should be a better way to pass the port.
-	 *         Like r->hostname, there should be a r->portno
-	 */
+         *         Like r->hostname, there should be a r->portno
+         */
         r->parsed_uri.port = port;
-	r->parsed_uri.port_str = apr_itoa(r->pool, (int)port);
+        r->parsed_uri.port_str = apr_itoa(r->pool, (int)port);
     }
 
     /* if the hostname is an IPv6 numeric address string, it was validated 

Modified: httpd/httpd/branches/2.2.x/support/htcacheclean.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/support/htcacheclean.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/support/htcacheclean.c (original)
+++ httpd/httpd/branches/2.2.x/support/htcacheclean.c Thu Nov 10 07:15:41 2005
@@ -824,7 +824,7 @@
                 }
                 benice = 1;
                 break;
-		
+                
             case 't':
                 if (deldirs) {
                     usage();

Modified: httpd/httpd/branches/2.2.x/support/logresolve.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/support/logresolve.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/support/logresolve.c (original)
+++ httpd/httpd/branches/2.2.x/support/logresolve.c Thu Nov 10 07:15:41 2005
@@ -154,72 +154,72 @@
     char *name;
 
     current = &nscache[((ipnum.s_addr + (ipnum.s_addr >> 8) +
-			 (ipnum.s_addr >> 16) + (ipnum.s_addr >> 24)) % BUCKETS)];
+                         (ipnum.s_addr >> 16) + (ipnum.s_addr >> 24)) % BUCKETS)];
 
     while (*current != NULL && ipnum.s_addr != (*current)->ipnum.s_addr)
-	current = &(*current)->next;
+        current = &(*current)->next;
 
     if (*current == NULL) {
-	cachesize++;
-	new = (struct nsrec *) malloc(sizeof(struct nsrec));
-	if (new == NULL) {
-	    perror("malloc");
-	    fprintf(stderr, "Insufficient memory\n");
-	    exit(1);
-	}
-	*current = new;
-	new->next = NULL;
-
-	new->ipnum = ipnum;
-
-	hostdata = gethostbyaddr((const char *) &ipnum, sizeof(struct in_addr),
-				 AF_INET);
-	if (hostdata == NULL) {
-	    if (h_errno > MAX_ERR)
-		errors[UNKNOWN_ERR]++;
-	    else
-		errors[h_errno]++;
-	    new->noname = h_errno;
-	    name = strdup(inet_ntoa(ipnum));
-	}
-	else {
-	    new->noname = 0;
-	    name = strdup(hostdata->h_name);
-	    if (check) {
-		if (name == NULL) {
-		    perror("strdup");
-		    fprintf(stderr, "Insufficient memory\n");
-		    exit(1);
-		}
-		hostdata = gethostbyname(name);
-		if (hostdata != NULL) {
-		    char **hptr;
-
-		    for (hptr = hostdata->h_addr_list; *hptr != NULL; hptr++)
-			if (((struct in_addr *) (*hptr))->s_addr == ipnum.s_addr)
-			    break;
-		    if (*hptr == NULL)
-			hostdata = NULL;
-		}
-		if (hostdata == NULL) {
-		    fprintf(stderr, "Bad host: %s != %s\n", name,
-			    inet_ntoa(ipnum));
-		    new->noname = NO_REVERSE;
-		    free(name);
-		    name = strdup(inet_ntoa(ipnum));
-		    errors[NO_REVERSE]++;
-		}
-	    }
-	}
-	new->hostname = name;
-	if (new->hostname == NULL) {
-	    perror("strdup");
-	    fprintf(stderr, "Insufficient memory\n");
-	    exit(1);
-	}
+        cachesize++;
+        new = (struct nsrec *) malloc(sizeof(struct nsrec));
+        if (new == NULL) {
+            perror("malloc");
+            fprintf(stderr, "Insufficient memory\n");
+            exit(1);
+        }
+        *current = new;
+        new->next = NULL;
+
+        new->ipnum = ipnum;
+
+        hostdata = gethostbyaddr((const char *) &ipnum, sizeof(struct in_addr),
+                                 AF_INET);
+        if (hostdata == NULL) {
+            if (h_errno > MAX_ERR)
+                errors[UNKNOWN_ERR]++;
+            else
+                errors[h_errno]++;
+            new->noname = h_errno;
+            name = strdup(inet_ntoa(ipnum));
+        }
+        else {
+            new->noname = 0;
+            name = strdup(hostdata->h_name);
+            if (check) {
+                if (name == NULL) {
+                    perror("strdup");
+                    fprintf(stderr, "Insufficient memory\n");
+                    exit(1);
+                }
+                hostdata = gethostbyname(name);
+                if (hostdata != NULL) {
+                    char **hptr;
+
+                    for (hptr = hostdata->h_addr_list; *hptr != NULL; hptr++)
+                        if (((struct in_addr *) (*hptr))->s_addr == ipnum.s_addr)
+                            break;
+                    if (*hptr == NULL)
+                        hostdata = NULL;
+                }
+                if (hostdata == NULL) {
+                    fprintf(stderr, "Bad host: %s != %s\n", name,
+                            inet_ntoa(ipnum));
+                    new->noname = NO_REVERSE;
+                    free(name);
+                    name = strdup(inet_ntoa(ipnum));
+                    errors[NO_REVERSE]++;
+                }
+            }
+        }
+        new->hostname = name;
+        if (new->hostname == NULL) {
+            perror("strdup");
+            fprintf(stderr, "Insufficient memory\n");
+            exit(1);
+        }
     }
     else
-	cachehits++;
+        cachehits++;
 
     /* size of string == MAXDNAME +1 */
     strncpy(string, (*current)->hostname, MAXDNAME);
@@ -238,7 +238,7 @@
     char *errstring[MAX_ERR + 3];
 
     for (i = 0; i < MAX_ERR + 3; i++)
-	errstring[i] = "Unknown error";
+        errstring[i] = "Unknown error";
     errstring[HOST_NOT_FOUND] = "Host not found";
     errstring[TRY_AGAIN] = "Try again";
     errstring[NO_RECOVERY] = "Non recoverable error";
@@ -252,34 +252,34 @@
     fprintf(output, "    With name   : %d\n", withname);
     fprintf(output, "    Resolves    : %d\n", resolves);
     if (errors[HOST_NOT_FOUND])
-	fprintf(output, "    - Not found : %d\n", errors[HOST_NOT_FOUND]);
+        fprintf(output, "    - Not found : %d\n", errors[HOST_NOT_FOUND]);
     if (errors[TRY_AGAIN])
-	fprintf(output, "    - Try again : %d\n", errors[TRY_AGAIN]);
+        fprintf(output, "    - Try again : %d\n", errors[TRY_AGAIN]);
     if (errors[NO_DATA])
-	fprintf(output, "    - No data   : %d\n", errors[NO_DATA]);
+        fprintf(output, "    - No data   : %d\n", errors[NO_DATA]);
     if (errors[NO_ADDRESS])
-	fprintf(output, "    - No address: %d\n", errors[NO_ADDRESS]);
+        fprintf(output, "    - No address: %d\n", errors[NO_ADDRESS]);
     if (errors[NO_REVERSE])
-	fprintf(output, "    - No reverse: %d\n", errors[NO_REVERSE]);
+        fprintf(output, "    - No reverse: %d\n", errors[NO_REVERSE]);
     fprintf(output, "Cache hits      : %d\n", cachehits);
     fprintf(output, "Cache size      : %d\n", cachesize);
     fprintf(output, "Cache buckets   :     IP number * hostname\n");
 
     for (i = 0; i < BUCKETS; i++)
-	for (current = nscache[i]; current != NULL; current = current->next) {
-	    ipstring = inet_ntoa(current->ipnum);
-	    if (current->noname == 0)
-		fprintf(output, "  %3d  %15s - %s\n", i, ipstring,
-			current->hostname);
-	    else {
-		if (current->noname > MAX_ERR + 2)
-		    fprintf(output, "  %3d  %15s : Unknown error\n", i,
-			    ipstring);
-		else
-		    fprintf(output, "  %3d  %15s : %s\n", i, ipstring,
-			    errstring[current->noname]);
-	    }
-	}
+        for (current = nscache[i]; current != NULL; current = current->next) {
+            ipstring = inet_ntoa(current->ipnum);
+            if (current->noname == 0)
+                fprintf(output, "  %3d  %15s - %s\n", i, ipstring,
+                        current->hostname);
+            else {
+                if (current->noname > MAX_ERR + 2)
+                    fprintf(output, "  %3d  %15s : Unknown error\n", i,
+                            ipstring);
+                else
+                    fprintf(output, "  %3d  %15s : %s\n", i, ipstring,
+                            errstring[current->noname]);
+            }
+        }
 }
 
 
@@ -292,10 +292,10 @@
     char *cp;
 
     if (!fgets(s, n, stdin))
-	return (0);
+        return (0);
     cp = strchr(s, '\n');
     if (cp)
-	*cp = '\0';
+        *cp = '\0';
     return (1);
 }
 
@@ -316,55 +316,55 @@
     check = 0;
     statfile = NULL;
     for (i = 1; i < argc; i++) {
-	if (strcmp(argv[i], "-c") == 0)
-	    check = 1;
-	else if (strcmp(argv[i], "-s") == 0) {
-	    if (i == argc - 1) {
-		fprintf(stderr, "logresolve: missing filename to -s\n");
-		exit(1);
-	    }
-	    i++;
-	    statfile = argv[i];
-	}
-	else {
-	    fprintf(stderr, "Usage: logresolve [-s statfile] [-c] < input > output\n");
-	    exit(0);
-	}
+        if (strcmp(argv[i], "-c") == 0)
+            check = 1;
+        else if (strcmp(argv[i], "-s") == 0) {
+            if (i == argc - 1) {
+                fprintf(stderr, "logresolve: missing filename to -s\n");
+                exit(1);
+            }
+            i++;
+            statfile = argv[i];
+        }
+        else {
+            fprintf(stderr, "Usage: logresolve [-s statfile] [-c] < input > output\n");
+            exit(0);
+        }
     }
 
     for (i = 0; i < BUCKETS; i++)
-	nscache[i] = NULL;
+        nscache[i] = NULL;
     for (i = 0; i < MAX_ERR + 2; i++)
-	errors[i] = 0;
+        errors[i] = 0;
 
     while (get_line(line, MAXLINE)) {
-	if (line[0] == '\0')
-	    continue;
-	entries++;
-	if (!apr_isdigit(line[0])) {	/* short cut */
-	    puts(line);
-	    withname++;
-	    continue;
-	}
-	bar = strchr(line, ' ');
-	if (bar != NULL)
-	    *bar = '\0';
-	ipnum.s_addr = inet_addr(line);
-	if (ipnum.s_addr == 0xffffffffu) {
-	    if (bar != NULL)
-		*bar = ' ';
-	    puts(line);
-	    withname++;
-	    continue;
-	}
-
-	resolves++;
-
-	cgethost(ipnum, hoststring, check);
-	if (bar != NULL)
-	    printf("%s %s\n", hoststring, bar + 1);
-	else
-	    puts(hoststring);
+        if (line[0] == '\0')
+            continue;
+        entries++;
+        if (!apr_isdigit(line[0])) {	/* short cut */
+            puts(line);
+            withname++;
+            continue;
+        }
+        bar = strchr(line, ' ');
+        if (bar != NULL)
+            *bar = '\0';
+        ipnum.s_addr = inet_addr(line);
+        if (ipnum.s_addr == 0xffffffffu) {
+            if (bar != NULL)
+                *bar = ' ';
+            puts(line);
+            withname++;
+            continue;
+        }
+
+        resolves++;
+
+        cgethost(ipnum, hoststring, check);
+        if (bar != NULL)
+            printf("%s %s\n", hoststring, bar + 1);
+        else
+            puts(hoststring);
     }
 
 #if defined(WIN32) || (defined(NETWARE) && defined(USE_WINSOCK))
@@ -372,15 +372,15 @@
 #endif
 
     if (statfile != NULL) {
-	FILE *fp;
-	fp = fopen(statfile, "w");
-	if (fp == NULL) {
-	    fprintf(stderr, "logresolve: could not open statistics file '%s'\n"
-		    ,statfile);
-	    exit(1);
-	}
-	stats(fp);
-	fclose(fp);
+        FILE *fp;
+        fp = fopen(statfile, "w");
+        if (fp == NULL) {
+            fprintf(stderr, "logresolve: could not open statistics file '%s'\n"
+                    ,statfile);
+            exit(1);
+        }
+        stats(fp);
+        fclose(fp);
     }
 
     return (0);

Modified: httpd/httpd/branches/2.2.x/support/win32/wintty.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/support/win32/wintty.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/support/win32/wintty.c (original)
+++ httpd/httpd/branches/2.2.x/support/win32/wintty.c Thu Nov 10 07:15:41 2005
@@ -136,7 +136,7 @@
                 case '?':
                     printf(options, arg0);
                     exit(1);
-		default:
+                default:
                     printf("wintty option %s not recognized, use -? for help.\n\n", *argv);
                     exit(1);
             }
@@ -214,7 +214,7 @@
         
     if (isservice) {
 #ifdef WE_EVER_FIGURE_OUT_WHY_THIS_DOESNT_WORK
-	hsavedesk = GetThreadDesktop(GetCurrentThreadId());
+        hsavedesk = GetThreadDesktop(GetCurrentThreadId());
         if (!hsavedesk || hsavedesk == INVALID_HANDLE_VALUE) {
             printerr("GetThreadDesktop(GetTID()) failed (%d)\n", GetLastError());
         }

Modified: httpd/httpd/branches/2.2.x/test/cls.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/test/cls.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/test/cls.c (original)
+++ httpd/httpd/branches/2.2.x/test/cls.c Thu Nov 10 07:15:41 2005
@@ -35,32 +35,32 @@
     int i, ch, d;
 
     for (i = 0; mask[i] != '\0' && mask[i] != '*'; i++) {
-	ch = mask[i];
-	d = data[i];
-	if (ch == '@') {
-	    if (!isupper(d))
-		return 0;
-	}
-	else if (ch == '$') {
-	    if (!islower(d))
-		return 0;
-	}
-	else if (ch == '#') {
-	    if (!isdigit(d))
-		return 0;
-	}
-	else if (ch == '&') {
-	    if (!isxdigit(d))
-		return 0;
-	}
-	else if (ch != d)
-	    return 0;
+        ch = mask[i];
+        d = data[i];
+        if (ch == '@') {
+            if (!isupper(d))
+                return 0;
+        }
+        else if (ch == '$') {
+            if (!islower(d))
+                return 0;
+        }
+        else if (ch == '#') {
+            if (!isdigit(d))
+                return 0;
+        }
+        else if (ch == '&') {
+            if (!isxdigit(d))
+                return 0;
+        }
+        else if (ch != d)
+            return 0;
     }
 
     if (mask[i] == '*')
-	return 1;
+        return 1;
     else
-	return (data[i] == '\0');
+        return (data[i] == '\0');
 }
 
 /*
@@ -72,19 +72,19 @@
     unsigned int j;
 
     for (i = 0, j = 0; i < 8; i++) {
-	ch = x[i];
-	j <<= 4;
-	if (isdigit(ch))
-	    j |= ch - '0';
-	else if (isupper(ch))
-	    j |= ch - ('A' - 10);
-	else
-	    j |= ch - ('a' - 10);
+        ch = x[i];
+        j <<= 4;
+        if (isdigit(ch))
+            j |= ch - '0';
+        else if (isupper(ch))
+            j |= ch - ('A' - 10);
+        else
+            j |= ch - ('a' - 10);
     }
     if (j == 0xffffffff)
-	return -1;		/* so that it works with 8-byte ints */
+        return -1;		/* so that it works with 8-byte ints */
     else
-	return j;
+        return j;
 }
 
 int main(int argc, char **argv)
@@ -103,78 +103,78 @@
     const char time_format[] = "%e %b %Y %R";
 
     if (argc != 2) {
-	printf("Usage: cls directory\n");
-	exit(0);
+        printf("Usage: cls directory\n");
+        exit(0);
     }
 
     d = opendir(argv[1]);
     if (d == NULL) {
-	perror("opendir");
-	exit(1);
+        perror("opendir");
+        exit(1);
     }
 
     for (;;) {
-	e = readdir(d);
-	if (e == NULL)
-	    break;
-	s = e->d_name;
-	if (s[0] == '.' || s[0] == '#')
-	    continue;
-	sprintf(path, "%s/%s", argv[1], s);
-	fp = fopen(path, "r");
-	if (fp == NULL) {
-	    perror("fopen");
-	    continue;
-	}
-	if (fgets(line, 1034, fp) == NULL) {
-	    perror("fgets");
-	    fclose(fp);
-	    continue;
-	}
-	if (!checkmask(line, "&&&&&&&& &&&&&&&& &&&&&&&& &&&&&&&& &&&&&&&&\n")) {
-	    fprintf(stderr, "Bad cache file\n");
-	    fclose(fp);
-	    continue;
-	}
-	date = hex2sec(line);
-	lmod = hex2sec(line + 9);
-	expire = hex2sec(line + 18);
-	ver = hex2sec(line + 27);
-	len = hex2sec(line + 35);
-	if (fgets(line, 1034, fp) == NULL) {
-	    perror("fgets");
-	    fclose(fp);
-	    continue;
-	}
-	fclose(fp);
-	i = strlen(line);
-	if (strncmp(line, "X-URL: ", 7) != 0 || line[i - 1] != '\n') {
-	    fprintf(stderr, "Bad cache file\n");
-	    continue;
-	}
-	line[i - 1] = '\0';
-	if (date != -1) {
-	    ts = *gmtime(&date);
-	    strftime(sdate, 30, time_format, &ts);
-	}
-	else
-	    strcpy(sdate, "-");
-
-	if (lmod != -1) {
-	    ts = *gmtime(&lmod);
-	    strftime(slmod, 30, time_format, &ts);
-	}
-	else
-	    strcpy(slmod, "-");
-
-	if (expire != -1) {
-	    ts = *gmtime(&expire);
-	    strftime(sexpire, 30, time_format, &ts);
-	}
-	else
-	    strcpy(sexpire, "-");
+        e = readdir(d);
+        if (e == NULL)
+            break;
+        s = e->d_name;
+        if (s[0] == '.' || s[0] == '#')
+            continue;
+        sprintf(path, "%s/%s", argv[1], s);
+        fp = fopen(path, "r");
+        if (fp == NULL) {
+            perror("fopen");
+            continue;
+        }
+        if (fgets(line, 1034, fp) == NULL) {
+            perror("fgets");
+            fclose(fp);
+            continue;
+        }
+        if (!checkmask(line, "&&&&&&&& &&&&&&&& &&&&&&&& &&&&&&&& &&&&&&&&\n")) {
+            fprintf(stderr, "Bad cache file\n");
+            fclose(fp);
+            continue;
+        }
+        date = hex2sec(line);
+        lmod = hex2sec(line + 9);
+        expire = hex2sec(line + 18);
+        ver = hex2sec(line + 27);
+        len = hex2sec(line + 35);
+        if (fgets(line, 1034, fp) == NULL) {
+            perror("fgets");
+            fclose(fp);
+            continue;
+        }
+        fclose(fp);
+        i = strlen(line);
+        if (strncmp(line, "X-URL: ", 7) != 0 || line[i - 1] != '\n') {
+            fprintf(stderr, "Bad cache file\n");
+            continue;
+        }
+        line[i - 1] = '\0';
+        if (date != -1) {
+            ts = *gmtime(&date);
+            strftime(sdate, 30, time_format, &ts);
+        }
+        else
+            strcpy(sdate, "-");
+
+        if (lmod != -1) {
+            ts = *gmtime(&lmod);
+            strftime(slmod, 30, time_format, &ts);
+        }
+        else
+            strcpy(slmod, "-");
+
+        if (expire != -1) {
+            ts = *gmtime(&expire);
+            strftime(sexpire, 30, time_format, &ts);
+        }
+        else
+            strcpy(sexpire, "-");
 
-	printf("%s: %d; %s  %s  %s\n", line + 7, ver, sdate, slmod, sexpire);
+        printf("%s: %d; %s  %s  %s\n", line + 7, ver, sdate, slmod, sexpire);
     }
 
     closedir(d);

Modified: httpd/httpd/branches/2.2.x/test/test-writev.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/test/test-writev.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/test/test-writev.c (original)
+++ httpd/httpd/branches/2.2.x/test/test-writev.c Thu Nov 10 07:15:41 2005
@@ -57,36 +57,36 @@
 
     if( argc != 3 ) {
 usage:
-	fprintf( stderr, "usage: test-writev a.b.c.d port#\n" );
-	exit( 1 );
+        fprintf( stderr, "usage: test-writev a.b.c.d port#\n" );
+        exit( 1 );
     }
     server_addr.sin_family = AF_INET;
     server_addr.sin_addr.s_addr = inet_addr( argv[1] );
     if( server_addr.sin_addr.s_addr == INADDR_NONE ) {
-	fprintf( stderr, "bogus address\n" );
-	goto usage;
+        fprintf( stderr, "bogus address\n" );
+        goto usage;
     }
     server_addr.sin_port = htons( atoi( argv[2] ) );
 
     s = socket( AF_INET, SOCK_STREAM, 0 );
     if( s < 0 ) {
-	perror("socket");
-	exit(1);
+        perror("socket");
+        exit(1);
     }
     if( connect( s, (struct sockaddr *)&server_addr, sizeof( server_addr ) )
-	!= 0 ) {
-	perror("connect");
-	exit(1);
+        != 0 ) {
+        perror("connect");
+        exit(1);
     }
 
     if( setsockopt(s, IPPROTO_TCP, TCP_NODELAY, (char*)&just_say_no,
-	sizeof(just_say_no)) != 0 ) {
-	perror( "TCP_NODELAY" );
-	exit(1);
+        sizeof(just_say_no)) != 0 ) {
+        perror( "TCP_NODELAY" );
+        exit(1);
     }
     /* now build up a two part writev and write it out */
     for( i = 0; i < sizeof( buf ); ++i ) {
-	buf[i] = 'x';
+        buf[i] = 'x';
     }
     vector[0].iov_base = buf;
     vector[0].iov_len = sizeof(buf);

Modified: httpd/httpd/branches/2.2.x/test/time-sem.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/test/time-sem.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/test/time-sem.c (original)
+++ httpd/httpd/branches/2.2.x/test/time-sem.c Thu Nov 10 07:15:41 2005
@@ -23,16 +23,16 @@
     - NFS filesystems absolutely suck for fcntl() and flock()
 
     - uslock absolutely sucks on single-processor IRIX boxes, but
-	absolutely rocks on multi-processor boxes.  The converse
-	is true for fcntl.  sysvsem seems a moderate balance.
+        absolutely rocks on multi-processor boxes.  The converse
+        is true for fcntl.  sysvsem seems a moderate balance.
 
     - Under Solaris you can't have too many processes use SEM_UNDO, there
-	might be a tuneable somewhere that increases the limit from 29.
-	We're not sure what the tunable is, so there's a define
-	NO_SEM_UNDO which can be used to simulate us trapping/blocking
-	signals to be able to properly release the semaphore on a clean
-	child death.  You'll also need to define NEED_UNION_SEMUN
-	under solaris.
+        might be a tuneable somewhere that increases the limit from 29.
+        We're not sure what the tunable is, so there's a define
+        NO_SEM_UNDO which can be used to simulate us trapping/blocking
+        signals to be able to properly release the semaphore on a clean
+        child death.  You'll also need to define NEED_UNION_SEMUN
+        under solaris.
 
 You'll need to define USE_SHMGET_SCOREBOARD if anonymous shared mmap()
 doesn't work on your system (i.e. linux).
@@ -101,9 +101,9 @@
     fcntl_fd = open("test-lock-thing", O_CREAT | O_WRONLY | O_EXCL, 0644);
     if (fcntl_fd == -1)
     {
-	perror ("open");
-	fprintf (stderr, "Cannot open lock file: %s\n", "test-lock-thing");
-	exit (1);
+        perror ("open");
+        fprintf (stderr, "Cannot open lock file: %s\n", "test-lock-thing");
+        exit (1);
     }
     unlink("test-lock-thing");
 }
@@ -113,11 +113,11 @@
     int ret;
     
     while ((ret = fcntl(fcntl_fd, F_SETLKW, &lock_it)) < 0 && errno == EINTR)
-	continue;
+        continue;
 
     if (ret < 0) {
-	perror ("fcntl lock_it");
-	exit(1);
+        perror ("fcntl lock_it");
+        exit(1);
     }
 }
 
@@ -125,8 +125,8 @@
 {
     if (fcntl (fcntl_fd, F_SETLKW, &unlock_it) < 0)
     {
-	perror ("fcntl unlock_it");
-	exit(1);
+        perror ("fcntl unlock_it");
+        exit(1);
     }
 }
 
@@ -149,9 +149,9 @@
     flock_fd = open(FNAME, O_CREAT | O_WRONLY | O_EXCL, 0644);
     if (flock_fd == -1)
     {
-	perror ("open");
-	fprintf (stderr, "Cannot open lock file: %s\n", "test-lock-thing");
-	exit (1);
+        perror ("open");
+        fprintf (stderr, "Cannot open lock file: %s\n", "test-lock-thing");
+        exit (1);
     }
 }
 
@@ -159,8 +159,8 @@
 {
     flock_fd = open(FNAME, O_WRONLY, 0600);
     if (flock_fd == -1) {
-	perror("open");
-	exit(1);
+        perror("open");
+        exit(1);
     }
 }
 
@@ -174,11 +174,11 @@
     int ret;
     
     while ((ret = flock(flock_fd, LOCK_EX)) < 0 && errno == EINTR)
-	continue;
+        continue;
 
     if (ret < 0) {
-	perror ("flock(LOCK_EX)");
-	exit(1);
+        perror ("flock(LOCK_EX)");
+        exit(1);
     }
 }
 
@@ -186,8 +186,8 @@
 {
     if (flock (flock_fd, LOCK_UN) < 0)
     {
-	perror ("flock(LOCK_UN)");
-	exit(1);
+        perror ("flock(LOCK_UN)");
+        exit(1);
     }
 }
 
@@ -211,9 +211,9 @@
 #ifdef NEED_UNION_SEMUN
     /* believe it or not, you need to define this under solaris */
     union semun {
-	int val;
-	struct semid_ds *buf;
-	ushort *array;
+        int val;
+        struct semid_ds *buf;
+        ushort *array;
     };
 #endif
 
@@ -243,8 +243,8 @@
 
 #ifdef NO_SEM_UNDO
     if (sigprocmask(SIG_BLOCK, &accept_block_mask, &accept_previous_mask)) {
-	perror("sigprocmask(SIG_BLOCK)");
-	exit (1);
+        perror("sigprocmask(SIG_BLOCK)");
+        exit (1);
     }
     op.sem_flg = 0;
 #else
@@ -253,8 +253,8 @@
     op.sem_num = 0;
     op.sem_op  = -1;
     if (semop(sem_id, &op, 1) < 0) {
-	perror ("accept_mutex_on");
-	exit (1);
+        perror ("accept_mutex_on");
+        exit (1);
     }
 }
 
@@ -270,13 +270,13 @@
     op.sem_flg = SEM_UNDO;
 #endif
     if (semop(sem_id, &op, 1) < 0) {
-	perror ("accept_mutex_off");
+        perror ("accept_mutex_off");
         exit (1);
     }
 #ifdef NO_SEM_UNDO
     if (sigprocmask(SIG_SETMASK, &accept_previous_mask, NULL)) {
-	perror("sigprocmask(SIG_SETMASK)");
-	exit (1);
+        perror("sigprocmask(SIG_SETMASK)");
+        exit (1);
     }
 #endif
 }
@@ -304,27 +304,27 @@
 
     fd = open ("/dev/zero", O_RDWR);
     if (fd == -1) {
-	perror ("open(/dev/zero)");
-	exit (1);
+        perror ("open(/dev/zero)");
+        exit (1);
     }
     mutex = (pthread_mutex_t *)mmap ((caddr_t)0, sizeof (*mutex),
-		    PROT_READ|PROT_WRITE, MAP_SHARED, fd, 0);
+                    PROT_READ|PROT_WRITE, MAP_SHARED, fd, 0);
     if (mutex == (void *)(caddr_t)-1) {
-	perror ("mmap");
-	exit (1);
+        perror ("mmap");
+        exit (1);
     }
     close (fd);
     if (pthread_mutexattr_init(&mattr)) {
-	perror ("pthread_mutexattr_init");
-	exit (1);
+        perror ("pthread_mutexattr_init");
+        exit (1);
     }
     if (pthread_mutexattr_setpshared(&mattr, PTHREAD_PROCESS_SHARED)) {
-	perror ("pthread_mutexattr_setpshared");
-	exit (1);
+        perror ("pthread_mutexattr_setpshared");
+        exit (1);
     }
     if (pthread_mutex_init(mutex, &mattr)) {
-	perror ("pthread_mutex_init");
-	exit (1);
+        perror ("pthread_mutex_init");
+        exit (1);
     }
     sigfillset(&accept_block_mask);
     sigdelset(&accept_block_mask, SIGHUP);
@@ -335,24 +335,24 @@
 void accept_mutex_on()
 {
     if (sigprocmask(SIG_BLOCK, &accept_block_mask, &accept_previous_mask)) {
-	perror("sigprocmask(SIG_BLOCK)");
-	exit (1);
+        perror("sigprocmask(SIG_BLOCK)");
+        exit (1);
     }
     if (pthread_mutex_lock (mutex)) {
-	perror ("pthread_mutex_lock");
-	exit (1);
+        perror ("pthread_mutex_lock");
+        exit (1);
     }
 }
 
 void accept_mutex_off()
 {
     if (pthread_mutex_unlock (mutex)) {
-	perror ("pthread_mutex_unlock");
-	exit (1);
+        perror ("pthread_mutex_unlock");
+        exit (1);
     }
     if (sigprocmask(SIG_SETMASK, &accept_previous_mask, NULL)) {
-	perror("sigprocmask(SIG_SETMASK)");
-	exit (1);
+        perror("sigprocmask(SIG_SETMASK)");
+        exit (1);
     }
 }
 
@@ -423,10 +423,10 @@
 
     /* allocate shared memory for the shared_counter */
     result = (unsigned long *)mmap ((caddr_t)0, size,
-		    PROT_READ|PROT_WRITE, MAP_ANON|MAP_SHARED, -1, 0);
+                    PROT_READ|PROT_WRITE, MAP_ANON|MAP_SHARED, -1, 0);
     if (result == (void *)(caddr_t)-1) {
-	perror ("mmap");
-	exit (1);
+        perror ("mmap");
+        exit (1);
     }
     return result;
 }
@@ -448,8 +448,8 @@
 #endif
 
     if ((shmid = shmget(shmkey, size, IPC_CREAT | SHM_R | SHM_W)) == -1) {
-	perror("shmget");
-	exit(1);
+        perror("shmget");
+        exit(1);
     }
 
 #ifdef MOVEBREAK
@@ -463,29 +463,29 @@
      * attach the segment and then move break back down. Ugly
      */
     if ((obrk = sbrk(MOVEBREAK)) == (char *) -1) {
-	perror("sbrk");
+        perror("sbrk");
     }
 #endif
 
 #define BADSHMAT	((void *)(-1))
     if ((result = shmat(shmid, 0, 0)) == BADSHMAT) {
-	perror("shmat");
+        perror("shmat");
     }
     /*
      * We must avoid leaving segments in the kernel's
      * (small) tables.
      */
     if (shmctl(shmid, IPC_RMID, NULL) != 0) {
-	perror("shmctl(IPC_RMID)");
+        perror("shmctl(IPC_RMID)");
     }
     if (result == BADSHMAT)	/* now bailout */
-	exit(1);
+        exit(1);
 
 #ifdef MOVEBREAK
     if (obrk == (char *) -1)
-	return;			/* nothing else to do */
+        return;			/* nothing else to do */
     if (sbrk(-(MOVEBREAK)) == (char *) -1) {
-	perror("sbrk 2");
+        perror("sbrk 2");
     }
 #endif
     return result;
@@ -513,8 +513,8 @@
     unsigned long *shared_counter;
 
     if (argc != 3) {
-	fprintf (stderr, "Usage: time-sem num-child num iter\n");
-	exit (1);
+        fprintf (stderr, "Usage: time-sem num-child num iter\n");
+        exit (1);
     }
 
     num_child = atoi (argv[1]);
@@ -532,54 +532,54 @@
     accept_mutex_on ();
 
     for (i = 0; i < num_child; ++i) {
-	pid = fork();
-	if (pid == 0) {
-	    /* child, do our thing */
-	    accept_mutex_child_init();
-	    for (i = 0; i < num_iter; ++i) {
-		unsigned long tmp;
-
-		accept_mutex_on ();
-		tmp = *shared_counter;
-		YIELD;
-		*shared_counter = tmp + 1;
-		accept_mutex_off ();
-	    }
-	    exit (0);
-	} else if (pid == -1) {
-	    perror ("fork");
-	    exit (1);
-	}
+        pid = fork();
+        if (pid == 0) {
+            /* child, do our thing */
+            accept_mutex_child_init();
+            for (i = 0; i < num_iter; ++i) {
+                unsigned long tmp;
+
+                accept_mutex_on ();
+                tmp = *shared_counter;
+                YIELD;
+                *shared_counter = tmp + 1;
+                accept_mutex_off ();
+            }
+            exit (0);
+        } else if (pid == -1) {
+            perror ("fork");
+            exit (1);
+        }
     }
 
     /* a quick test to see that nothing is screwed up */
     if (*shared_counter != 0) {
-	puts ("WTF! shared_counter != 0 before the children have been started!");
-	exit (1);
+        puts ("WTF! shared_counter != 0 before the children have been started!");
+        exit (1);
     }
 
     gettimeofday (&first, NULL);
     /* launch children into action */
     accept_mutex_off ();
     for (i = 0; i < num_child; ++i) {
-	if (wait(NULL) == -1) {
-	    perror ("wait");
-	}
+        if (wait(NULL) == -1) {
+            perror ("wait");
+        }
     }
     gettimeofday (&last, NULL);
 
     if (*shared_counter != num_child * num_iter) {
-	printf ("WTF! shared_counter != num_child * num_iter!\n"
-		"shared_counter = %lu\nnum_child = %d\nnum_iter=%d\n",
-		*shared_counter,
-		num_child, num_iter);
+        printf ("WTF! shared_counter != num_child * num_iter!\n"
+                "shared_counter = %lu\nnum_child = %d\nnum_iter=%d\n",
+                *shared_counter,
+                num_child, num_iter);
     }
 
     last.tv_sec -= first.tv_sec;
     ms = last.tv_usec - first.tv_usec;
     if (ms < 0) {
-	--last.tv_sec;
-	ms += 1000000;
+        --last.tv_sec;
+        ms += 1000000;
     }
     last.tv_usec = ms;
     printf ("%8lu.%06lu\n", last.tv_sec, last.tv_usec);

Modified: httpd/httpd/branches/2.2.x/test/zb.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/test/zb.c?rev=332307&r1=332306&r2=332307&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/test/zb.c (original)
+++ httpd/httpd/branches/2.2.x/test/zb.c Thu Nov 10 07:15:41 2005
@@ -1,6 +1,6 @@
 
 /*                          ZeusBench V1.01
-			    ===============
+                            ===============
 
 This program is Copyright (C) Zeus Technology Limited 1996.
 
@@ -196,11 +196,11 @@
   printf("Document Length:        %d\n", doclen);  
   printf("Concurency Level:       %d\n", concurrency);
   printf("Time taken for tests:   %d.%03d seconds\n", 
-	 timetaken/1000, timetaken%1000);
+         timetaken/1000, timetaken%1000);
   printf("Complete requests:      %d\n", done);
   printf("Failed requests:        %d\n", bad);
   if(bad) printf("   (Connect: %d, Length: %d, Exceptions: %d)\n",
-		 err_conn, err_length, err_except);
+                 err_conn, err_length, err_except);
   if(keepalive) printf("Keep-Alive requests:    %d\n", doneka);
   printf("Bytes transferred:      %d\n", totalread);
   printf("HTML transferred:       %d\n", totalbread);
@@ -209,7 +209,7 @@
   if(timetaken) {
     printf("Requests per seconds:   %.2f\n", 1000*(float)(done)/timetaken);
     printf("Transfer rate:          %.2f kb/s\n", 
-	   (float)(totalread)/timetaken);
+           (float)(totalread)/timetaken);
   }
 
   {
@@ -266,8 +266,8 @@
       close(c->fd);
       err_conn++;
       if(bad++>10) {
-	printf("\nTest aborted after 10 failures\n\n");
-	exit(1);
+        printf("\nTest aborted after 10 failures\n\n");
+        exit(1);
       } 
       start_connect(c);
     }      
@@ -352,44 +352,44 @@
     if(!s) {
        /* read rest next time */
       if(space) 
-	return;
+        return;
       else {
-	/* header is in invalid or too big - close connection */
-	close(c->fd);
-	if(bad++>10) {
-	  printf("\nTest aborted after 10 failures\n\n");
-	  exit(1);
-	} 
-	FD_CLR(c->fd, &writebits);
-	start_connect(c);
+        /* header is in invalid or too big - close connection */
+        close(c->fd);
+        if(bad++>10) {
+          printf("\nTest aborted after 10 failures\n\n");
+          exit(1);
+        } 
+        FD_CLR(c->fd, &writebits);
+        start_connect(c);
       }	
     }
     else {
       /* have full header */
       if(!good) {
-	/* this is first time, extract some interesting info */
-	char *p, *q;
-	p = strstr(c->cbuff, "Server:");
-	q = server_name;
-	if(p) { p+=8; while(*p>32) *q++ = *p++; }
-	*q = 0;
+        /* this is first time, extract some interesting info */
+        char *p, *q;
+        p = strstr(c->cbuff, "Server:");
+        q = server_name;
+        if(p) { p+=8; while(*p>32) *q++ = *p++; }
+        *q = 0;
       }
-	
+        
       c->gotheader = 1;
       *s = 0; /* terminate at end of header */
       if(keepalive && 
-	 (strstr(c->cbuff, "Keep-Alive") 
-	  || strstr(c->cbuff, "keep-alive")))  /* for benefit of MSIIS */
-	{
-	char *cl;
-	cl = strstr(c->cbuff, "Content-Length:");
-	/* for cacky servers like NCSA which break the spec and send a 
-	   lower case 'l' */
-	if(!cl) cl = strstr(c->cbuff, "Content-length:");
-	if(cl) {
-	  c->keepalive=1;
-	  c->length = atoi(cl+16);
-	}
+         (strstr(c->cbuff, "Keep-Alive") 
+          || strstr(c->cbuff, "keep-alive")))  /* for benefit of MSIIS */
+        {
+        char *cl;
+        cl = strstr(c->cbuff, "Content-Length:");
+        /* for cacky servers like NCSA which break the spec and send a 
+           lower case 'l' */
+        if(!cl) cl = strstr(c->cbuff, "Content-length:");
+        if(cl) {
+          c->keepalive=1;
+          c->length = atoi(cl+16);
+        }
       }
       c->bread += c->cbx - (s+l-c->cbuff) + r-tocopy;
       totalbread += c->bread;
@@ -454,8 +454,8 @@
 
   /* setup request */
   sprintf(request,"GET %s HTTP/1.0\r\nUser-Agent: ZeusBench/1.0\r\n"
-	  "%sHost: %s\r\nAccept: */*\r\n\r\n", file, 
-	  keepalive?"Connection: Keep-Alive\r\n":"", machine );
+          "%sHost: %s\r\nAccept: */*\r\n\r\n", file, 
+          keepalive?"Connection: Keep-Alive\r\n":"", machine );
     
   reqlen = strlen(request);
 
@@ -491,10 +491,10 @@
     for(i=0; i<concurrency; i++) {
       int s = con[i].fd;
       if(FD_ISSET(s, &sel_except)) {
-	bad++; 
-	err_except++;
-	start_connect(&con[i]);
-	continue;
+        bad++; 
+        err_except++;
+        start_connect(&con[i]);
+        continue;
       }
       if(FD_ISSET(s, &sel_read)) read_connection(&con[i]);
       if(FD_ISSET(s, &sel_write)) write_request(&con[i]);
@@ -511,7 +511,7 @@
 void usage(char *progname) {
   printf("\nZeusBench v1.0\n\n");
   printf("Usage: %s <machine> <file> [-k] [-n requests | -t timelimit (sec)]"
-	 "\n\t\t[-c concurrency] [-p port] \n",progname);
+         "\n\t\t[-c concurrency] [-p port] \n",progname);
   printf("Filename should start with a '/' e.g. /index.html\n\n");
   exit(EINVAL);
 }
@@ -534,8 +534,8 @@
     case 'n': 
       requests = atoi(optarg);
       if(!requests) {
-	printf("Invalid number of requests\n");
-	exit(1);
+        printf("Invalid number of requests\n");
+        exit(1);
       }
       break;
     case 'k':