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

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

Modified: httpd/httpd/branches/2.2.x/modules/cache/mod_mem_cache.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/cache/mod_mem_cache.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/cache/mod_mem_cache.c (original)
+++ httpd/httpd/branches/2.2.x/modules/cache/mod_mem_cache.c Thu Nov 10 07:20:05 2005
@@ -16,14 +16,14 @@
 
 /*
  * Rules for managing obj->refcount:
- * refcount should be incremented when an object is placed in the cache. Insertion 
- *   of an object into the cache and the refcount increment should happen under 
+ * refcount should be incremented when an object is placed in the cache. Insertion
+ *   of an object into the cache and the refcount increment should happen under
  *   protection of the sconf->lock.
  *
  * refcount should be decremented when the object is removed from the cache.
  *   Object should be removed from the cache and the refcount decremented while
  *   under protection of the sconf->lock.
- * 
+ *
  * refcount should be incremented when an object is retrieved from the cache
  *   by a worker thread. The retrieval/find operation and refcount increment
  *   should occur under protection of the sconf->lock
@@ -31,8 +31,8 @@
  * refcount can be atomically decremented w/o protection of the sconf->lock
  *   by worker threads.
  *
- * Any object whose refcount drops to 0 should be freed/cleaned up. A refcount 
- * of 0 means the object is not in the cache and no worker threads are accessing 
+ * Any object whose refcount drops to 0 should be freed/cleaned up. A refcount
+ * of 0 means the object is not in the cache and no worker threads are accessing
  * it.
  */
 #define CORE_PRIVATE
@@ -157,9 +157,9 @@
     cache_object_t *obj = (cache_object_t *)a;
     return obj->key;
 }
-/** 
+/**
  * memcache_cache_free()
- * memcache_cache_free is a callback that is only invoked by a thread 
+ * memcache_cache_free is a callback that is only invoked by a thread
  * running in cache_insert(). cache_insert() runs under protection
  * of sconf->lock.  By the time this function has been entered, the cache_object
  * has been ejected from the cache. decrement the refcount and if the refcount drops
@@ -180,21 +180,21 @@
  * functions return a 'negative' score since priority queues
  * dequeue the object with the highest value first
  */
-static long memcache_lru_algorithm(long queue_clock, void *a) 
+static long memcache_lru_algorithm(long queue_clock, void *a)
 {
     cache_object_t *obj = (cache_object_t *)a;
     mem_cache_object_t *mobj = obj->vobj;
     if (mobj->priority == 0)
         mobj->priority = queue_clock - mobj->total_refs;
 
-    /*	
+    /*
      * a 'proper' LRU function would just be
-     *  mobj->priority = mobj->total_refs; 
+     *  mobj->priority = mobj->total_refs;
      */
     return mobj->priority;
 }
 
-static long memcache_gdsf_algorithm(long queue_clock, void *a) 
+static long memcache_gdsf_algorithm(long queue_clock, void *a)
 {
     cache_object_t *obj = (cache_object_t *)a;
     mem_cache_object_t *mobj = obj->vobj;
@@ -212,7 +212,7 @@
 
     /* TODO:
      * We desperately need a more efficient way of allocating objects. We're
-     * making way too many malloc calls to create a fully populated 
+     * making way too many malloc calls to create a fully populated
      * cache object...
      */
 
@@ -236,7 +236,7 @@
 #endif
         }
         if (mobj->header_out) {
-            if (mobj->header_out[0].hdr) 
+            if (mobj->header_out[0].hdr)
                 free(mobj->header_out[0].hdr);
             free(mobj->header_out);
         }
@@ -248,7 +248,7 @@
         free(mobj);
     }
 }
-static apr_status_t decrement_refcount(void *arg) 
+static apr_status_t decrement_refcount(void *arg)
 {
     cache_object_t *obj = (cache_object_t *) arg;
 
@@ -271,7 +271,7 @@
         if (sconf->lock) {
             apr_thread_mutex_unlock(sconf->lock);
         }
-    } 
+    }
 
     /* If the refcount drops to 0, cleanup the cache object */
     if (!apr_atomic_dec32(&obj->refcount)) {
@@ -295,7 +295,7 @@
         apr_thread_mutex_lock(sconf->lock);
     }
     obj = cache_pop(co->cache_cache);
-    while (obj) {         
+    while (obj) {
         /* Iterate over the cache and clean up each unreferenced entry */
         if (!apr_atomic_dec32(&obj->refcount)) {
             cleanup_cache_object(obj);
@@ -303,7 +303,7 @@
         obj = cache_pop(co->cache_cache);
     }
 
-    /* Cache is empty, free the cache table */        
+    /* Cache is empty, free the cache table */
     cache_free(co->cache_cache);
 
     if (sconf->lock) {
@@ -332,7 +332,7 @@
 }
 
 static int create_entity(cache_handle_t *h, cache_type_e type_e,
-                         request_rec *r, const char *key, apr_off_t len) 
+                         request_rec *r, const char *key, apr_off_t len)
 {
     cache_object_t *obj, *tmp_obj;
     mem_cache_object_t *mobj;
@@ -347,12 +347,12 @@
         len = sconf->max_streaming_buffer_size;
     }
 
-    /* Note: cache_insert() will automatically garbage collect 
+    /* Note: cache_insert() will automatically garbage collect
      * objects from the cache if the max_cache_size threshold is
      * exceeded. This means mod_mem_cache does not need to implement
      * max_cache_size checks.
      */
-    if (len < sconf->min_cache_object_size || 
+    if (len < sconf->min_cache_object_size ||
         len > sconf->max_cache_object_size) {
         ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, r->server,
                      "mem_cache: URL %s failed the size check and will not be cached.",
@@ -361,7 +361,7 @@
     }
 
     if (type_e == CACHE_TYPE_FILE) {
-        /* CACHE_TYPE_FILE is only valid for local content handled by the 
+        /* CACHE_TYPE_FILE is only valid for local content handled by the
          * default handler. Need a better way to check if the file is
          * local or not.
          */
@@ -405,11 +405,11 @@
      * avoid multiple threads attempting to cache the same content only
      * to discover at the very end that only one of them will succeed.
      * Furthermore, adding the cache object to the table at the end could
-     * open up a subtle but easy to exploit DoS hole: someone could request 
+     * open up a subtle but easy to exploit DoS hole: someone could request
      * a very large file with multiple requests. Better to detect this here
      * rather than after the cache object has been completely built and
      * initialized...
-     * XXX Need a way to insert into the cache w/o such coarse grained locking 
+     * XXX Need a way to insert into the cache w/o such coarse grained locking
      */
     if (sconf->lock) {
         apr_thread_mutex_lock(sconf->lock);
@@ -418,7 +418,7 @@
 
     if (!tmp_obj) {
         cache_insert(sconf->cache_cache, obj);
-        /* Add a refcount to account for the reference by the 
+        /* Add a refcount to account for the reference by the
          * hashtable in the cache. Refcount should be 2 now, one
          * for this thread, and one for the cache.
          */
@@ -430,14 +430,14 @@
 
     if (tmp_obj) {
         /* This thread collided with another thread loading the same object
-         * into the cache at the same time. Defer to the other thread which 
+         * into the cache at the same time. Defer to the other thread which
          * is further along.
          */
         cleanup_cache_object(obj);
         return DECLINED;
     }
 
-    apr_pool_cleanup_register(r->pool, obj, decrement_refcount, 
+    apr_pool_cleanup_register(r->pool, obj, decrement_refcount,
                               apr_pool_cleanup_null);
 
     /* Populate the cache handle */
@@ -447,18 +447,18 @@
 }
 
 static int create_mem_entity(cache_handle_t *h, request_rec *r,
-                             const char *key, apr_off_t len) 
+                             const char *key, apr_off_t len)
 {
     return create_entity(h, CACHE_TYPE_HEAP, r, key, len);
 }
 
 static int create_fd_entity(cache_handle_t *h, request_rec *r,
-                            const char *key, apr_off_t len) 
+                            const char *key, apr_off_t len)
 {
     return create_entity(h, CACHE_TYPE_FILE, r, key, len);
 }
 
-static int open_entity(cache_handle_t *h, request_rec *r, const char *key) 
+static int open_entity(cache_handle_t *h, request_rec *r, const char *key)
 {
     cache_object_t *obj;
 
@@ -475,7 +475,7 @@
             cache_update(sconf->cache_cache, obj);
 
             /* If this is a subrequest, register the cleanup against
-             * the main request. This will prevent the cache object 
+             * the main request. This will prevent the cache object
              * from being cleaned up from under the request after the
              * subrequest is destroyed.
              */
@@ -507,13 +507,13 @@
 }
 
 /* remove_entity()
- * Notes: 
+ * Notes:
  *   refcount should be at least 1 upon entry to this function to account
  *   for this thread's reference to the object. If the refcount is 1, then
  *   object has been removed from the cache by another thread and this thread
  *   is the last thread accessing the object.
  */
-static int remove_entity(cache_handle_t *h) 
+static int remove_entity(cache_handle_t *h)
 {
     cache_object_t *obj = h->cache_obj;
     cache_object_t *tobj = NULL;
@@ -524,7 +524,7 @@
 
     /* If the entity is still in the cache, remove it and decrement the
      * refcount. If the entity is not in the cache, do nothing. In both cases
-     * decrement_refcount called by the last thread referencing the object will 
+     * decrement_refcount called by the last thread referencing the object will
      * trigger the cleanup.
      */
     tobj = cache_find(sconf->cache_cache, obj->key);
@@ -532,15 +532,15 @@
         cache_remove(sconf->cache_cache, obj);
         apr_atomic_dec32(&obj->refcount);
     }
-    
+
     if (sconf->lock) {
         apr_thread_mutex_unlock(sconf->lock);
     }
 
     return OK;
 }
-static apr_status_t serialize_table(cache_header_tbl_t **obj, 
-                                    apr_ssize_t *nelts, 
+static apr_status_t serialize_table(cache_header_tbl_t **obj,
+                                    apr_ssize_t *nelts,
                                     apr_table_t *table)
 {
     const apr_array_header_t *elts_arr = apr_table_elts(table);
@@ -549,7 +549,7 @@
     apr_size_t len = 0;
     apr_size_t idx = 0;
     char *buf;
-   
+
     *nelts = elts_arr->nelts;
     if (*nelts == 0 ) {
         *obj=NULL;
@@ -585,15 +585,15 @@
     }
     return APR_SUCCESS;
 }
-static int unserialize_table( cache_header_tbl_t *ctbl, 
-                              int num_headers, 
+static int unserialize_table( cache_header_tbl_t *ctbl,
+                              int num_headers,
                               apr_table_t *t )
 {
     int i;
 
     for (i = 0; i < num_headers; ++i) {
         apr_table_addn(t, ctbl[i].hdr, ctbl[i].val);
-    } 
+    }
 
     return APR_SUCCESS;
 }
@@ -601,7 +601,7 @@
 /* remove_url()
  * Notes:
  */
-static int remove_url(cache_handle_t *h, apr_pool_t *p) 
+static int remove_url(cache_handle_t *h, apr_pool_t *p)
 {
     cache_object_t *obj;
     int cleanup = 0;
@@ -609,8 +609,8 @@
     if (sconf->lock) {
         apr_thread_mutex_lock(sconf->lock);
     }
- 
-    obj = h->cache_obj; 
+
+    obj = h->cache_obj;
     if (obj) {
         cache_remove(sconf->cache_cache, obj);
         /* For performance, cleanup cache object after releasing the lock */
@@ -627,11 +627,11 @@
     return OK;
 }
 
-static apr_status_t recall_headers(cache_handle_t *h, request_rec *r) 
+static apr_status_t recall_headers(cache_handle_t *h, request_rec *r)
 {
     int rc;
     mem_cache_object_t *mobj = (mem_cache_object_t*) h->cache_obj->vobj;
- 
+
     h->req_hdrs = apr_table_make(r->pool, mobj->num_req_hdrs);
     h->resp_hdrs = apr_table_make(r->pool, mobj->num_header_out);
 
@@ -642,7 +642,7 @@
     return rc;
 }
 
-static apr_status_t recall_body(cache_handle_t *h, apr_pool_t *p, apr_bucket_brigade *bb) 
+static apr_status_t recall_body(cache_handle_t *h, apr_pool_t *p, apr_bucket_brigade *bb)
 {
     apr_bucket *b;
     mem_cache_object_t *mobj = (mem_cache_object_t*) h->cache_obj->vobj;
@@ -673,10 +673,10 @@
     apr_table_t *headers_out;
 
     /*
-     * The cache needs to keep track of the following information: 
-     * - Date, LastMod, Version, ReqTime, RespTime, ContentLength 
-     * - The original request headers (for Vary) 
-     * - The original response headers (for returning with a cached response) 
+     * The cache needs to keep track of the following information:
+     * - Date, LastMod, Version, ReqTime, RespTime, ContentLength
+     * - The original request headers (for Vary)
+     * - The original response headers (for returning with a cached response)
      * - The body of the message
      */
     rc = serialize_table(&mobj->req_hdrs,
@@ -715,7 +715,7 @@
     return APR_SUCCESS;
 }
 
-static apr_status_t store_body(cache_handle_t *h, request_rec *r, apr_bucket_brigade *b) 
+static apr_status_t store_body(cache_handle_t *h, request_rec *r, apr_bucket_brigade *b)
 {
     apr_status_t rv;
     cache_object_t *obj = h->cache_obj;
@@ -778,10 +778,10 @@
         mobj->type = CACHE_TYPE_HEAP;
     }
 
-    /* 
+    /*
      * FD cacheing is not enabled or the content was not
      * suitable for fd caching.
-     */  
+     */
     if (mobj->m == NULL) {
         mobj->m = malloc(mobj->m_len);
         if (mobj->m == NULL) {
@@ -801,8 +801,8 @@
 
         if (APR_BUCKET_IS_EOS(e)) {
             if (mobj->m_len > obj->count) {
-                /* Caching a streamed response. Reallocate a buffer of the 
-                 * correct size and copy the streamed response into that 
+                /* Caching a streamed response. Reallocate a buffer of the
+                 * correct size and copy the streamed response into that
                  * buffer */
                 char *buf = malloc(obj->count);
                 if (!buf) {
@@ -814,7 +814,7 @@
 
                 /* Now comes the crufty part... there is no way to tell the
                  * cache that the size of the object has changed. We need
-                 * to remove the object, update the size and re-add the 
+                 * to remove the object, update the size and re-add the
                  * object, all under protection of the lock.
                  */
                 if (sconf->lock) {
@@ -830,14 +830,14 @@
                     cache_remove(sconf->cache_cache, obj);
                     /* For illustration, cache no longer has reference to the object
                      * so decrement the refcount
-                     * apr_atomic_dec32(&obj->refcount); 
+                     * apr_atomic_dec32(&obj->refcount);
                      */
                     mobj->m_len = obj->count;
 
                     cache_insert(sconf->cache_cache, obj);
                     /* For illustration, cache now has reference to the object, so
                      * increment the refcount
-                     * apr_atomic_inc32(&obj->refcount); 
+                     * apr_atomic_inc32(&obj->refcount);
                      */
                 }
                 else if (tobj) {
@@ -850,7 +850,7 @@
                     /* Object has been ejected from the cache, add it back to the cache */
                     mobj->m_len = obj->count;
                     cache_insert(sconf->cache_cache, obj);
-                    apr_atomic_inc32(&obj->refcount); 
+                    apr_atomic_inc32(&obj->refcount);
                 }
 
                 if (sconf->lock) {
@@ -905,7 +905,7 @@
         return DONE;
     }
     if (sconf->max_streaming_buffer_size > sconf->max_cache_object_size) {
-        /* Issue a notice only if something other than the default config 
+        /* Issue a notice only if something other than the default config
          * is being used */
         if (sconf->max_streaming_buffer_size != DEFAULT_MAX_STREAMING_BUFFER_SIZE &&
             sconf->max_cache_object_size != DEFAULT_MAX_CACHE_OBJECT_SIZE) {
@@ -927,7 +927,7 @@
     }
 
     sconf->cache_cache = cache_init(sconf->max_object_cnt,
-                                    sconf->max_cache_size,                                   
+                                    sconf->max_cache_size,
                                     memcache_get_priority,
                                     sconf->cache_remove_algorithm,
                                     memcache_get_pos,
@@ -944,8 +944,8 @@
     return -1;
 
 }
- 
-static const char 
+
+static const char
 *set_max_cache_size(cmd_parms *parms, void *in_struct_ptr, const char *arg)
 {
     apr_size_t val;
@@ -956,7 +956,7 @@
     sconf->max_cache_size = val*1024;
     return NULL;
 }
-static const char 
+static const char
 *set_min_cache_object_size(cmd_parms *parms, void *in_struct_ptr, const char *arg)
 {
     apr_size_t val;
@@ -967,7 +967,7 @@
     sconf->min_cache_object_size = val;
     return NULL;
 }
-static const char 
+static const char
 *set_max_cache_object_size(cmd_parms *parms, void *in_struct_ptr, const char *arg)
 {
     apr_size_t val;
@@ -978,7 +978,7 @@
     sconf->max_cache_object_size = val;
     return NULL;
 }
-static const char 
+static const char
 *set_max_object_count(cmd_parms *parms, void *in_struct_ptr, const char *arg)
 {
     apr_size_t val;
@@ -990,7 +990,7 @@
     return NULL;
 }
 
-static const char 
+static const char
 *set_cache_removal_algorithm(cmd_parms *parms, void *name, const char *arg)
 {
     if (strcasecmp("LRU", arg)) {

Modified: httpd/httpd/branches/2.2.x/modules/dav/fs/dbm.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/fs/dbm.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/fs/dbm.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/fs/dbm.c Thu Nov 10 07:20:05 2005
@@ -129,13 +129,13 @@
     *pdb = NULL;
 
     if ((status = apr_dbm_open(&file, pathname,
-                               ro ? APR_DBM_READONLY : APR_DBM_RWCREATE, 
+                               ro ? APR_DBM_READONLY : APR_DBM_RWCREATE,
                                APR_OS_DEFAULT, p))
                 != APR_SUCCESS
         && !ro) {
         /* ### do something with 'status' */
 
-        /* we can't continue if we couldn't open the file 
+        /* we can't continue if we couldn't open the file
            and we need to write */
         return dav_fs_dbm_error(NULL, p, status);
     }

Modified: httpd/httpd/branches/2.2.x/modules/dav/fs/lock.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/fs/lock.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/fs/lock.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/fs/lock.c Thu Nov 10 07:20:05 2005
@@ -41,7 +41,7 @@
 
 /*
 ** LOCK DATABASES
-** 
+**
 ** Lockdiscovery information is stored in the single lock database specified
 ** by the DAVLockDB directive.  Information about this db is stored in the
 ** global server configuration.
@@ -107,7 +107,7 @@
 
 /*
 ** We need to reliably size the fixed-length portion of
-** dav_lock_discovery; best to separate it into another 
+** dav_lock_discovery; best to separate it into another
 ** struct for a convenient sizeof, unless we pack lock_discovery.
 */
 typedef struct dav_lock_discovery_fixed
@@ -146,7 +146,7 @@
 
 
 /*
-** Stored direct lock info - full lock_discovery length:  
+** Stored direct lock info - full lock_discovery length:
 ** prefix + Fixed length + lock token + 2 strings + 2 nulls (one for each string)
 */
 #define dav_size_direct(a)	(1 + sizeof(dav_lock_discovery_fixed) \
@@ -258,7 +258,7 @@
                              "The opaquelocktoken has an incorrect format "
                              "and could not be parsed.");
     }
-    
+
     *locktoken_p = locktoken;
     return NULL;
 }
@@ -480,7 +480,7 @@
         (void) dav_dbm_delete(lockdb->info->db, key);
         return NULL;
     }
-                
+
     while(dp) {
         val.dsize += dav_size_direct(dp);
         dp = dp->next;
@@ -506,7 +506,7 @@
             *ptr++ = '\0';
         }
         else {
-            memcpy(ptr, dp->owner, strlen(dp->owner) + 1);	
+            memcpy(ptr, dp->owner, strlen(dp->owner) + 1);
             ptr += strlen(dp->owner) + 1;
         }
         if (dp->auth_user == NULL) {
@@ -588,7 +588,7 @@
 
     if ((err = dav_dbm_fetch(lockdb->info->db, key, &val)) != NULL)
         return err;
-        
+
     if (!val.dsize)
         return NULL;
 
@@ -613,7 +613,7 @@
 
             if (*(val.dptr + offset) == '\0') {
                 ++offset;
-            } 
+            }
             else {
                 dp->auth_user = apr_pstrdup(p, val.dptr + offset);
                 offset += strlen(dp->auth_user) + 1;
@@ -655,7 +655,7 @@
             offset += sizeof(ip->timeout);
             memcpy(&ip->key.dsize, val.dptr + offset, sizeof(ip->key.dsize)); /* length of datum */
             offset += sizeof(ip->key.dsize);
-            ip->key.dptr = apr_palloc(p, ip->key.dsize); 
+            ip->key.dptr = apr_palloc(p, ip->key.dsize);
             memcpy(ip->key.dptr, val.dptr + offset, ip->key.dsize);
             offset += ip->key.dsize;
 
@@ -710,7 +710,7 @@
     dav_error *err;
     dav_lock_discovery *dir;
     dav_lock_indirect *ind;
-        
+
     if ((err = dav_fs_load_lock_record(lockdb, indirect->key,
                                        DAV_CREATE_LIST,
                                        &dir, &ind)) != NULL) {
@@ -721,7 +721,7 @@
         *ref_dp = dir;
         *ref_ip = ind;
     }
-                
+
     for (; dir != NULL; dir = dir->next) {
         if (!dav_compare_locktoken(indirect->locktoken, dir->locktoken)) {
             *direct = dir;
@@ -783,7 +783,7 @@
 **    for the given directory.
 */
 static dav_error * dav_fs_load_locknull_list(apr_pool_t *p, const char *dirpath,
-                                             dav_buffer *pbuf) 
+                                             dav_buffer *pbuf)
 {
     apr_finfo_t finfo;
     apr_file_t *file = NULL;
@@ -888,7 +888,7 @@
         || amt != pbuf->cur_len) {
         err = dav_new_error(p, HTTP_INTERNAL_SERVER_ERROR, 0,
                             apr_psprintf(p,
-                                        "Error writing %" APR_SIZE_T_FMT 
+                                        "Error writing %" APR_SIZE_T_FMT
                                         " bytes to %s",
                                         pbuf->cur_len, pathname));
     }

Modified: httpd/httpd/branches/2.2.x/modules/dav/fs/repos.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/fs/repos.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/fs/repos.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/fs/repos.c Thu Nov 10 07:20:05 2005
@@ -183,7 +183,7 @@
     const char *pathname;       /* we may need to remove it at close time */
 };
 
-/* returns an appropriate HTTP status code given an APR status code for a 
+/* returns an appropriate HTTP status code given an APR status code for a
  * failed I/O operation.  ### use something besides 500? */
 #define MAP_IO2HTTP(e) (APR_STATUS_IS_ENOSPC(e) ? HTTP_INSUFFICIENT_STORAGE : \
                         HTTP_INTERNAL_SERVER_ERROR)
@@ -232,7 +232,7 @@
         if (dirlen > 0) {
             rv = apr_filepath_root(&rootpath, &testpath, 0, ctx->pool);
         }
-        
+
         /* remove trailing slash from dirpath, unless it's a root path
          */
         if ((rv == APR_SUCCESS && testpath && *testpath)
@@ -241,7 +241,7 @@
                 dirpath[dirlen - 1] = '\0';
             }
         }
-        
+
         /* ###: Looks like a response could be appropriate
          *
          * APR_SUCCESS     here tells us the dir is a root
@@ -272,7 +272,7 @@
 static void dav_format_time(int style, apr_time_t sec, char *buf)
 {
     apr_time_exp_t tms;
-    
+
     /* ### what to do if fails? */
     (void) apr_time_exp_gmt(&tms, sec);
 
@@ -330,14 +330,14 @@
                                      "Could not set permissions on destination");
             }
         }
-    } 
+    }
     else {
         perms = APR_OS_DEFAULT;
     }
 
     dav_set_bufsize(p, pbuf, DAV_FS_COPY_BLOCKSIZE);
 
-    if ((apr_file_open(&inf, src, APR_READ | APR_BINARY, APR_OS_DEFAULT, p)) 
+    if ((apr_file_open(&inf, src, APR_READ | APR_BINARY, APR_OS_DEFAULT, p))
             != APR_SUCCESS) {
         /* ### use something besides 500? */
         return dav_new_error(p, HTTP_INTERNAL_SERVER_ERROR, 0,
@@ -345,7 +345,7 @@
     }
 
     /* ### do we need to deal with the umask? */
-    status = apr_file_open(&outf, dst, APR_WRITE | APR_CREATE | APR_TRUNCATE 
+    status = apr_file_open(&outf, dst, APR_WRITE | APR_CREATE | APR_TRUNCATE
                            | APR_BINARY, perms, p);
     if (status != APR_SUCCESS) {
         apr_file_close(inf);
@@ -361,7 +361,7 @@
         if (status != APR_SUCCESS && status != APR_EOF) {
             apr_file_close(inf);
             apr_file_close(outf);
-            
+
             if (apr_file_remove(dst, p) != APR_SUCCESS) {
                 /* ### ACK! Inconsistent state... */
 
@@ -750,7 +750,7 @@
      */
     testpath = ctx->pathname;
     rv = apr_filepath_root(&testroot, &testpath, 0, ctx->pool);
-    if ((rv != APR_SUCCESS && rv != APR_ERELATIVE) 
+    if ((rv != APR_SUCCESS && rv != APR_ERELATIVE)
         || !testpath || !*testpath) {
         *result_parent = NULL;
         return NULL;
@@ -765,7 +765,7 @@
     parent_ctx->pool = ctx->pool;
 
     dirpath = ap_make_dirstr_parent(ctx->pool, ctx->pathname);
-    if (strlen(dirpath) > 1 && dirpath[strlen(dirpath) - 1] == '/') 
+    if (strlen(dirpath) > 1 && dirpath[strlen(dirpath) - 1] == '/')
         dirpath[strlen(dirpath) - 1] = '\0';
     parent_ctx->pathname = dirpath;
 
@@ -782,7 +782,7 @@
         parent_resource->uri = uri;
     }
 
-    rv = apr_stat(&parent_ctx->finfo, parent_ctx->pathname, 
+    rv = apr_stat(&parent_ctx->finfo, parent_ctx->pathname,
                   APR_FINFO_NORM, ctx->pool);
     if (rv == APR_SUCCESS || rv == APR_INCOMPLETE) {
         parent_resource->exists = 1;
@@ -1056,9 +1056,9 @@
         }
     }
     else {
-        err = dav_fs_copymove_file(ctx->is_move, ctx->pool, 
-                                   srcinfo->pathname, dstinfo->pathname, 
-                                   &srcinfo->finfo, 
+        err = dav_fs_copymove_file(ctx->is_move, ctx->pool,
+                                   srcinfo->pathname, dstinfo->pathname,
+                                   &srcinfo->finfo,
                                    ctx->res_dst->exists ? &dstinfo->finfo : NULL,
                                    &ctx->work_buf);
         /* ### push a higher-level description? */
@@ -1141,13 +1141,13 @@
     /* not a collection */
     if ((err = dav_fs_copymove_file(is_move, src->info->pool,
                                     src->info->pathname, dst->info->pathname,
-                                    &src->info->finfo, 
+                                    &src->info->finfo,
                                     dst->exists ? &dst->info->finfo : NULL,
                                     &work_buf)) != NULL) {
         /* ### push a higher-level description? */
         return err;
     }
-        
+
     /* copy/move properties as well */
     return dav_fs_copymoveset(is_move, src->info->pool, src, dst, &work_buf);
 }
@@ -1223,10 +1223,10 @@
          * so try it
          */
         dirpath = ap_make_dirstr_parent(dstinfo->pool, dstinfo->pathname);
-        /* 
+        /*
          * XXX: If missing dev ... then what test?
          * Really need a try and failover for those platforms.
-         * 
+         *
          */
         rv = apr_stat(&finfo, dirpath, APR_FINFO_DEV, dstinfo->pool);
         if ((rv == APR_SUCCESS || rv == APR_INCOMPLETE)
@@ -1456,7 +1456,7 @@
         len = strlen(dirent.name);
 
         /* avoid recursing into our current, parent, or state directories */
-        if (dirent.name[0] == '.' 
+        if (dirent.name[0] == '.'
               && (len == 1 || (dirent.name[1] == '.' && len == 2))) {
             continue;
         }
@@ -1481,7 +1481,7 @@
 
 
         /* ### Optimize me, dirent can give us what we need! */
-        status = apr_stat(&fsctx->info1.finfo, fsctx->path1.buf, 
+        status = apr_stat(&fsctx->info1.finfo, fsctx->path1.buf,
                           APR_FINFO_NORM | APR_FINFO_LINK, pool);
         if (status != APR_SUCCESS && status != APR_INCOMPLETE) {
             /* woah! where'd it go? */
@@ -1611,7 +1611,7 @@
             ** resource, query the lock database to force removal
             ** of both the lock entry and .locknull, if necessary..
             ** Sure, the query in PROPFIND would do this.. after
-            ** the locknull resource was already included in the 
+            ** the locknull resource was already included in the
             ** return.
             **
             ** NOTE: we assume the caller has opened the lock database
@@ -1773,7 +1773,7 @@
 {
     dav_resource_private *ctx = resource->info;
 
-    if (!resource->exists) 
+    if (!resource->exists)
         return apr_pstrdup(ctx->pool, "");
 
     if (ctx->finfo.filetype != 0) {

Modified: httpd/httpd/branches/2.2.x/modules/dav/lock/locks.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/lock/locks.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/lock/locks.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/lock/locks.c Thu Nov 10 07:20:05 2005
@@ -418,7 +418,7 @@
 }
 
 /*
- * dav_generic_lock_expired:  return 1 (true) if the given timeout is in the 
+ * dav_generic_lock_expired:  return 1 (true) if the given timeout is in the
  *    past or present (the lock has expired), or 0 (false) if in the future
  *    (the lock has not yet expired).
  */
@@ -647,7 +647,7 @@
             /* length of datum */
             ip->key.dsize = *((int *) (val.dptr + offset));
             offset += sizeof(ip->key.dsize);
-            ip->key.dptr = apr_palloc(p, ip->key.dsize); 
+            ip->key.dptr = apr_palloc(p, ip->key.dsize);
             memcpy(ip->key.dptr, val.dptr + offset, ip->key.dsize);
             offset += ip->key.dsize;
 

Modified: httpd/httpd/branches/2.2.x/modules/dav/main/liveprop.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/main/liveprop.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/main/liveprop.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/main/liveprop.c Thu Nov 10 07:20:05 2005
@@ -128,7 +128,7 @@
     return 0;
 }
 
-DAV_DECLARE(void) dav_register_liveprop_group(apr_pool_t *p, 
+DAV_DECLARE(void) dav_register_liveprop_group(apr_pool_t *p,
                                               const dav_liveprop_group *group)
 {
     /* register the namespace URIs */

Modified: httpd/httpd/branches/2.2.x/modules/dav/main/mod_dav.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/main/mod_dav.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/main/mod_dav.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/main/mod_dav.c Thu Nov 10 07:20:05 2005
@@ -440,13 +440,13 @@
       }
       ap_fputc(output, bb, '>');
     }
-    
+
     ap_fputstrs(output, bb,
                 DEBUG_CR "<D:href>",
                 dav_xml_escape_uri(pool, response->href),
                 "</D:href>" DEBUG_CR,
                 NULL);
-    
+
     if (response->propresult.propstats == NULL) {
       /* use the Status-Line text from Apache.  Note, this will
        * default to 500 Internal Server Error if first->status
@@ -464,7 +464,7 @@
         ap_fputs(output, bb, t->text);
       }
     }
-    
+
     if (response->desc != NULL) {
       /*
        * We supply the description, so we know it doesn't have to
@@ -476,7 +476,7 @@
                   "</D:responsedescription>" DEBUG_CR,
                   NULL);
     }
-    
+
     ap_fputs(output, bb, "</D:response>" DEBUG_CR);
 }
 
@@ -514,9 +514,9 @@
                                            apr_bucket_brigade *bb)
 {
     apr_bucket *b;
-    
+
     ap_fputs(r->output_filters, bb, "</D:multistatus>" DEBUG_CR);
-    
+
     /* indicate the end of the response body */
     b = apr_bucket_eos_create(r->connection->bucket_alloc);
     APR_BRIGADE_INSERT_TAIL(bb, b);
@@ -1437,7 +1437,7 @@
             if (elem->first_child == NULL) {
                 /* show all supported reports */
                 for (rp = reports; rp->nmspace != NULL; ++rp) {
-                    /* Note: we presume reports->namespace is 
+                    /* Note: we presume reports->namespace is
                      * properly XML/URL quoted */
                     s = apr_psprintf(r->pool,
                                      "<D:supported-report D:name=\"%s\" "
@@ -1478,7 +1478,7 @@
                             if (strcmp(name, rp->name) == 0
                                 && strcmp(nmspace, rp->nmspace) == 0) {
                                 /* Note: we presume reports->nmspace is
-                                 * properly XML/URL quoted 
+                                 * properly XML/URL quoted
                                  */
                                 s = apr_psprintf(r->pool,
                                                  "<D:supported-report "
@@ -4557,7 +4557,7 @@
     if (r->parsed_uri.fragment != NULL) {
         ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                      "buggy client used un-escaped hash in Request-URI");
-        return dav_error_response(r, HTTP_BAD_REQUEST, 
+        return dav_error_response(r, HTTP_BAD_REQUEST,
                                   "The request was invalid: the URI included "
                                   "an un-escaped hash character");
     }
@@ -4769,7 +4769,7 @@
     /* ### this is wrong.  We should only be setting the r->handler for the
      * requests that mod_dav knows about.  If we set the handler for M_POST
      * requests, then CGI scripts that use POST will return the source for the
-     * script.  However, mod_dav DOES handle POST, so something else needs 
+     * script.  However, mod_dav DOES handle POST, so something else needs
      * to be fixed.
      */
     if (r->method_number != M_POST) {

Modified: httpd/httpd/branches/2.2.x/modules/dav/main/util.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/main/util.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/main/util.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/main/util.c Thu Nov 10 07:20:05 2005
@@ -33,7 +33,7 @@
 #include "http_log.h"
 #include "http_protocol.h"
 
-DAV_DECLARE(dav_error*) dav_new_error(apr_pool_t *p, int status, 
+DAV_DECLARE(dav_error*) dav_new_error(apr_pool_t *p, int status,
                                       int error_id, const char *desc)
 {
     int save_errno = errno;
@@ -49,7 +49,7 @@
     return err;
 }
 
-DAV_DECLARE(dav_error*) dav_new_error_tag(apr_pool_t *p, int status, 
+DAV_DECLARE(dav_error*) dav_new_error_tag(apr_pool_t *p, int status,
                                           int error_id, const char *desc,
                                           const char *namespace,
                                           const char *tagname)
@@ -63,8 +63,8 @@
 }
 
 
-DAV_DECLARE(dav_error*) dav_push_error(apr_pool_t *p, int status, 
-                                       int error_id, const char *desc, 
+DAV_DECLARE(dav_error*) dav_push_error(apr_pool_t *p, int status,
+                                       int error_id, const char *desc,
                                        dav_error *prev)
 {
     dav_error *err = apr_pcalloc(p, sizeof(*err));
@@ -77,7 +77,7 @@
     return err;
 }
 
-DAV_DECLARE(void) dav_check_bufsize(apr_pool_t * p, dav_buffer *pbuf, 
+DAV_DECLARE(void) dav_check_bufsize(apr_pool_t * p, dav_buffer *pbuf,
                                     apr_size_t extra_needed)
 {
     /* grow the buffer if necessary */
@@ -91,7 +91,7 @@
     }
 }
 
-DAV_DECLARE(void) dav_set_bufsize(apr_pool_t * p, dav_buffer *pbuf, 
+DAV_DECLARE(void) dav_set_bufsize(apr_pool_t * p, dav_buffer *pbuf,
                                   apr_size_t size)
 {
     /* NOTE: this does not retain prior contents */
@@ -113,7 +113,7 @@
 
 
 /* initialize a buffer and copy the specified (null-term'd) string into it */
-DAV_DECLARE(void) dav_buffer_init(apr_pool_t *p, dav_buffer *pbuf, 
+DAV_DECLARE(void) dav_buffer_init(apr_pool_t *p, dav_buffer *pbuf,
                                   const char *str)
 {
     dav_set_bufsize(p, pbuf, strlen(str));
@@ -121,7 +121,7 @@
 }
 
 /* append a string to the end of the buffer, adjust length */
-DAV_DECLARE(void) dav_buffer_append(apr_pool_t *p, dav_buffer *pbuf, 
+DAV_DECLARE(void) dav_buffer_append(apr_pool_t *p, dav_buffer *pbuf,
                                     const char *str)
 {
     apr_size_t len = strlen(str);
@@ -132,7 +132,7 @@
 }
 
 /* place a string on the end of the buffer, do NOT adjust length */
-DAV_DECLARE(void) dav_buffer_place(apr_pool_t *p, dav_buffer *pbuf, 
+DAV_DECLARE(void) dav_buffer_place(apr_pool_t *p, dav_buffer *pbuf,
                                    const char *str)
 {
     apr_size_t len = strlen(str);
@@ -142,8 +142,8 @@
 }
 
 /* place some memory on the end of a buffer; do NOT adjust length */
-DAV_DECLARE(void) dav_buffer_place_mem(apr_pool_t *p, dav_buffer *pbuf, 
-                                       const void *mem, apr_size_t amt, 
+DAV_DECLARE(void) dav_buffer_place_mem(apr_pool_t *p, dav_buffer *pbuf,
+                                       const void *mem, apr_size_t amt,
                                        apr_size_t pad)
 {
     dav_check_bufsize(p, pbuf, amt + pad);
@@ -237,7 +237,7 @@
     /* we have verified the scheme, port, and general structure */
 
     /*
-    ** Hrm.  IE5 will pass unqualified hostnames for both the 
+    ** Hrm.  IE5 will pass unqualified hostnames for both the
     ** Host: and Destination: headers.  This breaks the
     ** http_vhost.c::matches_aliases function.
     **
@@ -297,7 +297,7 @@
 }
 
 /* find and return the (unique) child with a given DAV: tagname */
-DAV_DECLARE(apr_xml_elem *) dav_find_child(const apr_xml_elem *elem, 
+DAV_DECLARE(apr_xml_elem *) dav_find_child(const apr_xml_elem *elem,
                                            const char *tagname)
 {
     apr_xml_elem *child = elem->first_child;
@@ -533,7 +533,7 @@
 
     new_sl->condition = condition;
     new_sl->type      = t;
-    
+
     if (t == dav_if_opaquelock) {
         dav_error *err;
 
@@ -568,7 +568,7 @@
 {
     char *sp;
     char *token;
-        
+
     token = *str + 1;
 
     while (*token && (*token == ' ' || *token == '\t'))
@@ -604,7 +604,7 @@
     const dav_hooks_locks *locks_hooks = DAV_GET_HOOKS_LOCKS(r);
     enum {no_tagged, tagged, unknown} list_type = unknown;
     int condition;
-        
+
     *p_ih = NULL;
 
     if ((str = apr_pstrdup(r->pool, apr_table_get(r->headers_in, "If"))) == NULL)
@@ -621,7 +621,7 @@
                                      "Invalid If-header: unclosed \"<\" or "
                                      "unexpected tagged-list production.");
             }
-            
+
             /* 2518 specifies this must be an absolute URI; just take the
              * relative part for later comparison against r->uri */
             if (apr_uri_parse(r->pool, uri, &parsed_uri) != APR_SUCCESS) {
@@ -876,14 +876,14 @@
         /* lock_list now determines whether we're in State 1, 2, or 3. */
     }
 
-    /* 
+    /*
     ** For a new, exclusive lock: if any locks exist, fail.
     ** For a new, shared lock:    if an exclusive lock exists, fail.
     **                            else, do not require a token to be seen.
     */
     if (flags & DAV_LOCKSCOPE_EXCLUSIVE) {
         if (lock_list != NULL) {
-            return dav_new_error(p, HTTP_LOCKED, 0, 
+            return dav_new_error(p, HTTP_LOCKED, 0,
                                  "Existing lock(s) on the requested resource "
                                  "prevent an exclusive lock.");
         }
@@ -1160,13 +1160,13 @@
                     ** the lock, only the same user may submit that locktoken
                     ** to manipulate a resource.
                     */
-                    if (lock->auth_user && 
+                    if (lock->auth_user &&
                         (!r->user ||
                          strcmp(lock->auth_user, r->user))) {
                         const char *errmsg;
 
                         errmsg = apr_pstrcat(p, "User \"",
-                                            r->user, 
+                                            r->user,
                                             "\" submitted a locktoken created "
                                             "by user \"",
                                             lock->auth_user, "\".", NULL);
@@ -1204,9 +1204,9 @@
                 /* Request is predicated on some unknown state token,
                  * which must be presumed to *not* match, so fail
                  * unless this is a Not condition. */
-                
+
                 if (state_list->condition == DAV_IF_COND_NORMAL) {
-                    reason = 
+                    reason =
                         "an unknown state token was supplied";
                     goto state_list_failed;
                 }
@@ -1417,7 +1417,7 @@
 ** On error, return appropriate HTTP_* code, and log error. If a multi-stat
 ** error is necessary, response will point to it, else NULL.
 */
-DAV_DECLARE(dav_error *) dav_validate_request(request_rec *r, 
+DAV_DECLARE(dav_error *) dav_validate_request(request_rec *r,
                                               dav_resource *resource,
                                               int depth,
                                               dav_locktoken *locktoken,
@@ -1449,7 +1449,7 @@
     if (response != NULL)
         *response = NULL;
 
-    /* Do the standard checks for conditional requests using 
+    /* Do the standard checks for conditional requests using
      * If-..-Since, If-Match etc */
     if ((result = ap_meets_conditions(r)) != OK) {
         /* ### fix this up... how? */
@@ -1545,7 +1545,7 @@
                                               if_header,
                                               flags | DAV_VALIDATE_IS_PARENT,
                                               &work_buf, r);
-            
+
             /*
             ** This error occurred on the parent resource. This implies that
             ** we have to create a multistatus response (to report the error
@@ -1554,7 +1554,7 @@
             */
             if (err != NULL) {
                 new_response = apr_pcalloc(r->pool, sizeof(*new_response));
-                
+
                 new_response->href = parent_resource->uri;
                 new_response->status = err->status;
                 new_response->desc =
@@ -1567,11 +1567,11 @@
                                                     " The error was: ",
                                                     err->desc, NULL);
                 }
-                
+
                 /* assert: DAV_VALIDATE_PARENT implies response != NULL */
                 new_response->next = *response;
                 *response = new_response;
-                
+
                 err = NULL;
             }
         }
@@ -1642,20 +1642,20 @@
  * else NULL if no If-header, or no positive locktokens.
  */
 DAV_DECLARE(dav_error *) dav_get_locktoken_list(request_rec *r,
-                                                dav_locktoken_list **ltl) 
+                                                dav_locktoken_list **ltl)
 {
     dav_error *err;
     dav_if_header *if_header;
     dav_if_state_list *if_state;
-    dav_locktoken_list *lock_token = NULL;                
-        
+    dav_locktoken_list *lock_token = NULL;
+
     *ltl = NULL;
 
     if ((err = dav_process_if_header(r, &if_header)) != NULL) {
         /* ### add a higher-level description? */
         return err;
     }
-                         
+
     while (if_header != NULL) {
         if_state = if_header->state;        /* Begining of the if_state linked list */
         while (if_state != NULL)        {
@@ -1666,7 +1666,7 @@
                 lock_token->next = *ltl;
                 *ltl = lock_token;
             }
-            if_state = if_state->next; 
+            if_state = if_state->next;
         }
         if_header = if_header->next;
     }
@@ -1750,7 +1750,7 @@
  * auto_checkout - set to 1 if auto-checkout enabled
  */
 static dav_error * dav_can_auto_checkout(
-    request_rec *r,                                         
+    request_rec *r,
     dav_resource *resource,
     dav_auto_version auto_version,
     dav_lockdb **lockdb,

Modified: httpd/httpd/branches/2.2.x/modules/dav/main/util_lock.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/dav/main/util_lock.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/dav/main/util_lock.c (original)
+++ httpd/httpd/branches/2.2.x/modules/dav/main/util_lock.c Thu Nov 10 07:20:05 2005
@@ -55,7 +55,7 @@
     /* If no locks or no lock provider, there are no locks */
     if (lock == NULL || hooks == NULL) {
         /*
-        ** Since resourcediscovery is defined with (activelock)*, 
+        ** Since resourcediscovery is defined with (activelock)*,
         ** <D:activelock/> shouldn't be necessary for an empty lock.
         */
         return "";
@@ -129,7 +129,7 @@
             */
             dav_buffer_append(p, pbuf, lock->owner);
         }
-                
+
         dav_buffer_append(p, pbuf, "<D:timeout>");
         if (lock->timeout == DAV_TIMEOUT_INFINITE) {
             dav_buffer_append(p, pbuf, "Infinite");
@@ -223,7 +223,7 @@
             ** Store a full <DAV:owner> element with namespace definitions
             ** and an xml:lang definition, if applicable.
             */
-            apr_xml_to_text(p, child, APR_XML_X2T_FULL_NS_LANG, doc->namespaces, 
+            apr_xml_to_text(p, child, APR_XML_X2T_FULL_NS_LANG, doc->namespaces,
                             NULL, &text, NULL);
             lock->owner = text;
 
@@ -359,7 +359,7 @@
 ** dav_lock_query:  Opens the lock database. Returns a linked list of
 **    dav_lock structures for all direct locks on path.
 */
-DAV_DECLARE(dav_error*) dav_lock_query(dav_lockdb *lockdb, 
+DAV_DECLARE(dav_error*) dav_lock_query(dav_lockdb *lockdb,
                                        const dav_resource *resource,
                                        dav_lock **locks)
 {
@@ -507,7 +507,7 @@
     /* 2518 requires the entire lock to be removed if resource/locktoken
      * point to an indirect lock.  We need resource of the _direct_
      * lock in order to walk down the tree and remove the locks.  So,
-     * If locktoken != null_locktoken, 
+     * If locktoken != null_locktoken,
      *    Walk up the resource hierarchy until we see a direct lock.
      *    Or, we could get the direct lock's db/key, pick out the URL
      *    and do a subrequest.  I think walking up is faster and will work
@@ -711,7 +711,7 @@
         if (r->path_info != NULL && *r->path_info != '\0') {
             return DAV_RESOURCE_NULL;
         }
-        
+
         if ((err = (*hooks->open_lockdb)(r, 1, 1, &lockdb)) == NULL) {
             /* note that we might see some expired locks... *shrug* */
             err = (*hooks->has_locks)(lockdb, resource, &locks_present);

Modified: httpd/httpd/branches/2.2.x/modules/debug/mod_bucketeer.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/debug/mod_bucketeer.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/debug/mod_bucketeer.c (original)
+++ httpd/httpd/branches/2.2.x/modules/debug/mod_bucketeer.c Thu Nov 10 07:20:05 2005
@@ -69,7 +69,7 @@
     c = ap_get_module_config(r->server->module_config, &bucketeer_module);
 
     /* If have a context, it means we've done this before successfully. */
-    if (!ctx) {  
+    if (!ctx) {
         if (!r->content_type || strncmp(r->content_type, "text/", 5)) {
             ap_remove_output_filter(f);
             return ap_pass_brigade(f->next, bb);
@@ -77,7 +77,7 @@
 
         /* We're cool with filtering this. */
         ctx = f->ctx = apr_pcalloc(f->r->pool, sizeof(*ctx));
-        ctx->bb = apr_brigade_create(f->r->pool, f->c->bucket_alloc); 
+        ctx->bb = apr_brigade_create(f->r->pool, f->c->bucket_alloc);
         apr_table_unset(f->r->headers_out, "Content-Length");
     }
 
@@ -98,9 +98,9 @@
             return ap_pass_brigade(f->next, ctx->bb);
         }
 
-        if (APR_BUCKET_IS_FLUSH(e)) {     
+        if (APR_BUCKET_IS_FLUSH(e)) {
             /*
-             * Ignore flush buckets for the moment.. 
+             * Ignore flush buckets for the moment..
              * we decide what to stream
              */
             continue;
@@ -143,7 +143,7 @@
                         ap_pass_brigade(f->next, ctx->bb);
                        /* apr_brigade_cleanup(ctx->bb);*/
                     }
-                }                       
+                }
             }
             /* XXX: really should append this to the next 'real' bucket */
             if (lastpos < i) {
@@ -157,7 +157,7 @@
                 lastpos = i;
                 APR_BRIGADE_INSERT_TAIL(ctx->bb, p);
             }
-        }     
+        }
     }
 
     return APR_SUCCESS;

Modified: httpd/httpd/branches/2.2.x/modules/debug/mod_dumpio.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/debug/mod_dumpio.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/debug/mod_dumpio.c (original)
+++ httpd/httpd/branches/2.2.x/modules/debug/mod_dumpio.c Thu Nov 10 07:20:05 2005
@@ -47,7 +47,7 @@
 static void dumpit(ap_filter_t *f, apr_bucket *b)
 {
     conn_rec *c = f->c;
-    
+
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, c->base_server,
         "mod_dumpio:  %s (%s-%s): %" APR_SIZE_T_FMT " bytes",
                 f->frec->name,
@@ -91,7 +91,7 @@
    (( mode ) == AP_MODE_EXHAUSTIVE) ? "exhaustive" : \
    (( mode ) == AP_MODE_INIT) ? "init" : "unknown" \
  )
-       
+
 static int dumpio_input_filter (ap_filter_t *f, apr_bucket_brigade *bb,
     ap_input_mode_t mode, apr_read_type_e block, apr_off_t readbytes)
 {
@@ -125,9 +125,9 @@
 {
     apr_bucket *b;
     conn_rec *c = f->c;
-    
+
     ap_log_error(APLOG_MARK, APLOG_DEBUG, 0, c->base_server, "mod_dumpio: %s", f->frec->name) ;
-    
+
     for (b = APR_BRIGADE_FIRST(bb); b != APR_BRIGADE_SENTINEL(bb); b = APR_BUCKET_NEXT(b)) {
         /*
          * If we ever see an EOS, make sure to FLUSH.
@@ -138,7 +138,7 @@
         }
         dumpit(f, b);
     }
-    
+
     return ap_pass_brigade(f->next, bb) ;
 }
 
@@ -147,7 +147,7 @@
     dumpio_conf_t *ptr =
     (dumpio_conf_t *) ap_get_module_config(c->base_server->module_config,
                                            &dumpio_module);
-    
+
     if (ptr->enable_input)
         ap_add_input_filter("DUMPIO_IN", NULL, NULL, c);
     if (ptr->enable_output)
@@ -181,7 +181,7 @@
     dumpio_conf_t *ptr =
     (dumpio_conf_t *) ap_get_module_config(cmd->server->module_config,
                                            &dumpio_module);
-    
+
     ptr->enable_input = arg;
     return NULL;
 }
@@ -191,7 +191,7 @@
     dumpio_conf_t *ptr =
     (dumpio_conf_t *) ap_get_module_config(cmd->server->module_config,
                                            &dumpio_module);
-    
+
     ptr->enable_output = arg;
     return NULL;
 }

Modified: httpd/httpd/branches/2.2.x/modules/echo/mod_echo.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/echo/mod_echo.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/echo/mod_echo.c (original)
+++ httpd/httpd/branches/2.2.x/modules/echo/mod_echo.c Thu Nov 10 07:20:05 2005
@@ -64,7 +64,7 @@
 
         /* Get a single line of input from the client */
         if ((rv = ap_get_brigade(c->input_filters, bb, AP_MODE_GETLINE,
-                                 APR_BLOCK_READ, 0) != APR_SUCCESS || 
+                                 APR_BLOCK_READ, 0) != APR_SUCCESS ||
              APR_BRIGADE_EMPTY(bb))) {
             apr_brigade_destroy(bb);
             break;
@@ -81,7 +81,7 @@
     return OK;
 }
 
-static const command_rec echo_cmds[] = 
+static const command_rec echo_cmds[] =
 {
     AP_INIT_FLAG("ProtocolEcho", echo_on, NULL, RSRC_CONF,
                  "Run an echo server on this host"),

Modified: httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter.c (original)
+++ httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter.c Thu Nov 10 07:20:05 2005
@@ -104,7 +104,7 @@
     return NULL;
     }
 
-static const command_rec CaseFilterCmds[] = 
+static const command_rec CaseFilterCmds[] =
     {
     AP_INIT_FLAG("CaseFilter", CaseFilterEnable, NULL, RSRC_CONF,
                  "Run a case filter on this host"),

Modified: httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter_in.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter_in.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter_in.c (original)
+++ httpd/httpd/branches/2.2.x/modules/experimental/mod_case_filter_in.c Thu Nov 10 07:20:05 2005
@@ -120,8 +120,8 @@
 
     return APR_SUCCESS;
 }
-            
-        
+
+
 static const char *CaseFilterInEnable(cmd_parms *cmd, void *dummy, int arg)
 {
     CaseFilterInConfig *pConfig
@@ -132,7 +132,7 @@
     return NULL;
 }
 
-static const command_rec CaseFilterInCmds[] = 
+static const command_rec CaseFilterInCmds[] =
 {
     AP_INIT_FLAG("CaseFilterIn", CaseFilterInEnable, NULL, RSRC_CONF,
                  "Run an input case filter on this host"),
@@ -142,7 +142,7 @@
 
 static void CaseFilterInRegisterHooks(apr_pool_t *p)
 {
-    ap_hook_insert_filter(CaseFilterInInsertFilter, NULL, NULL, 
+    ap_hook_insert_filter(CaseFilterInInsertFilter, NULL, NULL,
                           APR_HOOK_MIDDLE);
     ap_register_input_filter(s_szCaseFilterName, CaseFilterInFilter, NULL,
                              AP_FTYPE_RESOURCE);

Modified: httpd/httpd/branches/2.2.x/modules/experimental/mod_example.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/experimental/mod_example.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/experimental/mod_example.c (original)
+++ httpd/httpd/branches/2.2.x/modules/experimental/mod_example.c Thu Nov 10 07:20:05 2005
@@ -14,7 +14,7 @@
  * limitations under the License.
  */
 
-/* 
+/*
  * Apache example module.  Provide demonstrations of how modules do things.
  * It is not meant to be used in a production server.  Since it participates
  * in all of the processing phases, it could conceivable interfere with
@@ -458,7 +458,7 @@
 /* at it.  If it returns any other value, it's treated as the text of an    */
 /* error message.                                                           */
 /*--------------------------------------------------------------------------*/
-/* 
+/*
  * Command handler for the NO_ARGS "Example" directive.  All we do is mark the
  * call in the trace log, and flag the applicability of the directive to the
  * current location in that location's configuration record.
@@ -489,7 +489,7 @@
 /* calling send_http_header().  Otherwise, no header will be sent at all,   */
 /* and the output sent to the client will actually be HTTP-uncompliant.     */
 /*--------------------------------------------------------------------------*/
-/* 
+/*
  * Sample content handler.  All this does is display the call list that has
  * been built up so far.
  *
@@ -627,7 +627,7 @@
 /* see the individual handler comments below for details.                   */
 /*                                                                          */
 /*--------------------------------------------------------------------------*/
-/* 
+/*
  * This function is called during server initialisation.  Any information
  * that needs to be recorded must be in static cells, since there's no
  * configuration record.
@@ -635,7 +635,7 @@
  * There is no return value.
  */
 
-/* 
+/*
  * This function is called when an heavy-weight process (such as a child) is
  * being run down or destroyed.  As with the child initialisation function,
  * any information that needs to be recorded must be in static cells, since
@@ -644,7 +644,7 @@
  * There is no return value.
  */
 
-/* 
+/*
  * This function is called during server initialisation when an heavy-weight
  * process (such as a child) is being initialised.  As with the
  * module initialisation function, any information that needs to be recorded
@@ -1014,7 +1014,7 @@
  * some other protocol.  Both echo and POP3 modules are available as
  * examples.
  *
- * The return VALUE is OK, DECLINED, or HTTP_mumble.  If we return OK, no 
+ * The return VALUE is OK, DECLINED, or HTTP_mumble.  If we return OK, no
  * further modules are called for this phase.
  */
 static int x_process_connection(conn_rec *c)
@@ -1244,9 +1244,9 @@
 /* Which functions are responsible for which hooks in the server.           */
 /*                                                                          */
 /*--------------------------------------------------------------------------*/
-/* 
+/*
  * Each function our module provides to handle a particular hook is
- * specified here.  The functions are registered using 
+ * specified here.  The functions are registered using
  * ap_hook_foo(name, predecessors, successors, position)
  * where foo is the name of the hook.
  *
@@ -1262,7 +1262,7 @@
  *                 modules use the same relative position, Apache will
  *                 determine which to call first.
  *                 If your module relies on another module to run first,
- *                 or another module running after yours, use the 
+ *                 or another module running after yours, use the
  *                 predecessors and/or successors.
  *
  * The number in brackets indicates the order in which the routine is called
@@ -1309,7 +1309,7 @@
 /* collisions of directive names between modules.                           */
 /*                                                                          */
 /*--------------------------------------------------------------------------*/
-/* 
+/*
  * List of directives specific to our module.
  */
 static const command_rec x_cmds[] =
@@ -1329,7 +1329,7 @@
 /* the static hooks into our module from the other parts of the server.     */
 /*                                                                          */
 /*--------------------------------------------------------------------------*/
-/* 
+/*
  * Module definition for configuration.  If a particular callback is not
  * needed, replace its routine name below with the word NULL.
  */

Modified: httpd/httpd/branches/2.2.x/modules/filters/mod_charset_lite.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/filters/mod_charset_lite.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/filters/mod_charset_lite.c (original)
+++ httpd/httpd/branches/2.2.x/modules/filters/mod_charset_lite.c Thu Nov 10 07:20:05 2005
@@ -45,10 +45,10 @@
 #define INPUT_XLATE_BUF_SIZE  (8*1024)  /* size of translation buffer used on input */
 
 #define XLATE_MIN_BUFF_LEFT 128  /* flush once there is no more than this much
-                                  * space left in the translation buffer 
+                                  * space left in the translation buffer
                                   */
 
-#define FATTEST_CHAR  8          /* we don't handle chars wider than this that straddle 
+#define FATTEST_CHAR  8          /* we don't handle chars wider than this that straddle
                                   * two buckets
                                   */
 
@@ -67,15 +67,15 @@
 /* registered name of the output translation filter */
 #define XLATEOUT_FILTER_NAME "XLATEOUT"
 /* registered name of input translation filter */
-#define XLATEIN_FILTER_NAME  "XLATEIN" 
+#define XLATEIN_FILTER_NAME  "XLATEIN"
 
 typedef struct charset_dir_t {
     /** debug level; -1 means uninitialized, 0 means no debug */
     int debug;
     const char *charset_source; /* source encoding */
     const char *charset_default; /* how to ship on wire */
-    /** module does ap_add_*_filter()? */    
-    enum {IA_INIT, IA_IMPADD, IA_NOIMPADD} implicit_add; 
+    /** module does ap_add_*_filter()? */
+    enum {IA_INIT, IA_IMPADD, IA_NOIMPADD} implicit_add;
 } charset_dir_t;
 
 /* charset_filter_ctx_t is created for each filter instance; because the same
@@ -126,14 +126,14 @@
         *over = (charset_dir_t *)overridesv;
 
     /* If it is defined in the current container, use it.  Otherwise, use the one
-     * from the enclosing container. 
+     * from the enclosing container.
      */
 
-    a->debug = 
+    a->debug =
         over->debug != -1 ? over->debug : base->debug;
-    a->charset_default = 
+    a->charset_default =
         over->charset_default ? over->charset_default : base->charset_default;
-    a->charset_source = 
+    a->charset_source =
         over->charset_source ? over->charset_source : base->charset_source;
     a->implicit_add =
         over->implicit_add != IA_INIT ? over->implicit_add : base->implicit_add;
@@ -153,7 +153,7 @@
 
 /* CharsetDefault charset
  */
-static const char *add_charset_default(cmd_parms *cmd, void *in_dc, 
+static const char *add_charset_default(cmd_parms *cmd, void *in_dc,
                                        const char *name)
 {
     charset_dir_t *dc = in_dc;
@@ -164,7 +164,7 @@
 
 /* CharsetOptions optionflag...
  */
-static const char *add_charset_options(cmd_parms *cmd, void *in_dc, 
+static const char *add_charset_options(cmd_parms *cmd, void *in_dc,
                                        const char *flag)
 {
     charset_dir_t *dc = in_dc;
@@ -179,7 +179,7 @@
         dc->debug = atoi(flag + 11);
     }
     else {
-        return apr_pstrcat(cmd->temp_pool, 
+        return apr_pstrcat(cmd->temp_pool,
                            "Invalid CharsetOptions option: ",
                            flag,
                            NULL);
@@ -194,7 +194,7 @@
  */
 static int find_code_page(request_rec *r)
 {
-    charset_dir_t *dc = ap_get_module_config(r->per_dir_config, 
+    charset_dir_t *dc = ap_get_module_config(r->per_dir_config,
                                              &charset_lite_module);
     charset_req_t *reqinfo;
     charset_filter_ctx_t *input_ctx, *output_ctx;
@@ -228,21 +228,21 @@
     /* catch proxy requests */
     if (r->proxyreq) return DECLINED;
     /* mod_rewrite indicators */
-    if (!strncmp(r->filename, "redirect:", 9)) return DECLINED; 
-    if (!strncmp(r->filename, "gone:", 5)) return DECLINED; 
-    if (!strncmp(r->filename, "passthrough:", 12)) return DECLINED; 
-    if (!strncmp(r->filename, "forbidden:", 10)) return DECLINED; 
-    
+    if (!strncmp(r->filename, "redirect:", 9)) return DECLINED;
+    if (!strncmp(r->filename, "gone:", 5)) return DECLINED;
+    if (!strncmp(r->filename, "passthrough:", 12)) return DECLINED;
+    if (!strncmp(r->filename, "forbidden:", 10)) return DECLINED;
+
     mime_type = r->content_type ? r->content_type : ap_default_type(r);
 
     /* If mime type isn't text or message, bail out.
      */
 
 /* XXX When we handle translation of the request body, watch out here as
- *     1.3 allowed additional mime types: multipart and 
+ *     1.3 allowed additional mime types: multipart and
  *     application/x-www-form-urlencoded
  */
-             
+
     if (strncasecmp(mime_type, "text/", 5) &&
 #if APR_CHARSET_EBCDIC || AP_WANT_DIR_TRANSLATION
         /* On an EBCDIC machine, be willing to translate mod_autoindex-
@@ -283,8 +283,8 @@
     /* Get storage for the request data and the output filter context.
      * We rarely need the input filter context, so allocate that separately.
      */
-    reqinfo = (charset_req_t *)apr_pcalloc(r->pool, 
-                                           sizeof(charset_req_t) + 
+    reqinfo = (charset_req_t *)apr_pcalloc(r->pool,
+                                           sizeof(charset_req_t) +
                                            sizeof(charset_filter_ctx_t));
     output_ctx = (charset_filter_ctx_t *)(reqinfo + 1);
 
@@ -305,8 +305,8 @@
     switch (r->method_number) {
     case M_PUT:
     case M_POST:
-        /* Set up input translation.  Note: A request body can be included 
-         * with the OPTIONS method, but for now we don't set up translation 
+        /* Set up input translation.  Note: A request body can be included
+         * with the OPTIONS method, but for now we don't set up translation
          * of it.
          */
         input_ctx = apr_pcalloc(r->pool, sizeof(charset_filter_ctx_t));
@@ -315,7 +315,7 @@
         input_ctx->tmp = apr_palloc(r->pool, INPUT_XLATE_BUF_SIZE);
         input_ctx->dc = dc;
         reqinfo->input_ctx = input_ctx;
-        rv = apr_xlate_open(&input_ctx->xlate, dc->charset_source, 
+        rv = apr_xlate_open(&input_ctx->xlate, dc->charset_source,
                             dc->charset_default, r->pool);
         if (rv != APR_SUCCESS) {
             ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, r,
@@ -358,20 +358,20 @@
 static void xlate_insert_filter(request_rec *r)
 {
     /* Hey... don't be so quick to use reqinfo->dc here; reqinfo may be NULL */
-    charset_req_t *reqinfo = ap_get_module_config(r->request_config, 
+    charset_req_t *reqinfo = ap_get_module_config(r->request_config,
                                                   &charset_lite_module);
-    charset_dir_t *dc = ap_get_module_config(r->per_dir_config, 
+    charset_dir_t *dc = ap_get_module_config(r->per_dir_config,
                                              &charset_lite_module);
 
     if (reqinfo) {
         if (reqinfo->output_ctx && !configured_on_output(r, XLATEOUT_FILTER_NAME)) {
-            ap_add_output_filter(XLATEOUT_FILTER_NAME, reqinfo->output_ctx, r, 
+            ap_add_output_filter(XLATEOUT_FILTER_NAME, reqinfo->output_ctx, r,
                                  r->connection);
         }
         else if (dc->debug >= DBGLVL_FLOW) {
             ap_log_rerror(APLOG_MARK, APLOG_DEBUG, 0, r,
                           "xlate output filter not added implicitly because %s",
-                          !reqinfo->output_ctx ? 
+                          !reqinfo->output_ctx ?
                           "no output configuration available" :
                           "another module added the filter");
         }
@@ -443,7 +443,7 @@
     return rv;
 }
 
-static apr_status_t set_aside_partial_char(charset_filter_ctx_t *ctx, 
+static apr_status_t set_aside_partial_char(charset_filter_ctx_t *ctx,
                                            const char *partial,
                                            apr_size_t partial_len)
 {
@@ -456,8 +456,8 @@
     }
     else {
         rv = APR_INCOMPLETE;
-        ctx->ees = EES_LIMIT; /* we don't handle chars this wide which straddle 
-                               * buckets 
+        ctx->ees = EES_LIMIT; /* we don't handle chars this wide which straddle
+                               * buckets
                                */
     }
     return rv;
@@ -465,7 +465,7 @@
 
 static apr_status_t finish_partial_char(charset_filter_ctx_t *ctx,
                                         /* input buffer: */
-                                        const char **cur_str, 
+                                        const char **cur_str,
                                         apr_size_t *cur_len,
                                         /* output buffer: */
                                         char **out_str,
@@ -530,7 +530,7 @@
         strcpy(msgbuf, "xlate filter - incomplete char at end of input - ");
         cur = 0;
         while ((apr_size_t)cur < ctx->saved) {
-            apr_snprintf(msgbuf + strlen(msgbuf), sizeof(msgbuf) - strlen(msgbuf), 
+            apr_snprintf(msgbuf + strlen(msgbuf), sizeof(msgbuf) - strlen(msgbuf),
                          "%02X", (unsigned)ctx->buf[cur]);
             ++cur;
         }
@@ -602,15 +602,15 @@
             else {
                 if (strcmp(last_xlate_ctx->dc->charset_default,
                            curctx->dc->charset_source)) {
-                    /* incompatible translation 
+                    /* incompatible translation
                      * if our filter instance is incompatible with an instance
                      * already in place, noop our instance
-                     * Notes: 
+                     * Notes:
                      * . We are only willing to noop our own instance.
                      * . It is possible to noop another instance which has not
                      *   yet run, but this is not currently implemented.
                      *   Hopefully it will not be needed.
-                     * . It is not possible to noop an instance which has 
+                     * . It is not possible to noop an instance which has
                      *   already run.
                      */
                     if (last_xlate_ctx == f->ctx) {
@@ -680,7 +680,7 @@
  */
 static apr_status_t xlate_brigade(charset_filter_ctx_t *ctx,
                                   apr_bucket_brigade *bb,
-                                  char *buffer, 
+                                  char *buffer,
                                   apr_size_t *buffer_avail,
                                   int *hit_eos)
 {
@@ -737,7 +737,7 @@
                                            buffer_avail);
                 buffer  += old_buffer_avail - *buffer_avail;
                 bucket  += old_bucket_avail - bucket_avail;
-                
+
                 if (rv == APR_INCOMPLETE) { /* partial character at end of input */
                     /* We need to save the final byte(s) for next time; we can't
                      * convert it until we look at the next bucket.
@@ -781,7 +781,7 @@
     return rv;
 }
 
-/* xlate_out_filter() handles (almost) arbitrary conversions from one charset 
+/* xlate_out_filter() handles (almost) arbitrary conversions from one charset
  * to another...
  * translation is determined in the fixup hook (find_code_page), which is
  * where the filter's context data is set up... the context data gives us
@@ -802,7 +802,7 @@
     int done;
     apr_status_t rv = APR_SUCCESS;
 
-    if (!ctx) { 
+    if (!ctx) {
         /* this is SetOutputFilter path; grab the preallocated context,
          * if any; note that if we decided not to do anything in an earlier
          * handler, we won't even have a reqinfo
@@ -833,7 +833,7 @@
         const char *mime_type = f->r->content_type ? f->r->content_type : ap_default_type(f->r);
 
         /* XXX When we handle translation of the request body, watch out here as
-         *     1.3 allowed additional mime types: multipart and 
+         *     1.3 allowed additional mime types: multipart and
          *     application/x-www-form-urlencoded
          */
         if (strncasecmp(mime_type, "text/", 5) == 0 ||
@@ -854,7 +854,7 @@
 #endif
         strncasecmp(mime_type, "message/", 8) == 0) {
 
-            rv = apr_xlate_open(&ctx->xlate, 
+            rv = apr_xlate_open(&ctx->xlate,
                         dc->charset_default, dc->charset_source, f->r->pool);
             if (rv != APR_SUCCESS) {
                 ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, f->r,
@@ -865,7 +865,7 @@
         }
         else {
                 ctx->noop = 1;
-                if (dc->debug >= DBGLVL_GORY) 
+                if (dc->debug >= DBGLVL_GORY)
                     ap_log_rerror(APLOG_MARK, APLOG_DEBUG, 0, f->r,
                                   "mime type is %s; no translation selected",
                                   mime_type);
@@ -925,7 +925,7 @@
                 break;
             }
             consumed_bucket = dptr; /* for axing when we're done reading it */
-            dptr = APR_BUCKET_NEXT(dptr); /* get ready for when we access the 
+            dptr = APR_BUCKET_NEXT(dptr); /* get ready for when we access the
                                           * next bucket */
         }
         /* Try to fill up our tmp buffer with translated data. */
@@ -937,7 +937,7 @@
                  * bucket.
                  */
                 char *tmp_tmp;
-                
+
                 tmp_tmp = tmp + sizeof(tmp) - space_avail;
                 rv = finish_partial_char(ctx,
                                          &cur_str, &cur_len,
@@ -947,11 +947,11 @@
                 rv = apr_xlate_conv_buffer(ctx->xlate,
                                            cur_str, &cur_avail,
                                            tmp + sizeof(tmp) - space_avail, &space_avail);
-                
+
                 /* Update input ptr and len after consuming some bytes */
                 cur_str += cur_len - cur_avail;
                 cur_len = cur_avail;
-                
+
                 if (rv == APR_INCOMPLETE) { /* partial character at end of input */
                     /* We need to save the final byte(s) for next time; we can't
                      * convert it until we look at the next bucket.
@@ -975,7 +975,7 @@
             if (rv != APR_SUCCESS) {
                 done = 1;
             }
-            
+
             /* tmp is now empty */
             space_avail = sizeof(tmp);
         }
@@ -998,7 +998,7 @@
     return rv;
 }
 
-static int xlate_in_filter(ap_filter_t *f, apr_bucket_brigade *bb, 
+static int xlate_in_filter(ap_filter_t *f, apr_bucket_brigade *bb,
                            ap_input_mode_t mode, apr_read_type_e block,
                            apr_off_t readbytes)
 {
@@ -1011,7 +1011,7 @@
     apr_size_t buffer_size;
     int hit_eos;
 
-    if (!ctx) { 
+    if (!ctx) {
         /* this is SetInputFilter path; grab the preallocated context,
          * if any; note that if we decided not to do anything in an earlier
          * handler, we won't even have a reqinfo
@@ -1048,7 +1048,7 @@
     }
 
     if (APR_BRIGADE_EMPTY(ctx->bb)) {
-        if ((rv = ap_get_brigade(f->next, bb, mode, block, 
+        if ((rv = ap_get_brigade(f->next, bb, mode, block,
                                  readbytes)) != APR_SUCCESS) {
             return rv;
         }
@@ -1071,11 +1071,11 @@
         if (buffer_size < INPUT_XLATE_BUF_SIZE) { /* do we have output? */
             apr_bucket *e;
 
-            e = apr_bucket_heap_create(ctx->tmp, 
+            e = apr_bucket_heap_create(ctx->tmp,
                                        INPUT_XLATE_BUF_SIZE - buffer_size,
                                        NULL, f->r->connection->bucket_alloc);
             /* make sure we insert at the head, because there may be
-             * an eos bucket already there, and the eos bucket should 
+             * an eos bucket already there, and the eos bucket should
              * come after the data
              */
             APR_BRIGADE_INSERT_HEAD(bb, e);
@@ -1102,10 +1102,10 @@
                   NULL,
                   OR_FILEINFO,
                   "source (html,cgi,ssi) file charset"),
-    AP_INIT_TAKE1("CharsetDefault", 
+    AP_INIT_TAKE1("CharsetDefault",
                   add_charset_default,
                   NULL,
-                  OR_FILEINFO, 
+                  OR_FILEINFO,
                   "name of default charset"),
     AP_INIT_ITERATE("CharsetOptions",
                     add_charset_options,
@@ -1130,7 +1130,7 @@
     STANDARD20_MODULE_STUFF,
     create_charset_dir_conf,
     merge_charset_dir_conf,
-    NULL, 
+    NULL,
     NULL,
     cmds,
     charset_register_hooks

Modified: httpd/httpd/branches/2.2.x/modules/filters/mod_deflate.c
URL: http://svn.apache.org/viewcvs/httpd/httpd/branches/2.2.x/modules/filters/mod_deflate.c?rev=332309&r1=332308&r2=332309&view=diff
==============================================================================
--- httpd/httpd/branches/2.2.x/modules/filters/mod_deflate.c (original)
+++ httpd/httpd/branches/2.2.x/modules/filters/mod_deflate.c Thu Nov 10 07:20:05 2005
@@ -67,7 +67,7 @@
  * |ID1|ID2|CM |FLG|     MTIME     |XFL|OS |
  * +---+---+---+---+---+---+---+---+---+---+
  */
-static const char gzip_header[10] = 
+static const char gzip_header[10] =
 { '\037', '\213', Z_DEFLATED, 0,
   0, 0, 0, 0, /* mtime */
   0, 0x03 /* Unix OS_CODE */
@@ -152,7 +152,7 @@
 {
     deflate_filter_config *c = ap_get_module_config(cmd->server->module_config,
                                                     &deflate_module);
-    
+
     if (arg2 == NULL) {
         c->note_ratio_name = apr_pstrdup(cmd->pool, arg1);
     }
@@ -264,7 +264,7 @@
             if ( env_value && (strcmp(env_value,"1") == 0) ) {
                 ap_remove_output_filter(f);
                 return ap_pass_brigade(f->next, bb);
-            }            
+            }
         }
 
         /* Let's see what our current Content-Encoding is.
@@ -332,7 +332,7 @@
             token = ap_get_token(r->pool, &accepts, 0);
             while (token && token[0] && strcasecmp(token, "gzip")) {
                 /* skip parameters, XXX: ;q=foo evaluation? */
-                while (*accepts == ';') { 
+                while (*accepts == ';') {
                     ++accepts;
                     token = ap_get_token(r->pool, &accepts, 1);
                 }
@@ -394,7 +394,7 @@
         ctx->stream.next_out = ctx->buffer;
         ctx->stream.avail_out = c->bufferSize;
     }
-    
+
     while (!APR_BRIGADE_EMPTY(bb))
     {
         const char *data;
@@ -627,8 +627,8 @@
             return rv;
         }
 
-        len = 10; 
-        rv = apr_brigade_flatten(ctx->bb, deflate_hdr, &len); 
+        len = 10;
+        rv = apr_brigade_flatten(ctx->bb, deflate_hdr, &len);
         if (rv != APR_SUCCESS) {
             return rv;
         }
@@ -784,7 +784,7 @@
                 inflateEnd(&ctx->stream);
 
                 eos = apr_bucket_eos_create(f->c->bucket_alloc);
-                APR_BRIGADE_INSERT_TAIL(ctx->proc_bb, eos); 
+                APR_BRIGADE_INSERT_TAIL(ctx->proc_bb, eos);
                 break;
             }
 
@@ -831,7 +831,7 @@
 {
     int zlib_method;
     int zlib_flags;
-    int deflate_init = 1; 
+    int deflate_init = 1;
     apr_bucket *bkt;
     request_rec *r = f->r;
     deflate_ctx *ctx = f->ctx;
@@ -961,7 +961,7 @@
                 ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, r,
                               "Insufficient data for inflate");
                 return APR_EGENERAL;
-            } 
+            }
             else  {
                 zlib_method = data[2];
                 zlib_flags = data[3];
@@ -1077,7 +1077,7 @@
             inflateEnd(&ctx->stream);
 
             eos = apr_bucket_eos_create(f->c->bucket_alloc);
-            APR_BRIGADE_INSERT_TAIL(ctx->proc_bb, eos); 
+            APR_BRIGADE_INSERT_TAIL(ctx->proc_bb, eos);
             break;
         }