You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apr.apache.org by iv...@apache.org on 2022/11/20 07:14:40 UTC

svn commit: r1905414 [1/8] - in /apr/apr/trunk: atomic/netware/ atomic/os390/ buckets/ build/ crypto/ dbd/ dbd/unsupported/ dbm/ dbm/sdbm/ dso/aix/ dso/beos/ dso/netware/ dso/os2/ dso/os390/ dso/unix/ dso/win32/ encoding/ file_io/netware/ file_io/os2/ ...

Author: ivan
Date: Sun Nov 20 07:14:38 2022
New Revision: 1905414

URL: http://svn.apache.org/viewvc?rev=1905414&view=rev
Log:
Remove trailing whitespaces in *.c.

Modified:
    apr/apr/trunk/atomic/netware/apr_atomic.c
    apr/apr/trunk/atomic/os390/atomic.c
    apr/apr/trunk/buckets/apr_brigade.c
    apr/apr/trunk/buckets/apr_buckets_eos.c
    apr/apr/trunk/buckets/apr_buckets_flush.c
    apr/apr/trunk/buckets/apr_buckets_heap.c
    apr/apr/trunk/buckets/apr_buckets_mmap.c
    apr/apr/trunk/buckets/apr_buckets_pipe.c
    apr/apr/trunk/buckets/apr_buckets_pool.c
    apr/apr/trunk/buckets/apr_buckets_simple.c
    apr/apr/trunk/buckets/apr_buckets_socket.c
    apr/apr/trunk/build/jlibtool.c
    apr/apr/trunk/crypto/apr_crypto_prng.c
    apr/apr/trunk/crypto/apr_md4.c
    apr/apr/trunk/crypto/apr_md5.c
    apr/apr/trunk/crypto/apr_passwd.c
    apr/apr/trunk/crypto/getuuid.c
    apr/apr/trunk/dbd/apr_dbd_mysql.c
    apr/apr/trunk/dbd/apr_dbd_odbc.c
    apr/apr/trunk/dbd/apr_dbd_oracle.c
    apr/apr/trunk/dbd/apr_dbd_pgsql.c
    apr/apr/trunk/dbd/apr_dbd_sqlite2.c
    apr/apr/trunk/dbd/apr_dbd_sqlite3.c
    apr/apr/trunk/dbd/unsupported/apr_dbd_freetds.c
    apr/apr/trunk/dbm/apr_dbm.c
    apr/apr/trunk/dbm/apr_dbm_berkeleydb.c
    apr/apr/trunk/dbm/sdbm/sdbm.c
    apr/apr/trunk/dbm/sdbm/sdbm_hash.c
    apr/apr/trunk/dbm/sdbm/sdbm_lock.c
    apr/apr/trunk/dbm/sdbm/sdbm_pair.c
    apr/apr/trunk/dso/aix/dso.c
    apr/apr/trunk/dso/beos/dso.c
    apr/apr/trunk/dso/netware/dso.c
    apr/apr/trunk/dso/os2/dso.c
    apr/apr/trunk/dso/os390/dso.c
    apr/apr/trunk/dso/unix/dso.c
    apr/apr/trunk/dso/win32/dso.c
    apr/apr/trunk/encoding/apr_base64.c
    apr/apr/trunk/encoding/apr_escape.c
    apr/apr/trunk/file_io/netware/filestat.c
    apr/apr/trunk/file_io/netware/filesys.c
    apr/apr/trunk/file_io/netware/flock.c
    apr/apr/trunk/file_io/netware/pipe.c
    apr/apr/trunk/file_io/os2/buffer.c
    apr/apr/trunk/file_io/os2/dir.c
    apr/apr/trunk/file_io/os2/dir_make_recurse.c
    apr/apr/trunk/file_io/os2/filedup.c
    apr/apr/trunk/file_io/os2/filestat.c
    apr/apr/trunk/file_io/os2/filesys.c
    apr/apr/trunk/file_io/os2/maperrorcode.c
    apr/apr/trunk/file_io/os2/open.c
    apr/apr/trunk/file_io/os2/pipe.c
    apr/apr/trunk/file_io/os2/readwrite.c
    apr/apr/trunk/file_io/unix/buffer.c
    apr/apr/trunk/file_io/unix/dir.c
    apr/apr/trunk/file_io/unix/fileacc.c
    apr/apr/trunk/file_io/unix/filedup.c
    apr/apr/trunk/file_io/unix/filestat.c
    apr/apr/trunk/file_io/unix/open.c
    apr/apr/trunk/file_io/unix/pipe.c
    apr/apr/trunk/file_io/unix/printf.c
    apr/apr/trunk/file_io/unix/readwrite.c
    apr/apr/trunk/file_io/unix/tempdir.c
    apr/apr/trunk/file_io/win32/buffer.c
    apr/apr/trunk/file_io/win32/dir.c
    apr/apr/trunk/file_io/win32/filedup.c
    apr/apr/trunk/file_io/win32/filepath.c
    apr/apr/trunk/file_io/win32/filestat.c
    apr/apr/trunk/file_io/win32/filesys.c
    apr/apr/trunk/file_io/win32/flock.c
    apr/apr/trunk/file_io/win32/open.c
    apr/apr/trunk/file_io/win32/readwrite.c
    apr/apr/trunk/file_io/win32/seek.c
    apr/apr/trunk/locks/beos/proc_mutex.c
    apr/apr/trunk/locks/beos/thread_cond.c
    apr/apr/trunk/locks/beos/thread_mutex.c
    apr/apr/trunk/locks/beos/thread_rwlock.c
    apr/apr/trunk/locks/netware/proc_mutex.c
    apr/apr/trunk/locks/netware/thread_cond.c
    apr/apr/trunk/locks/netware/thread_mutex.c
    apr/apr/trunk/locks/netware/thread_rwlock.c
    apr/apr/trunk/locks/os2/proc_mutex.c
    apr/apr/trunk/locks/unix/proc_mutex.c
    apr/apr/trunk/locks/unix/thread_cond.c
    apr/apr/trunk/locks/unix/thread_mutex.c
    apr/apr/trunk/locks/unix/thread_rwlock.c
    apr/apr/trunk/locks/win32/proc_mutex.c
    apr/apr/trunk/memcache/apr_memcache.c
    apr/apr/trunk/memory/unix/apr_pools.c
    apr/apr/trunk/misc/netware/libprews.c
    apr/apr/trunk/misc/netware/rand.c
    apr/apr/trunk/misc/netware/start.c
    apr/apr/trunk/misc/unix/errorcodes.c
    apr/apr/trunk/misc/unix/getopt.c
    apr/apr/trunk/misc/unix/otherchild.c
    apr/apr/trunk/misc/unix/rand.c
    apr/apr/trunk/misc/unix/start.c
    apr/apr/trunk/misc/win32/apr_app.c
    apr/apr/trunk/misc/win32/internal.c
    apr/apr/trunk/misc/win32/misc.c
    apr/apr/trunk/misc/win32/rand.c
    apr/apr/trunk/misc/win32/utf8.c
    apr/apr/trunk/mmap/unix/common.c
    apr/apr/trunk/mmap/unix/mmap.c
    apr/apr/trunk/mmap/win32/mmap.c
    apr/apr/trunk/network_io/beos/sendrecv.c
    apr/apr/trunk/network_io/os2/sendrecv.c
    apr/apr/trunk/network_io/os2/sendrecv_udp.c
    apr/apr/trunk/network_io/os2/sockets.c
    apr/apr/trunk/network_io/os2/sockopt.c
    apr/apr/trunk/network_io/unix/multicast.c
    apr/apr/trunk/network_io/unix/sendrecv.c
    apr/apr/trunk/network_io/unix/sockaddr.c
    apr/apr/trunk/network_io/unix/sockets.c
    apr/apr/trunk/network_io/unix/sockopt.c
    apr/apr/trunk/network_io/win32/sendrecv.c
    apr/apr/trunk/network_io/win32/sockets.c
    apr/apr/trunk/network_io/win32/sockopt.c
    apr/apr/trunk/passwd/apr_getpass.c
    apr/apr/trunk/poll/unix/epoll.c
    apr/apr/trunk/poll/unix/kqueue.c
    apr/apr/trunk/poll/unix/poll.c
    apr/apr/trunk/poll/unix/port.c
    apr/apr/trunk/poll/unix/select.c
    apr/apr/trunk/poll/unix/z_asio.c
    apr/apr/trunk/random/unix/apr_random.c
    apr/apr/trunk/random/unix/sha2.c
    apr/apr/trunk/shmem/beos/shm.c
    apr/apr/trunk/shmem/os2/shm.c
    apr/apr/trunk/shmem/unix/shm.c
    apr/apr/trunk/shmem/win32/shm.c
    apr/apr/trunk/strings/apr_cpystrn.c
    apr/apr/trunk/strings/apr_cstr.c
    apr/apr/trunk/strings/apr_fnmatch.c
    apr/apr/trunk/strings/apr_snprintf.c
    apr/apr/trunk/strings/apr_strings.c
    apr/apr/trunk/strings/apr_strnatcmp.c
    apr/apr/trunk/strings/apr_strtok.c
    apr/apr/trunk/tables/apr_hash.c
    apr/apr/trunk/tables/apr_skiplist.c
    apr/apr/trunk/tables/apr_tables.c
    apr/apr/trunk/test/abts.c
    apr/apr/trunk/test/echod.c
    apr/apr/trunk/test/globalmutexchild.c
    apr/apr/trunk/test/internal/testregex.c
    apr/apr/trunk/test/internal/testutf.c
    apr/apr/trunk/test/proc_child.c
    apr/apr/trunk/test/readchild.c
    apr/apr/trunk/test/sendfile.c
    apr/apr/trunk/test/sockchild.c
    apr/apr/trunk/test/sockperf.c
    apr/apr/trunk/test/testargs.c
    apr/apr/trunk/test/testbuckets.c
    apr/apr/trunk/test/testcond.c
    apr/apr/trunk/test/testdate.c
    apr/apr/trunk/test/testdir.c
    apr/apr/trunk/test/testdso.c
    apr/apr/trunk/test/testdup.c
    apr/apr/trunk/test/testfile.c
    apr/apr/trunk/test/testfilecopy.c
    apr/apr/trunk/test/testfileinfo.c
    apr/apr/trunk/test/testflock.c
    apr/apr/trunk/test/testfnmatch.c
    apr/apr/trunk/test/testglobalmutex.c
    apr/apr/trunk/test/testhash.c
    apr/apr/trunk/test/testhooks.c
    apr/apr/trunk/test/testipsub.c
    apr/apr/trunk/test/testlfs.c
    apr/apr/trunk/test/testlock.c
    apr/apr/trunk/test/testlockperf.c
    apr/apr/trunk/test/testmd4.c
    apr/apr/trunk/test/testmd5.c
    apr/apr/trunk/test/testmemcache.c
    apr/apr/trunk/test/testmmap.c
    apr/apr/trunk/test/testmutexscope.c
    apr/apr/trunk/test/testnames.c
    apr/apr/trunk/test/testoc.c
    apr/apr/trunk/test/testpass.c
    apr/apr/trunk/test/testpipe.c
    apr/apr/trunk/test/testpoll.c
    apr/apr/trunk/test/testpools.c
    apr/apr/trunk/test/testproc.c
    apr/apr/trunk/test/testprocmutex.c
    apr/apr/trunk/test/testredis.c
    apr/apr/trunk/test/testshm.c
    apr/apr/trunk/test/testshmconsumer.c
    apr/apr/trunk/test/testshmproducer.c
    apr/apr/trunk/test/testskiplist.c
    apr/apr/trunk/test/testsock.c
    apr/apr/trunk/test/testsockets.c
    apr/apr/trunk/test/testsockopt.c
    apr/apr/trunk/test/teststr.c
    apr/apr/trunk/test/teststrmatch.c
    apr/apr/trunk/test/testtable.c
    apr/apr/trunk/test/testtemp.c
    apr/apr/trunk/test/testthread.c
    apr/apr/trunk/test/testuri.c
    apr/apr/trunk/test/testuser.c
    apr/apr/trunk/test/testutil.c
    apr/apr/trunk/test/testxml.c
    apr/apr/trunk/test/tryread.c
    apr/apr/trunk/threadproc/beos/apr_proc_stub.c
    apr/apr/trunk/threadproc/beos/proc.c
    apr/apr/trunk/threadproc/beos/thread.c
    apr/apr/trunk/threadproc/beos/threadpriv.c
    apr/apr/trunk/threadproc/beos/threadproc_common.c
    apr/apr/trunk/threadproc/netware/proc.c
    apr/apr/trunk/threadproc/netware/thread.c
    apr/apr/trunk/threadproc/netware/threadpriv.c
    apr/apr/trunk/threadproc/os2/proc.c
    apr/apr/trunk/threadproc/os2/thread.c
    apr/apr/trunk/threadproc/os2/threadpriv.c
    apr/apr/trunk/threadproc/unix/proc.c
    apr/apr/trunk/threadproc/unix/signals.c
    apr/apr/trunk/threadproc/unix/thread.c
    apr/apr/trunk/threadproc/win32/proc.c
    apr/apr/trunk/threadproc/win32/signals.c
    apr/apr/trunk/threadproc/win32/thread.c
    apr/apr/trunk/threadproc/win32/threadpriv.c
    apr/apr/trunk/time/unix/time.c
    apr/apr/trunk/time/unix/timestr.c
    apr/apr/trunk/time/win32/time.c
    apr/apr/trunk/time/win32/timestr.c
    apr/apr/trunk/uri/apr_uri.c
    apr/apr/trunk/user/netware/groupinfo.c
    apr/apr/trunk/user/unix/groupinfo.c
    apr/apr/trunk/user/unix/userinfo.c
    apr/apr/trunk/user/win32/groupinfo.c
    apr/apr/trunk/user/win32/userinfo.c
    apr/apr/trunk/util-misc/apr_date.c
    apr/apr/trunk/util-misc/apr_queue.c
    apr/apr/trunk/util-misc/apr_reslist.c
    apr/apr/trunk/util-misc/apr_rmm.c
    apr/apr/trunk/util-misc/apr_thread_pool.c
    apr/apr/trunk/xlate/xlate.c

Modified: apr/apr/trunk/atomic/netware/apr_atomic.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/atomic/netware/apr_atomic.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/atomic/netware/apr_atomic.c (original)
+++ apr/apr/trunk/atomic/netware/apr_atomic.c Sun Nov 20 07:14:38 2022
@@ -62,7 +62,7 @@ APR_DECLARE(apr_uint32_t) apr_atomic_xch
     return atomic_xchg((unsigned long *)mem,(unsigned long)val);
 }
 
-APR_DECLARE(int) apr_atomic_dec32(volatile apr_uint32_t *mem) 
+APR_DECLARE(int) apr_atomic_dec32(volatile apr_uint32_t *mem)
 {
     return (atomic_xchgadd((unsigned long *)mem, 0xFFFFFFFF) - 1);
 }

Modified: apr/apr/trunk/atomic/os390/atomic.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/atomic/os390/atomic.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/atomic/os390/atomic.c (original)
+++ apr/apr/trunk/atomic/os390/atomic.c Sun Nov 20 07:14:38 2022
@@ -29,7 +29,7 @@ apr_status_t apr_atomic_init(apr_pool_t
 
 apr_uint32_t apr_atomic_add32(volatile apr_uint32_t *mem, apr_uint32_t val)
 {
-    apr_uint32_t old, new_val; 
+    apr_uint32_t old, new_val;
 
     old = *mem;   /* old is automatically updated on cs failure */
     do {
@@ -55,12 +55,12 @@ apr_uint32_t apr_atomic_inc32(volatile a
 
 int apr_atomic_dec32(volatile apr_uint32_t *mem)
 {
-    apr_uint32_t old, new_val; 
+    apr_uint32_t old, new_val;
 
     old = *mem;   /* old is automatically updated on cs failure */
     do {
         new_val = old - 1;
-    } while (__cs(&old, (cs_t *)mem, new_val)); 
+    } while (__cs(&old, (cs_t *)mem, new_val));
 
     return new_val != 0;
 }
@@ -75,11 +75,11 @@ void apr_atomic_set32(volatile apr_uint3
     *mem = val;
 }
 
-apr_uint32_t apr_atomic_cas32(volatile apr_uint32_t *mem, apr_uint32_t swap, 
+apr_uint32_t apr_atomic_cas32(volatile apr_uint32_t *mem, apr_uint32_t swap,
                               apr_uint32_t cmp)
 {
     apr_uint32_t old = cmp;
-    
+
     __cs(&old, (cs_t *)mem, swap);
     return old; /* old is automatically updated from mem on cs failure */
 }
@@ -101,7 +101,7 @@ void *apr_atomic_casptr(void *volatile *
 {
      __csg(&cmp_ptr,     /* automatically updated from mem on __csg failure  */
            mem_ptr,      /* set from swap when __csg succeeds                */
-           &swap_ptr);  
+           &swap_ptr);
      return (void *)cmp_ptr;
 }
 #else
@@ -110,12 +110,12 @@ void *apr_atomic_casptr(void *volatile *
 
 apr_uint32_t apr_atomic_xchg32(volatile apr_uint32_t *mem, apr_uint32_t val)
 {
-    apr_uint32_t old, new_val; 
+    apr_uint32_t old, new_val;
 
     old = *mem;   /* old is automatically updated on cs failure */
     do {
         new_val = val;
-    } while (__cs(&old, (cs_t *)mem, new_val)); 
+    } while (__cs(&old, (cs_t *)mem, new_val));
 
     return old;
 }
@@ -127,10 +127,10 @@ APR_DECLARE(void*) apr_atomic_xchgptr(vo
     old_ptr = *mem_ptr; /* old is automatically updated on cs failure */
 #if APR_SIZEOF_VOIDP == 4
     do {
-    } while (__cs1(&old_ptr, mem_ptr, &new_ptr)); 
+    } while (__cs1(&old_ptr, mem_ptr, &new_ptr));
 #elif APR_SIZEOF_VOIDP == 8
-    do { 
-    } while (__csg(&old_ptr, mem_ptr, &new_ptr)); 
+    do {
+    } while (__csg(&old_ptr, mem_ptr, &new_ptr));
 #else
 #error APR_SIZEOF_VOIDP value not supported
 #endif /* APR_SIZEOF_VOIDP */

Modified: apr/apr/trunk/buckets/apr_brigade.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_brigade.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_brigade.c (original)
+++ apr/apr/trunk/buckets/apr_brigade.c Sun Nov 20 07:14:38 2022
@@ -29,7 +29,7 @@
 #include <sys/uio.h>
 #endif
 
-static apr_status_t brigade_cleanup(void *data) 
+static apr_status_t brigade_cleanup(void *data)
 {
     return apr_brigade_cleanup(data);
 }
@@ -57,7 +57,7 @@ APR_DECLARE(apr_status_t) apr_brigade_cl
         apr_bucket_delete(e);
     }
 #endif
-    
+
     /* We don't need to free(bb) because it's allocated from a pool. */
     return APR_SUCCESS;
 }
@@ -68,7 +68,7 @@ APR_DECLARE(apr_status_t) apr_brigade_de
     return apr_pool_cleanup_run(b->p, b, brigade_cleanup);
 #else
     apr_status_t rv;
-    
+
     APR_BRIGADE_CHECK_CONSISTENCY(b);
 
     rv = apr_pool_cleanup_run(b->p, b, brigade_cleanup);
@@ -109,8 +109,8 @@ APR_DECLARE(apr_bucket_brigade *) apr_br
     else if (!APR_BRIGADE_EMPTY(a)) {
         apr_brigade_cleanup(a);
     }
-    /* Return an empty brigade if there is nothing left in 
-     * the first brigade to split off 
+    /* Return an empty brigade if there is nothing left in
+     * the first brigade to split off
      */
     if (e != APR_BRIGADE_SENTINEL(b)) {
         f = APR_RING_LAST(&b->list);
@@ -183,7 +183,7 @@ APR_DECLARE(apr_status_t) apr_brigade_pa
              * and is within this bucket, or this bucket's len
              * is undefined, so now we are ready to split it.
              * First try to split the bucket natively... */
-            if ((rv = apr_bucket_split(e, (apr_size_t)point64)) 
+            if ((rv = apr_bucket_split(e, (apr_size_t)point64))
                     != APR_ENOTIMPL) {
                 *after_point = APR_BUCKET_NEXT(e);
                 return rv;
@@ -212,7 +212,7 @@ APR_DECLARE(apr_status_t) apr_brigade_pa
         }
         point64 -= (apr_uint64_t)e->length;
     }
-    *after_point = APR_BRIGADE_SENTINEL(b); 
+    *after_point = APR_BRIGADE_SENTINEL(b);
     return APR_INCOMPLETE;
 }
 
@@ -254,7 +254,7 @@ APR_DECLARE(apr_status_t) apr_brigade_fl
 {
     apr_size_t actual = 0;
     apr_bucket *b;
- 
+
     for (b = APR_BRIGADE_FIRST(bb);
          b != APR_BRIGADE_SENTINEL(bb);
          b = APR_BUCKET_NEXT(b))
@@ -304,14 +304,14 @@ APR_DECLARE(apr_status_t) apr_brigade_pf
     apr_status_t rv;
 
     apr_brigade_length(bb, 1, &actual);
-    
+
     /* XXX: This is dangerous beyond belief.  At least in the
      * apr_brigade_flatten case, the user explicitly stated their
      * buffer length - so we don't up and palloc 4GB for a single
      * file bucket.  This API must grow a useful max boundry,
      * either compiled-in or preset via the *len value.
      *
-     * Shouldn't both fn's grow an additional return value for 
+     * Shouldn't both fn's grow an additional return value for
      * the case that the brigade couldn't be flattened into the
      * provided or allocated buffer (such as APR_EMOREDATA?)
      * Not a failure, simply an advisory result.
@@ -319,7 +319,7 @@ APR_DECLARE(apr_status_t) apr_brigade_pf
     total = (apr_size_t)actual;
 
     *c = apr_palloc(pool, total);
-    
+
     rv = apr_brigade_flatten(bb, *c, &total);
 
     if (rv != APR_SUCCESS) {
@@ -687,7 +687,7 @@ skip:
 }
 
 
-APR_DECLARE(apr_status_t) apr_brigade_to_iovec(apr_bucket_brigade *b, 
+APR_DECLARE(apr_status_t) apr_brigade_to_iovec(apr_bucket_brigade *b,
                                                struct iovec *vec, int *nvec)
 {
     int left = *nvec;
@@ -719,7 +719,7 @@ APR_DECLARE(apr_status_t) apr_brigade_to
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_brigade_vputstrs(apr_bucket_brigade *b, 
+APR_DECLARE(apr_status_t) apr_brigade_vputstrs(apr_bucket_brigade *b,
                                                apr_brigade_flush flush,
                                                void *ctx,
                                                va_list va)
@@ -761,7 +761,7 @@ APR_DECLARE(apr_status_t) apr_brigade_pu
 
 APR_DECLARE(apr_status_t) apr_brigade_write(apr_bucket_brigade *b,
                                             apr_brigade_flush flush,
-                                            void *ctx, 
+                                            void *ctx,
                                             const char *str, apr_size_t nbyte)
 {
     apr_bucket *e = APR_BRIGADE_LAST(b);
@@ -782,7 +782,7 @@ APR_DECLARE(apr_status_t) apr_brigade_wr
     }
 
     if (nbyte > remaining) {
-        /* either a buffer bucket exists but is full, 
+        /* either a buffer bucket exists but is full,
          * or no buffer bucket exists and the data is too big
          * to buffer.  In either case, we should flush.  */
         if (flush) {
@@ -946,7 +946,7 @@ APR_DECLARE(apr_status_t) apr_brigade_pu
     return apr_brigade_write(bb, flush, ctx, str, strlen(str));
 }
 
-APR_DECLARE_NONSTD(apr_status_t) apr_brigade_putstrs(apr_bucket_brigade *b, 
+APR_DECLARE_NONSTD(apr_status_t) apr_brigade_putstrs(apr_bucket_brigade *b,
                                                      apr_brigade_flush flush,
                                                      void *ctx, ...)
 {
@@ -959,9 +959,9 @@ APR_DECLARE_NONSTD(apr_status_t) apr_bri
     return rv;
 }
 
-APR_DECLARE_NONSTD(apr_status_t) apr_brigade_printf(apr_bucket_brigade *b, 
+APR_DECLARE_NONSTD(apr_status_t) apr_brigade_printf(apr_bucket_brigade *b,
                                                     apr_brigade_flush flush,
-                                                    void *ctx, 
+                                                    void *ctx,
                                                     const char *fmt, ...)
 {
     va_list ap;
@@ -1046,12 +1046,12 @@ APR_DECLARE(apr_bucket *) apr_brigade_in
     apr_bucket *e;
 
     if (sizeof(apr_off_t) == sizeof(apr_size_t) || length < MAX_BUCKET_SIZE) {
-        e = apr_bucket_file_create(f, start, (apr_size_t)length, p, 
+        e = apr_bucket_file_create(f, start, (apr_size_t)length, p,
                                    bb->bucket_alloc);
     }
     else {
-        /* Several buckets are needed. */        
-        e = apr_bucket_file_create(f, start, MAX_BUCKET_SIZE, p, 
+        /* Several buckets are needed. */
+        e = apr_bucket_file_create(f, start, MAX_BUCKET_SIZE, p,
                                    bb->bucket_alloc);
 
         while (length > MAX_BUCKET_SIZE) {
@@ -1063,7 +1063,7 @@ APR_DECLARE(apr_bucket *) apr_brigade_in
         }
         e->length = (apr_size_t)length; /* Resize just the last bucket */
     }
-    
+
     APR_BRIGADE_INSERT_TAIL(bb, e);
     return e;
 }

Modified: apr/apr/trunk/buckets/apr_buckets_eos.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_eos.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_eos.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_eos.c Sun Nov 20 07:14:38 2022
@@ -16,7 +16,7 @@
 
 #include "apr_buckets.h"
 
-static apr_status_t eos_bucket_read(apr_bucket *b, const char **str, 
+static apr_status_t eos_bucket_read(apr_bucket *b, const char **str,
                                     apr_size_t *len, apr_read_type_e block)
 {
     *str = NULL;
@@ -30,7 +30,7 @@ APR_DECLARE(apr_bucket *) apr_bucket_eos
     b->start       = 0;
     b->data        = NULL;
     b->type        = &apr_bucket_type_eos;
-    
+
     return b;
 }
 

Modified: apr/apr/trunk/buckets/apr_buckets_flush.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_flush.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_flush.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_flush.c Sun Nov 20 07:14:38 2022
@@ -16,7 +16,7 @@
 
 #include "apr_buckets.h"
 
-static apr_status_t flush_bucket_read(apr_bucket *b, const char **str, 
+static apr_status_t flush_bucket_read(apr_bucket *b, const char **str,
                                       apr_size_t *len, apr_read_type_e block)
 {
     *str = NULL;
@@ -30,7 +30,7 @@ APR_DECLARE(apr_bucket *) apr_bucket_flu
     b->start       = 0;
     b->data        = NULL;
     b->type        = &apr_bucket_type_flush;
-    
+
     return b;
 }
 
@@ -45,7 +45,7 @@ APR_DECLARE(apr_bucket *) apr_bucket_flu
 }
 
 APR_DECLARE_DATA const apr_bucket_type_t apr_bucket_type_flush = {
-    "FLUSH", 5, APR_BUCKET_METADATA, 
+    "FLUSH", 5, APR_BUCKET_METADATA,
     apr_bucket_destroy_noop,
     flush_bucket_read,
     apr_bucket_setaside_noop,

Modified: apr/apr/trunk/buckets/apr_buckets_heap.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_heap.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_heap.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_heap.c Sun Nov 20 07:14:38 2022
@@ -18,7 +18,7 @@
 #define APR_WANT_MEMFUNC
 #include "apr_want.h"
 
-static apr_status_t heap_bucket_read(apr_bucket *b, const char **str, 
+static apr_status_t heap_bucket_read(apr_bucket *b, const char **str,
                                      apr_size_t *len, apr_read_type_e block)
 {
     apr_bucket_heap *h = b->data;

Modified: apr/apr/trunk/buckets/apr_buckets_mmap.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_mmap.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_mmap.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_mmap.c Sun Nov 20 07:14:38 2022
@@ -18,13 +18,13 @@
 
 #if APR_HAS_MMAP
 
-static apr_status_t mmap_bucket_read(apr_bucket *b, const char **str, 
+static apr_status_t mmap_bucket_read(apr_bucket *b, const char **str,
                                      apr_size_t *length, apr_read_type_e block)
 {
     apr_bucket_mmap *m = b->data;
     apr_status_t ok;
     void *addr;
-   
+
     if (!m->mmap) {
         /* the apr_mmap_t was already cleaned up out from under us */
         return APR_EINVAL;
@@ -68,8 +68,8 @@ static void mmap_bucket_destroy(void *da
 /*
  * XXX: are the start and length arguments useful?
  */
-APR_DECLARE(apr_bucket *) apr_bucket_mmap_make(apr_bucket *b, apr_mmap_t *mm, 
-                                               apr_off_t start, 
+APR_DECLARE(apr_bucket *) apr_bucket_mmap_make(apr_bucket *b, apr_mmap_t *mm,
+                                               apr_off_t start,
                                                apr_size_t length)
 {
     apr_bucket_mmap *m;
@@ -87,8 +87,8 @@ APR_DECLARE(apr_bucket *) apr_bucket_mma
 }
 
 
-APR_DECLARE(apr_bucket *) apr_bucket_mmap_create(apr_mmap_t *mm, 
-                                                 apr_off_t start, 
+APR_DECLARE(apr_bucket *) apr_bucket_mmap_create(apr_mmap_t *mm,
+                                                 apr_off_t start,
                                                  apr_size_t length,
                                                  apr_bucket_alloc_t *list)
 {

Modified: apr/apr/trunk/buckets/apr_buckets_pipe.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_pipe.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_pipe.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_pipe.c Sun Nov 20 07:14:38 2022
@@ -46,7 +46,7 @@ static apr_status_t pipe_bucket_read(apr
     /*
      * If there's more to read we have to keep the rest of the pipe
      * for later.  Otherwise, we'll close the pipe.
-     * XXX: Note that more complicated bucket types that 
+     * XXX: Note that more complicated bucket types that
      * refer to data not in memory and must therefore have a read()
      * function similar to this one should be wary of copying this
      * code because if they have a destroy function they probably
@@ -94,7 +94,7 @@ APR_DECLARE(apr_bucket *) apr_bucket_pip
     b->length      = (apr_size_t)(-1);
     b->start       = -1;
     b->data        = p;
-    
+
     return b;
 }
 
@@ -110,7 +110,7 @@ APR_DECLARE(apr_bucket *) apr_bucket_pip
 }
 
 APR_DECLARE_DATA const apr_bucket_type_t apr_bucket_type_pipe = {
-    "PIPE", 5, APR_BUCKET_DATA, 
+    "PIPE", 5, APR_BUCKET_DATA,
     apr_bucket_destroy_noop,
     pipe_bucket_read,
     apr_bucket_setaside_notimpl,

Modified: apr/apr/trunk/buckets/apr_buckets_pool.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_pool.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_pool.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_pool.c Sun Nov 20 07:14:38 2022
@@ -42,7 +42,7 @@ static apr_status_t pool_bucket_cleanup(
     return APR_SUCCESS;
 }
 
-static apr_status_t pool_bucket_read(apr_bucket *b, const char **str, 
+static apr_status_t pool_bucket_read(apr_bucket *b, const char **str,
                                      apr_size_t *len, apr_read_type_e block)
 {
     apr_bucket_pool *p = b->data;

Modified: apr/apr/trunk/buckets/apr_buckets_simple.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_simple.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_simple.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_simple.c Sun Nov 20 07:14:38 2022
@@ -45,7 +45,7 @@ APR_DECLARE_NONSTD(apr_status_t) apr_buc
     return APR_SUCCESS;
 }
 
-static apr_status_t simple_bucket_read(apr_bucket *b, const char **str, 
+static apr_status_t simple_bucket_read(apr_bucket *b, const char **str,
                                        apr_size_t *len, apr_read_type_e block)
 {
     *str = (char *)b->data + b->start;
@@ -129,7 +129,7 @@ const apr_bucket_type_t apr_bucket_type_
 
 APR_DECLARE_DATA const apr_bucket_type_t apr_bucket_type_transient = {
     "TRANSIENT", 5, APR_BUCKET_DATA,
-    apr_bucket_destroy_noop, 
+    apr_bucket_destroy_noop,
     simple_bucket_read,
     transient_bucket_setaside,
     apr_bucket_simple_split,

Modified: apr/apr/trunk/buckets/apr_buckets_socket.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/buckets/apr_buckets_socket.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/buckets/apr_buckets_socket.c (original)
+++ apr/apr/trunk/buckets/apr_buckets_socket.c Sun Nov 20 07:14:38 2022
@@ -55,7 +55,7 @@ static apr_status_t socket_bucket_read(a
      * new bucket.
      *
      * Even if there is nothing more to read, don't close the socket here
-     * as we have to use it to send any response :)  We could shut it 
+     * as we have to use it to send any response :)  We could shut it
      * down for reading, but there is no benefit to doing so.
      */
     if (*len > 0) {
@@ -83,7 +83,7 @@ APR_DECLARE(apr_bucket *) apr_bucket_soc
      * destroy it instead.
      *
      * Note that typically the socket is allocated from the connection pool
-     * so it will disappear when the connection is finished. 
+     * so it will disappear when the connection is finished.
      */
     b->type        = &apr_bucket_type_socket;
     b->length      = (apr_size_t)(-1);
@@ -108,7 +108,7 @@ APR_DECLARE_DATA const apr_bucket_type_t
     "SOCKET", 5, APR_BUCKET_DATA,
     apr_bucket_destroy_noop,
     socket_bucket_read,
-    apr_bucket_setaside_notimpl, 
+    apr_bucket_setaside_notimpl,
     apr_bucket_split_notimpl,
     apr_bucket_copy_notimpl
 };

Modified: apr/apr/trunk/build/jlibtool.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/build/jlibtool.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/build/jlibtool.c (original)
+++ apr/apr/trunk/build/jlibtool.c Sun Nov 20 07:14:38 2022
@@ -223,7 +223,7 @@ enum lib_type {
 
 typedef struct {
     const char **vals;
-    int num; 
+    int num;
 } count_chars;
 
 typedef struct {
@@ -312,7 +312,7 @@ static int snprintf( char *str, size_t n
 {
         va_list ap;
         int res;
- 
+
         va_start( ap, fmt );
         res = vsnprintf( str, n, fmt, ap );
         va_end( ap );
@@ -680,7 +680,7 @@ long safe_strtol(const char *nptr, const
         return 0;
     }
 
-    return rv; 
+    return rv;
 }
 
 void safe_mkdir(const char *path)
@@ -867,7 +867,7 @@ char *check_object_exists(command_t *cmd
 */
         default:
             break;
-        } 
+        }
 
         if (!cmd->options.silent) {
             printf("Checking (obj): %s\n", newarg);
@@ -939,7 +939,7 @@ char *check_library_exists(command_t *cm
         default:
             *libtype = type_UNKNOWN;
             break;
-        } 
+        }
 
         if (!cmd->options.silent) {
             printf("Checking (lib): %s\n", newarg);
@@ -1932,7 +1932,7 @@ int run_mode(command_t *cmd_data)
         break;
     default:
         break;
-    } 
+    }
 
     return 0;
 }
@@ -2048,7 +2048,7 @@ int main(int argc, char *argv[])
     rc = run_mode(&cmd_data);
 
     if (!rc) {
-       add_for_runtime(&cmd_data); 
+       add_for_runtime(&cmd_data);
     }
 
     cleanup_tmp_dirs(&cmd_data);

Modified: apr/apr/trunk/crypto/apr_crypto_prng.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/crypto/apr_crypto_prng.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/crypto/apr_crypto_prng.c (original)
+++ apr/apr/trunk/crypto/apr_crypto_prng.c Sun Nov 20 07:14:38 2022
@@ -472,7 +472,7 @@ APR_DECLARE(apr_status_t) apr_crypto_prn
         /* Use the system entropy, i.e. one of "/dev/[u]random", getrandom(),
          * arc4random()... This may block but still we really want to wait for
          * the system to gather enough entropy for these 32 initial bytes, much
-         * more than we want non-random bytes, and that's once and for all! 
+         * more than we want non-random bytes, and that's once and for all!
          */
         rv = apr_generate_random_bytes(cprng->key, CPRNG_KEY_SIZE);
     }

Modified: apr/apr/trunk/crypto/apr_md4.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/crypto/apr_md4.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/crypto/apr_md4.c (original)
+++ apr/apr/trunk/crypto/apr_md4.c Sun Nov 20 07:14:38 2022
@@ -51,7 +51,7 @@
 
 /* Constants for MD4Transform routine.
  */
- 
+
 #define S11 3
 #define S12 7
 #define S13 11
@@ -64,7 +64,7 @@
 #define S32 9
 #define S33 11
 #define S34 15
- 
+
 static void MD4Transform(apr_uint32_t state[4], const unsigned char block[64]);
 static void Encode(unsigned char *output, const apr_uint32_t *input,
                    unsigned int len);
@@ -119,7 +119,7 @@ APR_DECLARE(apr_status_t) apr_md4_init(a
     context->state[1] = 0xefcdab89;
     context->state[2] = 0x98badcfe;
     context->state[3] = 0x10325476;
-    
+
 #if APR_HAS_XLATE
     context->xlate = NULL;
 #endif
@@ -132,7 +132,7 @@ APR_DECLARE(apr_status_t) apr_md4_init(a
  * to be used for translating the content before calculating the
  * digest.
  */
-APR_DECLARE(apr_status_t) apr_md4_set_xlate(apr_md4_ctx_t *context, 
+APR_DECLARE(apr_status_t) apr_md4_set_xlate(apr_md4_ctx_t *context,
                                             apr_xlate_t *xlate)
 {
     apr_status_t rv;
@@ -169,7 +169,7 @@ APR_DECLARE(apr_status_t) apr_md4_update
     idx = (unsigned int)((context->count[0] >> 3) & 0x3F);
 
     /* Update number of bits */
-    if ((context->count[0] += ((apr_uint32_t)inputLen << 3)) 
+    if ((context->count[0] += ((apr_uint32_t)inputLen << 3))
             < ((apr_uint32_t)inputLen << 3))
         context->count[1]++;
     context->count[1] += (apr_uint32_t)inputLen >> 29;
@@ -196,9 +196,9 @@ APR_DECLARE(apr_status_t) apr_md4_update
     if (inputLen >= partLen) {
         if (context->xlate) {
             inbytes_left = outbytes_left = partLen;
-            apr_xlate_conv_buffer(context->xlate, (const char *)input, 
-                                  &inbytes_left, 
-                                  (char *)&context->buffer[idx], 
+            apr_xlate_conv_buffer(context->xlate, (const char *)input,
+                                  &inbytes_left,
+                                  (char *)&context->buffer[idx],
                                   &outbytes_left);
         }
         else {
@@ -210,7 +210,7 @@ APR_DECLARE(apr_status_t) apr_md4_update
             if (context->xlate) {
                 unsigned char inp_tmp[64];
                 inbytes_left = outbytes_left = 64;
-                apr_xlate_conv_buffer(context->xlate, (const char *)&input[i], 
+                apr_xlate_conv_buffer(context->xlate, (const char *)&input[i],
                                       &inbytes_left,
                                       (char *)inp_tmp, &outbytes_left);
                 MD4Transform(context->state, inp_tmp);
@@ -228,8 +228,8 @@ APR_DECLARE(apr_status_t) apr_md4_update
     /* Buffer remaining input */
     if (context->xlate) {
         inbytes_left = outbytes_left = inputLen - i;
-        apr_xlate_conv_buffer(context->xlate, (const char *)&input[i], 
-                              &inbytes_left, (char *)&context->buffer[idx], 
+        apr_xlate_conv_buffer(context->xlate, (const char *)&input[i],
+                              &inbytes_left, (char *)&context->buffer[idx],
                               &outbytes_left);
     }
     else {
@@ -270,7 +270,7 @@ APR_DECLARE(apr_status_t) apr_md4_final(
 
     /* Zeroize sensitive information. */
     memset(context, 0, sizeof(*context));
-    
+
     return APR_SUCCESS;
 }
 
@@ -357,7 +357,7 @@ static void MD4Transform(apr_uint32_t st
     state[1] += b;
     state[2] += c;
     state[3] += d;
-    
+
     /* Zeroize sensitive information. */
     apr_memzero_explicit(x, sizeof(x));
 }

Modified: apr/apr/trunk/crypto/apr_md5.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/crypto/apr_md5.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/crypto/apr_md5.c (original)
+++ apr/apr/trunk/crypto/apr_md5.c Sun Nov 20 07:14:38 2022
@@ -145,14 +145,14 @@ static apr_xlate_t *xlate_ebcdic_to_asci
 APR_DECLARE(apr_status_t) apr_md5_init(apr_md5_ctx_t *context)
 {
     context->count[0] = context->count[1] = 0;
-    
+
     /* Load magic initialization constants. */
     context->state[0] = 0x67452301;
     context->state[1] = 0xefcdab89;
     context->state[2] = 0x98badcfe;
     context->state[3] = 0x10325476;
     context->xlate = NULL;
-    
+
     return APR_SUCCESS;
 }
 
@@ -160,7 +160,7 @@ APR_DECLARE(apr_status_t) apr_md5_init(a
  * to be used for translating the content before calculating the
  * digest.
  */
-APR_DECLARE(apr_status_t) apr_md5_set_xlate(apr_md5_ctx_t *context, 
+APR_DECLARE(apr_status_t) apr_md5_set_xlate(apr_md5_ctx_t *context,
                                             apr_xlate_t *xlate)
 {
 #if APR_HAS_XLATE
@@ -202,7 +202,7 @@ static apr_status_t md5_update_buffer(ap
     idx = (unsigned int)((context->count[0] >> 3) & 0x3F);
 
     /* Update number of bits */
-    if ((context->count[0] += ((apr_uint32_t)inputLen << 3)) 
+    if ((context->count[0] += ((apr_uint32_t)inputLen << 3))
             < ((apr_uint32_t)inputLen << 3))
         context->count[1]++;
     context->count[1] += (apr_uint32_t)inputLen >> 29;
@@ -229,9 +229,9 @@ static apr_status_t md5_update_buffer(ap
     if (inputLen >= partLen) {
         if (context->xlate && (xlate_buffer == DO_XLATE)) {
             inbytes_left = outbytes_left = partLen;
-            apr_xlate_conv_buffer(context->xlate, (const char *)input, 
+            apr_xlate_conv_buffer(context->xlate, (const char *)input,
                                   &inbytes_left,
-                                  (char *)&context->buffer[idx], 
+                                  (char *)&context->buffer[idx],
                                   &outbytes_left);
         }
         else {
@@ -243,8 +243,8 @@ static apr_status_t md5_update_buffer(ap
             if (context->xlate && (xlate_buffer == DO_XLATE)) {
                 unsigned char inp_tmp[64];
                 inbytes_left = outbytes_left = 64;
-                apr_xlate_conv_buffer(context->xlate, (const char *)&input[i], 
-                                      &inbytes_left, (char *)inp_tmp, 
+                apr_xlate_conv_buffer(context->xlate, (const char *)&input[i],
+                                      &inbytes_left, (char *)inp_tmp,
                                       &outbytes_left);
                 MD5Transform(context->state, inp_tmp);
             }
@@ -261,8 +261,8 @@ static apr_status_t md5_update_buffer(ap
     /* Buffer remaining input */
     if (context->xlate && (xlate_buffer == DO_XLATE)) {
         inbytes_left = outbytes_left = inputLen - i;
-        apr_xlate_conv_buffer(context->xlate, (const char *)&input[i], 
-                              &inbytes_left, (char *)&context->buffer[idx], 
+        apr_xlate_conv_buffer(context->xlate, (const char *)&input[i],
+                              &inbytes_left, (char *)&context->buffer[idx],
                               &outbytes_left);
     }
     else {
@@ -272,9 +272,9 @@ static apr_status_t md5_update_buffer(ap
     return APR_SUCCESS;
 }
 
-/* MD5 block update operation. API with the default setting 
+/* MD5 block update operation. API with the default setting
  * for EBCDIC translations
- */  
+ */
 APR_DECLARE(apr_status_t) apr_md5_update(apr_md5_ctx_t *context,
                                          const void *input,
                                          apr_size_t inputLen)
@@ -312,7 +312,7 @@ APR_DECLARE(apr_status_t) apr_md5_final(
 
     /* Zeroize sensitive information. */
     memset(context, 0, sizeof(*context));
-    
+
     return APR_SUCCESS;
 }
 
@@ -517,7 +517,7 @@ APR_DECLARE(apr_status_t) apr_md5_encode
     apr_md5_ctx_t ctx, ctx1;
     unsigned long l;
 
-    /* 
+    /*
      * Refine the salt first.  It's possible we were given an already-hashed
      * string as the salt argument, so extract the actual salt value from it
      * if so.  Otherwise just use the string up to the first '$' as the salt.
@@ -550,7 +550,7 @@ APR_DECLARE(apr_status_t) apr_md5_encode
 #if APR_CHARSET_EBCDIC
     apr_md5_set_xlate(&ctx, xlate_ebcdic_to_ascii);
 #endif
-    
+
     /*
      * The password first, since that is what is most unknown
      */

Modified: apr/apr/trunk/crypto/apr_passwd.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/crypto/apr_passwd.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/crypto/apr_passwd.c (original)
+++ apr/apr/trunk/crypto/apr_passwd.c Sun Nov 20 07:14:38 2022
@@ -105,7 +105,7 @@ static void crypt_mutex_unlock()
  * they match, or APR_EMISMATCH if they don't.  If the platform doesn't
  * support crypt, then the default check is against a clear text string.
  */
-APR_DECLARE(apr_status_t) apr_password_validate(const char *passwd, 
+APR_DECLARE(apr_status_t) apr_password_validate(const char *passwd,
                                                 const char *hash)
 {
     char sample[200];

Modified: apr/apr/trunk/crypto/getuuid.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/crypto/getuuid.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/crypto/getuuid.c (original)
+++ apr/apr/trunk/crypto/getuuid.c Sun Nov 20 07:14:38 2022
@@ -152,7 +152,7 @@ static void get_current_time(apr_uint64_
     static apr_uint64_t fudge = 0;
 
     get_system_time(&time_now);
-        
+
     /* if clock reading changed since last UUID generated... */
     if (time_last != time_now) {
         /* The clock reading has changed since the last UUID was generated.

Modified: apr/apr/trunk/dbd/apr_dbd_mysql.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/apr_dbd_mysql.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/apr_dbd_mysql.c (original)
+++ apr/apr/trunk/dbd/apr_dbd_mysql.c Sun Nov 20 07:14:38 2022
@@ -33,7 +33,7 @@
 #include <mysql/mysql.h>
 #include <mysql/errmsg.h>
 #else /* !defined(HAVE_MYSQL_MYSQL_H) */
-#if defined(HAVE_MY_GLOBAL_H) 
+#if defined(HAVE_MY_GLOBAL_H)
 #include <my_global.h>
 #if defined(HAVE_MY_SYS_H)
 #include <my_sys.h>

Modified: apr/apr/trunk/dbd/apr_dbd_odbc.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/apr_dbd_odbc.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/apr_dbd_odbc.c (original)
+++ apr/apr/trunk/dbd/apr_dbd_odbc.c Sun Nov 20 07:14:38 2022
@@ -30,7 +30,7 @@
 
 #include <stdlib.h>
 
-/* If library is ODBC-V2, use macros for limited ODBC-V2 support 
+/* If library is ODBC-V2, use macros for limited ODBC-V2 support
  * No random access in V2.
  */
 #ifdef ODBCV2
@@ -47,9 +47,9 @@
 #include <odbc/sqlext.h>
 #endif
 
-/* Driver name is "odbc" and the entry point is 'apr_dbd_odbc_driver' 
+/* Driver name is "odbc" and the entry point is 'apr_dbd_odbc_driver'
  * unless ODBC_DRIVER_NAME is defined and it is linked with another db library which
- * is ODBC source-compatible. e.g. DB2, Informix, TimesTen, mysql.  
+ * is ODBC source-compatible. e.g. DB2, Informix, TimesTen, mysql.
  */
 #ifndef ODBC_DRIVER_NAME
 #define ODBC_DRIVER_NAME odbc
@@ -86,14 +86,14 @@ static void check_error(apr_dbd_t *a, co
 #define TEXTMODE 1              /* used for text (APR 1.2) mode params */
 #define BINARYMODE 0            /* used for binary (APR 1.3+) mode params */
 
-/* Identify datatypes which are LOBs 
+/* Identify datatypes which are LOBs
  * - DB2 DRDA driver uses undefined types -98 and -99 for CLOB & BLOB
  */
 #define IS_LOB(t)  (t == SQL_LONGVARCHAR \
      || t == SQL_LONGVARBINARY || t == SQL_VARBINARY \
      || t == -98 || t == -99)
 
-/* These types are CLOBs 
+/* These types are CLOBs
  * - DB2 DRDA driver uses undefined type -98 for CLOB
  */
 #define IS_CLOB(t) \
@@ -112,7 +112,7 @@ struct apr_dbd_t
     int lasterrorcode;
     int lineNumber;
     char lastError[MAX_ERROR_STRING];
-    int defaultBufferSize;      /* used for CLOBs in text mode, 
+    int defaultBufferSize;      /* used for CLOBs in text mode,
                                  * and when fld size is indeterminate */
     apr_intptr_t transaction_mode;
     apr_intptr_t dboptions;     /* driver options re SQLGetData */
@@ -136,7 +136,7 @@ struct apr_dbd_results_t
     SQLSMALLINT *coltypes;      /* array of SQL data types for columns */
     SQLLEN *colinds;            /* array of SQL data indicator/strlens */
     int *colstate;              /* array of column states
-                                 * - avail, bound, present, unavail 
+                                 * - avail, bound, present, unavail
                                  */
     int *all_data_fetched;      /* flags data as all fetched, for LOBs  */
     void *data;                 /* buffer for all data for one row */
@@ -150,7 +150,7 @@ enum                            /* resul
     COL_RETRIEVED,              /* all data from column has been returned */
     COL_UNAVAIL                 /* column is unavailable because ODBC driver
                                  *  requires that columns be retrieved
-                                 *  in ascending order and a higher col 
+                                 *  in ascending order and a higher col
                                  *  was accessed
                                  */
 };
@@ -200,8 +200,8 @@ typedef struct {
     SQLSMALLINT type;
 } odbc_bucket;
 
-/* SQL datatype mappings to DBD datatypes 
- * These tables must correspond *exactly* to the apr_dbd_type_e enum 
+/* SQL datatype mappings to DBD datatypes
+ * These tables must correspond *exactly* to the apr_dbd_type_e enum
  * in apr_dbd.h
  */
 
@@ -296,7 +296,7 @@ static apr_status_t odbc_close_results(v
 {
     apr_dbd_results_t *dbr = (apr_dbd_results_t *)d;
     SQLRETURN rc = SQL_SUCCESS;
-    
+
     if (dbr && dbr->apr_dbd && dbr->apr_dbd->dbc) {
     	if (!dbr->isclosed)
             rc = SQLCloseCursor(dbr->stmt);
@@ -307,7 +307,7 @@ static apr_status_t odbc_close_results(v
 
 /* close the ODBC statement handle from a  prepare */
 static apr_status_t odbc_close_pstmt(void *s)
-{   
+{
     SQLRETURN rc = APR_SUCCESS;
     apr_dbd_prepared_t *statement = s;
 
@@ -346,7 +346,7 @@ static apr_status_t odbc_close_cleanup(v
 
 /* close the ODBC environment handle at process termination */
 static apr_status_t odbc_close_env(SQLHANDLE henv)
-{   
+{
     SQLRETURN rc;
 
     rc = SQLFreeHandle(SQL_HANDLE_ENV, henv);
@@ -355,7 +355,7 @@ static apr_status_t odbc_close_env(SQLHA
 }
 
 /* setup the arrays in results for all the returned columns */
-static SQLRETURN odbc_set_result_column(int icol, apr_dbd_results_t *res, 
+static SQLRETURN odbc_set_result_column(int icol, apr_dbd_results_t *res,
                                         SQLHANDLE stmt)
 {
     SQLRETURN rc;
@@ -388,21 +388,21 @@ static SQLRETURN odbc_set_result_column(
       type += (isunsigned) ? SQL_UNSIGNED_OFFSET : SQL_SIGNED_OFFSET;
       break;
     /* LOB types are not changed to C types */
-    case SQL_LONGVARCHAR: 
-        type = SQL_LONGVARCHAR; 
+    case SQL_LONGVARCHAR:
+        type = SQL_LONGVARCHAR;
         break;
-    case SQL_LONGVARBINARY: 
-        type = SQL_LONGVARBINARY; 
+    case SQL_LONGVARBINARY:
+        type = SQL_LONGVARBINARY;
         break;
-    case SQL_FLOAT : 
-        type = SQL_C_FLOAT; 
+    case SQL_FLOAT :
+        type = SQL_C_FLOAT;
         break;
-    case SQL_DOUBLE : 
-        type = SQL_C_DOUBLE; 
+    case SQL_DOUBLE :
+        type = SQL_C_DOUBLE;
         break;
 
     /* DBD wants times as strings */
-    case SQL_TIMESTAMP:      
+    case SQL_TIMESTAMP:
     case SQL_DATE:
     case SQL_TIME:
     default:
@@ -449,15 +449,15 @@ static SQLRETURN odbc_set_result_column(
         res->colsizes[icol] = (SQLINTEGER)maxsize;
         if (res->apr_dbd->dboptions & SQL_GD_BOUND) {
             /* we are allowed to call SQLGetData if we need to */
-            rc = SQLBindCol(stmt, icol + 1, res->coltypes[icol], 
-                            res->colptrs[icol], maxsize, 
+            rc = SQLBindCol(stmt, icol + 1, res->coltypes[icol],
+                            res->colptrs[icol], maxsize,
                             &(res->colinds[icol]));
             CHECK_ERROR(res->apr_dbd, "SQLBindCol", rc, SQL_HANDLE_STMT,
                         stmt);
             res->colstate[icol] = SQL_SUCCEEDED(rc) ? COL_BOUND : COL_AVAIL;
         }
         else {
-            /* this driver won't allow us to call SQLGetData on bound 
+            /* this driver won't allow us to call SQLGetData on bound
              * columns - so don't bind any
              */
             res->colstate[icol] = COL_AVAIL;
@@ -599,7 +599,7 @@ static SQLRETURN odbc_bind_param(apr_poo
             (*argp)++;          /* non LOBs consume one argument */
         }
     }
-    rc = SQLBindParameter(statement->stmt, narg, inOut, cType, 
+    rc = SQLBindParameter(statement->stmt, narg, inOut, cType,
                           baseType, len, 0, ptr, len, indicator);
     CHECK_ERROR(statement->apr_dbd, "SQLBindParameter", rc, SQL_HANDLE_STMT,
                 statement->stmt);
@@ -625,7 +625,7 @@ static apr_status_t odbc_lob_bucket_seta
     /* Unlikely - but if the row pool is ancestor of this pool then it is OK */
     if (apr_pool_is_ancestor(bd->row->pool, pool))
         return APR_SUCCESS;
-    
+
     return apr_bucket_setaside_notimpl(e, pool);
 }
 
@@ -641,12 +641,12 @@ static apr_status_t odbc_lob_bucket_read
     void *buf;
     int bufsize = bd->row->res->apr_dbd->defaultBufferSize;
     int eos;
-    
+
     /* C type is CHAR for CLOBs, DEFAULT for BLOBs */
     type = bd->row->res->coltypes[bd->col];
     type = (type == SQL_LONGVARCHAR) ? SQL_C_CHAR : SQL_C_DEFAULT;
 
-    /* LOB buffers are always at least APR_BUCKET_BUFF_SIZE, 
+    /* LOB buffers are always at least APR_BUCKET_BUFF_SIZE,
      *   but they may be much bigger per the BUFSIZE parameter.
      */
     if (bufsize < APR_BUCKET_BUFF_SIZE)
@@ -656,13 +656,13 @@ static apr_status_t odbc_lob_bucket_read
     *str = NULL;
     *len = 0;
 
-    rc = SQLGetData(bd->row->res->stmt, bd->col + 1, 
-                    type, buf, bufsize, 
+    rc = SQLGetData(bd->row->res->stmt, bd->col + 1,
+                    type, buf, bufsize,
                     &len_indicator);
 
-    CHECK_ERROR(bd->row->res->apr_dbd, "SQLGetData", rc, 
+    CHECK_ERROR(bd->row->res->apr_dbd, "SQLGetData", rc,
                 SQL_HANDLE_STMT, bd->row->res->stmt);
-    
+
     if (rc == SQL_NO_DATA || len_indicator == SQL_NULL_DATA || len_indicator < 0)
         len_indicator = 0;
 
@@ -676,11 +676,11 @@ static apr_status_t odbc_lob_bucket_read
              eos = 0;
         }
         else {
-            /* the last read - len_indicator is supposed to be the length, 
+            /* the last read - len_indicator is supposed to be the length,
              * but some driver get this wrong and return the total length.
              * We try to handle both interpretations.
              */
-            *len =  (len_indicator > bufsize 
+            *len =  (len_indicator > bufsize
                      && len_indicator >= (SQLLEN)e->start)
                 ? (len_indicator - (SQLLEN)e->start) : len_indicator;
 
@@ -713,14 +713,14 @@ static apr_status_t odbc_lob_bucket_read
 }
 
 /* Create a bucket brigade on the row pool for a LOB column */
-static apr_status_t odbc_create_bucket(const apr_dbd_row_t *row, const int col, 
+static apr_status_t odbc_create_bucket(const apr_dbd_row_t *row, const int col,
                                        SQLSMALLINT type, apr_bucket_brigade *bb)
 {
     apr_bucket_alloc_t *list = bb->bucket_alloc;
     apr_bucket *b = apr_bucket_alloc(sizeof(*b), list);
     odbc_bucket *bd = apr_bucket_alloc(sizeof(odbc_bucket), list);
     apr_bucket *eos = apr_bucket_eos_create(list);
-    
+
     bd->row = row;
     bd->col = col;
     bd->type = type;
@@ -741,7 +741,7 @@ static apr_status_t odbc_create_bucket(c
 /* returns a data pointer for a column,  returns NULL for NULL value,
  * return -1 if data not available
  */
-static void *odbc_get(const apr_dbd_row_t *row, const int col, 
+static void *odbc_get(const apr_dbd_row_t *row, const int col,
                       const SQLSMALLINT sqltype)
 {
     SQLRETURN rc;
@@ -756,11 +756,11 @@ static void *odbc_get(const apr_dbd_row_
         return NULL;
 
     case (COL_BOUND):
-    case (COL_PRESENT): 
+    case (COL_PRESENT):
         if (sqltype == row->res->coltypes[col]) {
             /* same type and we already have the data */
             row->res->colstate[col] = COL_RETRIEVED;
-            return (row->res->colinds[col] == SQL_NULL_DATA) ? 
+            return (row->res->colinds[col] == SQL_NULL_DATA) ?
                 NULL : row->res->colptrs[col];
         }
     }
@@ -793,7 +793,7 @@ static void *odbc_get(const apr_dbd_row_
 
     rc = SQLGetData(row->res->stmt, col + 1, sqltype, row->res->colptrs[col],
                     row->res->colsizes[col], &indicator);
-    CHECK_ERROR(row->res->apr_dbd, "SQLGetData", rc, SQL_HANDLE_STMT, 
+    CHECK_ERROR(row->res->apr_dbd, "SQLGetData", rc, SQL_HANDLE_STMT,
                 row->res->stmt);
     if (indicator == SQL_NULL_DATA || rc == SQL_NO_DATA)
         return NULL;
@@ -804,7 +804,7 @@ static void *odbc_get(const apr_dbd_row_
         /* this allows getting CLOBs in text mode by calling get_entry
          *   until it returns NULL
          */
-        row->res->colstate[col] = 
+        row->res->colstate[col] =
             (rc == SQL_SUCCESS_WITH_INFO) ? COL_AVAIL : COL_RETRIEVED;
         return row->res->colptrs[col];
     }
@@ -814,8 +814,8 @@ static void *odbc_get(const apr_dbd_row_
 
 /* Parse the parameter string for open */
 static apr_status_t odbc_parse_params(apr_pool_t *pool, const char *params,
-                               int *connect, SQLCHAR **datasource, 
-                               SQLCHAR **user, SQLCHAR **password, 
+                               int *connect, SQLCHAR **datasource,
+                               SQLCHAR **user, SQLCHAR **password,
                                int *defaultBufferSize, int *nattrs,
                                int **attrs, apr_intptr_t **attrvals)
 {
@@ -954,7 +954,7 @@ static void check_error(apr_dbd_t *dbc,
         res = "unrecognized SQL return code";
     }
     /* these two returns are expected during normal execution */
-    if (rc != SQL_SUCCESS_WITH_INFO && rc != SQL_NO_DATA 
+    if (rc != SQL_SUCCESS_WITH_INFO && rc != SQL_NO_DATA
         && dbc->can_commit != APR_DBD_TRANSACTION_IGNORE_ERRORS) {
         dbc->can_commit = APR_DBD_TRANSACTION_ROLLBACK;
     }
@@ -964,9 +964,9 @@ static void check_error(apr_dbd_t *dbc,
     p += sprintf(p, "[dbd_odbc] %.64s returned %.30s (%d) at %.24s:%d ",
                  step, res, rc, SOURCE_FILE, line - 1);
     for (i = 1, rc = 0; rc == 0; i++) {
-        rc = SQLGetDiagRec(type, h, i, sqlstate, &native, buffer, 
+        rc = SQLGetDiagRec(type, h, i, sqlstate, &native, buffer,
                             sizeof(buffer), &reslength);
-        if (SQL_SUCCEEDED(rc) && (p < (end - 280))) 
+        if (SQL_SUCCEEDED(rc) && (p < (end - 280)))
             p += sprintf(p, "%.256s %.20s ", buffer, sqlstate);
     }
     apr_env_get(&logval, "apr_dbd_odbc_log", dbc->pool);
@@ -1002,21 +1002,21 @@ static void odbc_init(apr_pool_t *pool)
     SQLRETURN rc;
     char *step;
     apr_version_t aprver;
-    
+
     apr_version(&aprver);
-    if (aprver.major != DRIVER_APR_VERSION_MAJOR 
+    if (aprver.major != DRIVER_APR_VERSION_MAJOR
         || aprver.minor != DRIVER_APR_VERSION_MINOR) {
             apr_file_t *se;
 
             apr_file_open_stderr(&se, pool);
             apr_file_printf(se, "Incorrect " ODBC_DRIVER_STRING " dbd driver version\n"
                 "Attempt to load APR version %d.%d driver with APR version %d.%d\n",
-                DRIVER_APR_VERSION_MAJOR, DRIVER_APR_VERSION_MINOR, 
+                DRIVER_APR_VERSION_MAJOR, DRIVER_APR_VERSION_MINOR,
                 aprver.major, aprver.minor);
         abort();
     }
 
-    if (henv) 
+    if (henv)
         return;
 
     step = "SQLAllocHandle (SQL_HANDLE_ENV)";
@@ -1045,7 +1045,7 @@ static void *odbc_native_handle(apr_dbd_
 
 /** open: obtain a database connection from the server rec. **/
 
-/* It would be more efficient to allocate a single statement handle 
+/* It would be more efficient to allocate a single statement handle
  * here - but SQL_ATTR_CURSOR_SCROLLABLE must be set before
  * SQLPrepare, and we don't know whether random-access is
  * specified until SQLExecute so we cannot.
@@ -1199,7 +1199,7 @@ static int odbc_start_transaction(apr_po
 static int odbc_end_transaction(apr_dbd_transaction_t *trans)
 {
     SQLRETURN rc;
-    int action = (trans->apr_dbd->can_commit != APR_DBD_TRANSACTION_ROLLBACK) 
+    int action = (trans->apr_dbd->can_commit != APR_DBD_TRANSACTION_ROLLBACK)
         ? SQL_COMMIT : SQL_ROLLBACK;
 
     rc = SQLEndTran(SQL_HANDLE_DBC, trans->dbc, action);
@@ -1283,7 +1283,7 @@ static int odbc_select(apr_pool_t *pool,
     }
     if (SQL_SUCCEEDED(rc)) {
         rc = odbc_create_results(handle, hstmt, pool, random, res);
-        apr_pool_cleanup_register(pool, *res, 
+        apr_pool_cleanup_register(pool, *res,
                                   odbc_close_results, apr_pool_cleanup_null);
     }
     return APR_FROM_SQL_RESULT(rc);
@@ -1327,7 +1327,7 @@ static int odbc_get_row(apr_pool_t *pool
         }
         /* some drivers do not null-term zero-len CHAR data */
         if (res->colptrs[c])
-            *(char *)res->colptrs[c] = 0; 
+            *(char *)res->colptrs[c] = 0;
     }
     if (res->random && (rownum > 0)) {
         fetchtype = "SQLFetchScroll";
@@ -1369,7 +1369,7 @@ static apr_status_t odbc_datum_get(const
     sqltype = sqlCtype[dbdtype];
 
     /* must not memcpy a brigade, sentinals are relative to orig loc */
-    if (IS_LOB(sqltype)) 
+    if (IS_LOB(sqltype))
         return odbc_create_bucket(row, col, sqltype, data);
 
     p = odbc_get(row, col, sqltype);
@@ -1378,12 +1378,12 @@ static apr_status_t odbc_datum_get(const
 
     if (p == NULL)
         return APR_ENOENT;          /* SQL NULL value */
-    
+
     if (len < 0)
        *(char**)data = (char *)p;
     else
         memcpy(data, p, len);
-    
+
     return APR_SUCCESS;
 
 }
@@ -1400,26 +1400,26 @@ static const char *odbc_get_entry(const
 
     /* NULL or invalid (-1) */
     if (p == NULL || p == (void *)-1)
-        return p;     
+        return p;
     else
-        return apr_pstrdup(row->pool, p);   
+        return apr_pstrdup(row->pool, p);
 }
 
 /** error: get current error message (if any) **/
 static const char *odbc_error(apr_dbd_t *handle, int errnum)
-{   
+{
     return (handle) ? handle->lastError : "[dbd_odbc]No error message available";
 }
 
 /** escape: escape a string so it is safe for use in query/select **/
 static const char *odbc_escape(apr_pool_t *pool, const char *s,
                                apr_dbd_t *handle)
-{   
+{
     char *newstr, *src, *dst, *sq;
     int qcount;
 
     /* return the original if there are no single-quotes */
-    if (!(sq = strchr(s, '\''))) 
+    if (!(sq = strchr(s, '\'')))
         return (char *)s;
     /* count the single-quotes and allocate a new buffer */
     for (qcount = 1; (sq = strchr(sq + 1, '\'')); )
@@ -1429,7 +1429,7 @@ static const char *odbc_escape(apr_pool_
     /* move chars, doubling all single-quotes */
     src = (char *)s;
     for (dst = newstr; *src; src++) {
-        if ((*dst++ = *src) == '\'')  
+        if ((*dst++ = *src) == '\'')
             *dst++ = '\'';
     }
     *dst = 0;
@@ -1456,7 +1456,7 @@ static int odbc_prepare(apr_pool_t *pool
     (*statement)->types =
         apr_pmemdup(pool, types, nargs * sizeof(apr_dbd_type_e));
     rc = SQLAllocHandle(SQL_HANDLE_STMT, handle->dbc, &((*statement)->stmt));
-    apr_pool_cleanup_register(pool, *statement, 
+    apr_pool_cleanup_register(pool, *statement,
                               odbc_close_pstmt, apr_pool_cleanup_null);
     CHECK_ERROR(handle, "SQLAllocHandle (STMT)", rc,
                 SQL_HANDLE_DBC, handle->dbc);

Modified: apr/apr/trunk/dbd/apr_dbd_oracle.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/apr_dbd_oracle.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/apr_dbd_oracle.c (original)
+++ apr/apr/trunk/dbd/apr_dbd_oracle.c Sun Nov 20 07:14:38 2022
@@ -762,7 +762,7 @@ static const char *dbd_oracle_error(apr_
     switch (OCIErrorGet(sql->err, 1, NULL, &errorcode,
                         (text*) sql->buf, sizeof(sql->buf), OCI_HTYPE_ERROR)) {
     case OCI_SUCCESS:
-        return sql->buf; 
+        return sql->buf;
     default:
         return "internal error: OCIErrorGet failed";
     }
@@ -2134,16 +2134,16 @@ static apr_status_t dbd_oracle_check_con
 {
     apr_dbd_results_t *res = NULL;
     apr_dbd_row_t *row = NULL;
-    
+
     if(dbd_oracle_pselect(pool, sql, &res, sql->check_conn_stmt,
                           0, NULL) != 0) {
         return APR_EGENERAL;
     }
-    
+
     if(dbd_oracle_get_row(pool, res, &row, -1) != 0) {
         return APR_EGENERAL;
     }
-    
+
     if(dbd_oracle_get_row(pool, res, &row, -1) != -1) {
         return APR_EGENERAL;
     }

Modified: apr/apr/trunk/dbd/apr_dbd_pgsql.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/apr_dbd_pgsql.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/apr_dbd_pgsql.c (original)
+++ apr/apr/trunk/dbd/apr_dbd_pgsql.c Sun Nov 20 07:14:38 2022
@@ -424,7 +424,7 @@ static int dbd_pgsql_query(apr_dbd_t *sq
     else {
         ret = PGRES_FATAL_ERROR;
     }
-    
+
     if (ret != 0){
         if (TXN_IGNORE_ERRORS(sql->trans)) {
             PGresult *res = PQexec(sql->conn,
@@ -501,19 +501,19 @@ static int dbd_pgsql_prepare(apr_pool_t
 
     for (i = 0; i < nargs; i++) {
         switch (types[i]) {
-        case APR_DBD_TYPE_TINY: 
-        case APR_DBD_TYPE_UTINY: 
-        case APR_DBD_TYPE_SHORT: 
+        case APR_DBD_TYPE_TINY:
+        case APR_DBD_TYPE_UTINY:
+        case APR_DBD_TYPE_SHORT:
         case APR_DBD_TYPE_USHORT:
             args[i] = "smallint";
             break;
-        case APR_DBD_TYPE_INT: 
+        case APR_DBD_TYPE_INT:
         case APR_DBD_TYPE_UINT:
             args[i] = "integer";
             break;
-        case APR_DBD_TYPE_LONG: 
-        case APR_DBD_TYPE_ULONG:   
-        case APR_DBD_TYPE_LONGLONG: 
+        case APR_DBD_TYPE_LONG:
+        case APR_DBD_TYPE_ULONG:
+        case APR_DBD_TYPE_LONGLONG:
         case APR_DBD_TYPE_ULONGLONG:
             args[i] = "bigint";
             break;
@@ -1209,7 +1209,7 @@ static apr_dbd_t *dbd_pgsql_open(apr_poo
                                  const char **error)
 {
     apr_dbd_t *sql;
-    
+
     PGconn *conn = PQconnectdb(params);
 
     /* if there's an error in the connect string or something we get

Modified: apr/apr/trunk/dbd/apr_dbd_sqlite2.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/apr_dbd_sqlite2.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/apr_dbd_sqlite2.c (original)
+++ apr/apr/trunk/dbd/apr_dbd_sqlite2.c Sun Nov 20 07:14:38 2022
@@ -73,7 +73,7 @@ struct apr_dbd_prepared_t {
 
 static apr_status_t free_table(void *data)
 {
-    sqlite_free_table(data); 
+    sqlite_free_table(data);
     return APR_SUCCESS;
 }
 
@@ -159,8 +159,8 @@ static int dbd_sqlite_get_row(apr_pool_t
     }
 
     /* Pointer magic explanation:
-     *      The sqlite result is an array such that the first res->sz elements are 
-     *      the column names and each tuple follows afterwards 
+     *      The sqlite result is an array such that the first res->sz elements are
+     *      the column names and each tuple follows afterwards
      *      ex: (from the sqlite2 documentation)
      SELECT employee_name, login, host FROM users WHERE login LIKE *        'd%';
 

Modified: apr/apr/trunk/dbd/apr_dbd_sqlite3.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/apr_dbd_sqlite3.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/apr_dbd_sqlite3.c (original)
+++ apr/apr/trunk/dbd/apr_dbd_sqlite3.c Sun Nov 20 07:14:38 2022
@@ -422,7 +422,7 @@ static int dbd_sqlite3_prepare(apr_pool_
 
     ret = sqlite3_prepare(sql->conn, query, strlen(query), &stmt, &tail);
     if (ret == SQLITE_OK) {
-        apr_dbd_prepared_t *prep; 
+        apr_dbd_prepared_t *prep;
 
         prep = apr_pcalloc(sql->pool, sizeof(*prep));
         prep->stmt = stmt;
@@ -438,7 +438,7 @@ static int dbd_sqlite3_prepare(apr_pool_
     } else {
         sqlite3_finalize(stmt);
     }
-   
+
     apr_dbd_mutex_unlock();
 
     return ret;

Modified: apr/apr/trunk/dbd/unsupported/apr_dbd_freetds.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbd/unsupported/apr_dbd_freetds.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbd/unsupported/apr_dbd_freetds.c (original)
+++ apr/apr/trunk/dbd/unsupported/apr_dbd_freetds.c Sun Nov 20 07:14:38 2022
@@ -216,7 +216,7 @@ static const char *dbd_statement(apr_poo
     const char *p_in;
     char *p_out;
     char *q;
-   
+
     /* compute upper bound on length (since untaint shrinks) */
     len  = strlen(stmt->fmt) +1;
     for (i=0; i<nargs; ++i) {
@@ -612,7 +612,7 @@ static DBPROCESS *freetds_open(apr_pool_
     {
         dbuse(process, databaseName);
     }
- 
+
     dbloginfree(login);
     if (process == NULL) {
         return NULL;

Modified: apr/apr/trunk/dbm/apr_dbm.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbm/apr_dbm.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbm/apr_dbm.c (original)
+++ apr/apr/trunk/dbm/apr_dbm.c Sun Nov 20 07:14:38 2022
@@ -36,7 +36,7 @@
 #include "apr_dbm_private.h"
 
 /* ### note: the setting of DBM_VTABLE will go away once we have multiple
-   ### DBMs in here. 
+   ### DBMs in here.
    ### Well, that day is here.  So, do we remove DBM_VTABLE and the old
    ### API entirely?  Oh, what to do.  We need an APU_DEFAULT_DBM #define.
    ### Sounds like a job for autoconf. */
@@ -143,9 +143,9 @@ APR_DECLARE(apr_status_t) apr_dbm_get_dr
     if (!strcasecmp(type, "default"))        type = DBM_NAME;
     else if (!strcasecmp(type, "db"))        type = "db";
     else if (*type && !strcasecmp(type + 1, "dbm")) {
-        if      (*type == 'G' || *type == 'g') type = "gdbm"; 
-        else if (*type == 'N' || *type == 'n') type = "ndbm"; 
-        else if (*type == 'S' || *type == 's') type = "sdbm"; 
+        if      (*type == 'G' || *type == 'g') type = "gdbm";
+        else if (*type == 'N' || *type == 'n') type = "ndbm";
+        else if (*type == 'S' || *type == 's') type = "sdbm";
     }
     else usertype = 1;
 
@@ -232,8 +232,8 @@ APR_DECLARE(apr_status_t) apr_dbm_get_dr
 #endif /* APR_HAVE_MODULAR_DSO */
 }
 
-APR_DECLARE(apr_status_t) apr_dbm_open_ex(apr_dbm_t **pdb, const char *type, 
-                                          const char *pathname, 
+APR_DECLARE(apr_status_t) apr_dbm_open_ex(apr_dbm_t **pdb, const char *type,
+                                          const char *pathname,
                                           apr_int32_t mode,
                                           apr_fileperms_t perm,
                                           apr_pool_t *pool)
@@ -245,9 +245,9 @@ APR_DECLARE(apr_status_t) apr_dbm_open_e
         rv = (vtable->open)(pdb, pathname, mode, perm, pool);
     }
     return rv;
-} 
+}
 
-APR_DECLARE(apr_status_t) apr_dbm_open(apr_dbm_t **pdb, const char *pathname, 
+APR_DECLARE(apr_status_t) apr_dbm_open(apr_dbm_t **pdb, const char *pathname,
                                        apr_int32_t mode, apr_fileperms_t perm,
                                        apr_pool_t *pool)
 {
@@ -319,8 +319,8 @@ APR_DECLARE(char *) apr_dbm_geterror(apr
     return errbuf;
 }
 
-APR_DECLARE(apr_status_t) apr_dbm_get_usednames_ex(apr_pool_t *p, 
-                                                   const char *type, 
+APR_DECLARE(apr_status_t) apr_dbm_get_usednames_ex(apr_pool_t *p,
+                                                   const char *type,
                                                    const char *pathname,
                                                    const char **used1,
                                                    const char **used2)
@@ -333,14 +333,14 @@ APR_DECLARE(apr_status_t) apr_dbm_get_us
         return APR_SUCCESS;
     }
     return rv;
-} 
+}
 
 APR_DECLARE(void) apr_dbm_get_usednames(apr_pool_t *p,
                                         const char *pathname,
                                         const char **used1,
                                         const char **used2)
 {
-    apr_dbm_get_usednames_ex(p, DBM_NAME, pathname, used1, used2); 
+    apr_dbm_get_usednames_ex(p, DBM_NAME, pathname, used1, used2);
 }
 
 /* Most DBM libraries take a POSIX mode for creating files.  Don't trust

Modified: apr/apr/trunk/dbm/apr_dbm_berkeleydb.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbm/apr_dbm_berkeleydb.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbm/apr_dbm_berkeleydb.c (original)
+++ apr/apr/trunk/dbm/apr_dbm_berkeleydb.c Sun Nov 20 07:14:38 2022
@@ -28,7 +28,7 @@
 #include "apu.h"
 #include "apr_private.h"
 
-#if APU_HAVE_DB 
+#if APU_HAVE_DB
 #include "apr_dbm_private.h"
 
 /*
@@ -169,8 +169,8 @@ static apr_status_t vt_db_open(apr_dbm_t
 #if DB_VER == 4
                                            NULL,
 #endif
-                                           pathname, NULL, 
-                                           DB_HASH, dbmode, 
+                                           pathname, NULL,
+                                           DB_HASH, dbmode,
                                            apr_posix_perms2mode(perm))) != 0) {
                 /* close the DB handler */
                 (void) (*file.bdb->close)(file.bdb, 0);

Modified: apr/apr/trunk/dbm/sdbm/sdbm.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbm/sdbm/sdbm.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbm/sdbm/sdbm.c (original)
+++ apr/apr/trunk/dbm/sdbm/sdbm.c Sun Nov 20 07:14:38 2022
@@ -98,7 +98,7 @@ static apr_status_t prep(apr_sdbm_t **pd
     db->pool = p;
 
     /*
-     * adjust user flags so that WRONLY becomes RDWR, 
+     * adjust user flags so that WRONLY becomes RDWR,
      * as required by this package. Also set our internal
      * flag for RDONLY if needed.
      */
@@ -132,7 +132,7 @@ static apr_status_t prep(apr_sdbm_t **pd
                 != APR_SUCCESS)
         goto error;
 
-    if ((status = apr_sdbm_lock(db, (db->flags & SDBM_RDONLY) 
+    if ((status = apr_sdbm_lock(db, (db->flags & SDBM_RDONLY)
                                         ? APR_FLOCK_SHARED
                                         : APR_FLOCK_EXCLUSIVE))
                 != APR_SUCCESS)
@@ -143,7 +143,7 @@ static apr_status_t prep(apr_sdbm_t **pd
      */
 
     /*
-     * if we are opened in SHARED mode, unlock ourself 
+     * if we are opened in SHARED mode, unlock ourself
      */
     if (db->flags & SDBM_SHARED)
         if ((status = apr_sdbm_unlock(db)) != APR_SUCCESS)
@@ -168,13 +168,13 @@ error:
     return status;
 }
 
-APR_DECLARE(apr_status_t) apr_sdbm_open(apr_sdbm_t **db, const char *file, 
-                                        apr_int32_t flags, 
+APR_DECLARE(apr_status_t) apr_sdbm_open(apr_sdbm_t **db, const char *file,
+                                        apr_int32_t flags,
                                         apr_fileperms_t perms, apr_pool_t *p)
 {
     char *dirname = apr_pstrcat(p, file, APR_SDBM_DIRFEXT, NULL);
     char *pagname = apr_pstrcat(p, file, APR_SDBM_PAGFEXT, NULL);
-    
+
     return prep(db, dirname, pagname, flags, perms, p);
 }
 
@@ -187,7 +187,7 @@ APR_DECLARE(apr_status_t) apr_sdbm_fetch
                                          apr_sdbm_datum_t key)
 {
     apr_status_t status;
-    
+
     if (db == NULL || bad(key))
         return APR_EINVAL;
 
@@ -208,23 +208,23 @@ static apr_status_t write_page(apr_sdbm_
 {
     apr_status_t status;
     apr_off_t off = OFF_PAG(pagno);
-    
+
     if ((status = apr_file_seek(db->pagf, APR_SET, &off)) == APR_SUCCESS)
         status = apr_file_write_full(db->pagf, buf, PBLKSIZ, NULL);
 
     return status;
 }
 
-APR_DECLARE(apr_status_t) apr_sdbm_delete(apr_sdbm_t *db, 
+APR_DECLARE(apr_status_t) apr_sdbm_delete(apr_sdbm_t *db,
                                           const apr_sdbm_datum_t key)
 {
     apr_status_t status;
-    
+
     if (db == NULL || bad(key))
         return APR_EINVAL;
     if (apr_sdbm_rdonly(db))
         return APR_EINVAL;
-    
+
     if ((status = apr_sdbm_lock(db, APR_FLOCK_EXCLUSIVE)) != APR_SUCCESS)
         return status;
 
@@ -247,7 +247,7 @@ APR_DECLARE(apr_status_t) apr_sdbm_store
     int need;
     register long hash;
     apr_status_t status;
-    
+
     if (db == NULL || bad(key))
         return APR_EINVAL;
     if (apr_sdbm_rdonly(db))
@@ -290,7 +290,7 @@ APR_DECLARE(apr_status_t) apr_sdbm_store
     }
 
 error:
-    (void) apr_sdbm_unlock(db);    
+    (void) apr_sdbm_unlock(db);
 
     return status;
 }
@@ -328,10 +328,10 @@ static apr_status_t makroom(apr_sdbm_t *
          * here, as sdbm_store will do so, after it inserts the incoming pair.
          */
         if (hash & (db->hmask + 1)) {
-            if ((status = write_page(db, db->pagbuf, db->pagbno)) 
+            if ((status = write_page(db, db->pagbuf, db->pagbno))
                         != APR_SUCCESS)
                 return status;
-                    
+
             db->pagbno = newp;
             (void) memcpy(pag, new, PBLKSIZ);
         }
@@ -356,11 +356,11 @@ static apr_status_t makroom(apr_sdbm_t *
         db->curbit = 2 * db->curbit
                    + ((hash & (db->hmask + 1)) ? 2 : 1);
         db->hmask |= db->hmask + 1;
-            
+
         if ((status = write_page(db, db->pagbuf, db->pagbno))
                     != APR_SUCCESS)
             return status;
-            
+
     } while (--smax);
 
     /*
@@ -380,7 +380,7 @@ static apr_status_t makroom(apr_sdbm_t *
  * If 'create' is asked and EOF is returned while reading, this is taken
  * as success (i.e. a cleared buffer is returned).
  */
-static apr_status_t read_from(apr_file_t *f, void *buf, 
+static apr_status_t read_from(apr_file_t *f, void *buf,
                               apr_off_t off, apr_size_t len,
                               int create)
 {
@@ -402,11 +402,11 @@ static apr_status_t read_from(apr_file_t
  * the following two routines will break if
  * deletions aren't taken into account. (ndbm bug)
  */
-APR_DECLARE(apr_status_t) apr_sdbm_firstkey(apr_sdbm_t *db, 
+APR_DECLARE(apr_status_t) apr_sdbm_firstkey(apr_sdbm_t *db,
                                             apr_sdbm_datum_t *key)
 {
     apr_status_t status;
-    
+
     if ((status = apr_sdbm_lock(db, APR_FLOCK_SHARED)) != APR_SUCCESS)
         return status;
 
@@ -424,11 +424,11 @@ APR_DECLARE(apr_status_t) apr_sdbm_first
     return status;
 }
 
-APR_DECLARE(apr_status_t) apr_sdbm_nextkey(apr_sdbm_t *db, 
+APR_DECLARE(apr_status_t) apr_sdbm_nextkey(apr_sdbm_t *db,
                                            apr_sdbm_datum_t *key)
 {
     apr_status_t status;
-    
+
     if ((status = apr_sdbm_lock(db, APR_FLOCK_SHARED)) != APR_SUCCESS)
         return status;
 
@@ -468,7 +468,7 @@ static apr_status_t getpage(apr_sdbm_t *
      * see if the block we need is already in memory.
      * note: this lookaside cache has about 10% hit rate.
      */
-    if (pagb != db->pagbno) { 
+    if (pagb != db->pagbno) {
         /*
          * note: here, we assume a "hole" is read as 0s.
          * if not, must zero pagbuf first.
@@ -529,7 +529,7 @@ static apr_status_t setdbit(apr_sdbm_t *
             return status;
 
         db->dirbno = dirb;
-        
+
         debug(("dir read: %d\n", dirb));
     }
 

Modified: apr/apr/trunk/dbm/sdbm/sdbm_hash.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbm/sdbm/sdbm_hash.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbm/sdbm/sdbm_hash.c (original)
+++ apr/apr/trunk/dbm/sdbm/sdbm_hash.c Sun Nov 20 07:14:38 2022
@@ -31,7 +31,7 @@
  * [this seems to work remarkably well, in fact better
  * then the ndbm hash function. Replace at your own risk]
  * use: 65599	nice.
- *      65587   even better. 
+ *      65587   even better.
  */
 long sdbm_hash(const char *str, int len)
 {

Modified: apr/apr/trunk/dbm/sdbm/sdbm_lock.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbm/sdbm/sdbm_lock.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbm/sdbm/sdbm_lock.c (original)
+++ apr/apr/trunk/dbm/sdbm/sdbm_lock.c Sun Nov 20 07:14:38 2022
@@ -48,7 +48,7 @@ APR_DECLARE(apr_status_t) apr_sdbm_lock(
      * zero size: either a fresh database, or one with a single,
      * unsplit data page: dirpage is all zeros.
      */
-    if ((status = apr_file_lock(db->dirf, type)) == APR_SUCCESS) 
+    if ((status = apr_file_lock(db->dirf, type)) == APR_SUCCESS)
     {
         apr_finfo_t finfo;
         if ((status = apr_file_info_get(&finfo, APR_FINFO_SIZE, db->dirf))

Modified: apr/apr/trunk/dbm/sdbm/sdbm_pair.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dbm/sdbm/sdbm_pair.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dbm/sdbm/sdbm_pair.c (original)
+++ apr/apr/trunk/dbm/sdbm/sdbm_pair.c Sun Nov 20 07:14:38 2022
@@ -34,8 +34,8 @@
 
 #define exhash(item)	sdbm_hash((item).dptr, (item).dsize)
 
-/* 
- * forward 
+/*
+ * forward
  */
 static int seepair(char *, int, char *, int);
 
@@ -270,7 +270,7 @@ long sbit;
 
 	n = ino[0];
 	for (ino++; n > 0; ino += 2) {
-		key.dptr = cur + ino[0]; 
+		key.dptr = cur + ino[0];
 		key.dsize = off - ino[0];
 		val.dptr = cur + ino[1];
 		val.dsize = ino[0] - ino[1];
@@ -283,13 +283,13 @@ long sbit;
 		n -= 2;
 	}
 
-	debug(("%d split %d/%d\n", ((short *) cur)[0] / 2, 
+	debug(("%d split %d/%d\n", ((short *) cur)[0] / 2,
 	       ((short *) new)[0] / 2,
 	       ((short *) pag)[0] / 2));
 }
 
 /*
- * check page sanity: 
+ * check page sanity:
  * number of entries should be something
  * reasonable, and all offsets in the index should be in order.
  * this could be made more rigorous.

Modified: apr/apr/trunk/dso/aix/dso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dso/aix/dso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dso/aix/dso.c (original)
+++ apr/apr/trunk/dso/aix/dso.c Sun Nov 20 07:14:38 2022
@@ -33,10 +33,10 @@
  *  as such, and this notice is not modified.
  *
  *  Changes marked with `--jwe' were made on April 7 1996 by
- *  John W. Eaton <jw...@bevo.che.wisc.edu> to support g++ 
+ *  John W. Eaton <jw...@bevo.che.wisc.edu> to support g++
  *
- *  Bundled, stripped and adjusted on April 1998 as one single source file 
- *  for inclusion into the Apache HTTP server by 
+ *  Bundled, stripped and adjusted on April 1998 as one single source file
+ *  for inclusion into the Apache HTTP server by
  *  Ralf S. Engelschall <rs...@apache.org>
  *
  *  Added to APR by David Reid April 2000
@@ -125,7 +125,7 @@ static apr_status_t dso_cleanup(void *th
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle, 
+APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle,
                                        const char *path, apr_pool_t *ctx)
 {
     void *os_handle = dlopen((char *)path, RTLD_NOW | RTLD_GLOBAL);
@@ -133,7 +133,7 @@ APR_DECLARE(apr_status_t) apr_dso_load(a
     *res_handle = apr_pcalloc(ctx, sizeof(*res_handle));
 
     if(os_handle == NULL) {
-        (*res_handle)->errormsg = dlerror();       
+        (*res_handle)->errormsg = dlerror();
         return APR_EDSOOPEN;
     }
 
@@ -151,8 +151,8 @@ APR_DECLARE(apr_status_t) apr_dso_unload
     return apr_pool_cleanup_run(handle->pool, handle, dso_cleanup);
 }
 
-APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym, 
-                                      apr_dso_handle_t *handle, 
+APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym,
+                                      apr_dso_handle_t *handle,
                                       const char *symname)
 {
     void *retval = dlsym(handle->handle, symname);

Modified: apr/apr/trunk/dso/beos/dso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dso/beos/dso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dso/beos/dso.c (original)
+++ apr/apr/trunk/dso/beos/dso.c Sun Nov 20 07:14:38 2022
@@ -30,7 +30,7 @@ static apr_status_t dso_cleanup(void *th
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle, 
+APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle,
                                        const char *path, apr_pool_t *pool)
 {
     image_id newid = -1;
@@ -41,7 +41,7 @@ APR_DECLARE(apr_status_t) apr_dso_load(a
         (*res_handle)->errormsg = strerror(newid);
         return APR_EDSOOPEN;
 	}
-	
+
     (*res_handle)->pool = pool;
     (*res_handle)->handle = newid;
 
@@ -63,7 +63,7 @@ APR_DECLARE(apr_status_t) apr_dso_sym(ap
     if (symname == NULL)
         return APR_ESYMNOTFOUND;
 
-    err = get_image_symbol(handle->handle, symname, B_SYMBOL_TYPE_ANY, 
+    err = get_image_symbol(handle->handle, symname, B_SYMBOL_TYPE_ANY,
 			 ressym);
 
     if(err != B_OK)

Modified: apr/apr/trunk/dso/netware/dso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dso/netware/dso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dso/netware/dso.c (original)
+++ apr/apr/trunk/dso/netware/dso.c Sun Nov 20 07:14:38 2022
@@ -65,7 +65,7 @@ static apr_status_t dso_cleanup(void *th
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle, 
+APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle,
                                        const char *path, apr_pool_t *pool)
 {
 
@@ -73,7 +73,7 @@ APR_DECLARE(apr_status_t) apr_dso_load(a
     char *fullpath = NULL;
     apr_status_t rv;
 
-    if ((rv = apr_filepath_merge(&fullpath, NULL, path, 
+    if ((rv = apr_filepath_merge(&fullpath, NULL, path,
                                  APR_FILEPATH_NATIVE, pool)) != APR_SUCCESS) {
         return rv;
     }
@@ -97,14 +97,14 @@ APR_DECLARE(apr_status_t) apr_dso_load(a
 
     return APR_SUCCESS;
 }
-    
+
 APR_DECLARE(apr_status_t) apr_dso_unload(apr_dso_handle_t *handle)
 {
     return apr_pool_cleanup_run(handle->pool, handle, dso_cleanup);
 }
 
-APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym, 
-                                      apr_dso_handle_t *handle, 
+APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym,
+                                      apr_dso_handle_t *handle,
                                       const char *symname)
 {
     sym_list *symbol = NULL;
@@ -121,11 +121,11 @@ APR_DECLARE(apr_status_t) apr_dso_sym(ap
     symbol->symbol = apr_pstrdup(handle->pool, symname);
 
     *ressym = retval;
-    
+
     return APR_SUCCESS;
 }
 
-APR_DECLARE(const char *) apr_dso_error(apr_dso_handle_t *dso, char *buffer, 
+APR_DECLARE(const char *) apr_dso_error(apr_dso_handle_t *dso, char *buffer,
                                         apr_size_t buflen)
 {
     if (dso->errormsg) {

Modified: apr/apr/trunk/dso/os2/dso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dso/os2/dso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dso/os2/dso.c (original)
+++ apr/apr/trunk/dso/os2/dso.c Sun Nov 20 07:14:38 2022
@@ -29,7 +29,7 @@ static apr_status_t dso_cleanup(void *th
 
     if (dso->handle == 0)
         return APR_SUCCESS;
-       
+
     rc = DosFreeModule(dso->handle);
 
     if (rc == 0)
@@ -70,8 +70,8 @@ APR_DECLARE(apr_status_t) apr_dso_unload
 
 
 
-APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym, 
-                                      apr_dso_handle_t *handle, 
+APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym,
+                                      apr_dso_handle_t *handle,
                                       const char *symname)
 {
     PFN func;

Modified: apr/apr/trunk/dso/os390/dso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dso/os390/dso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dso/os390/dso.c (original)
+++ apr/apr/trunk/dso/os390/dso.c Sun Nov 20 07:14:38 2022
@@ -25,7 +25,7 @@
 APR_DECLARE(apr_status_t) apr_os_dso_handle_put(apr_dso_handle_t **aprdso,
                                                 apr_os_dso_handle_t osdso,
                                                 apr_pool_t *pool)
-{   
+{
     *aprdso = apr_pcalloc(pool, sizeof **aprdso);
     (*aprdso)->handle = osdso;
     (*aprdso)->pool = pool;
@@ -46,7 +46,7 @@ static apr_status_t dso_cleanup(void *th
 
     if (dso->handle == 0)
         return APR_SUCCESS;
-       
+
     rc = dllfree(dso->handle);
 
     if (rc == 0) {
@@ -57,7 +57,7 @@ static apr_status_t dso_cleanup(void *th
     return errno;
 }
 
-APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle, 
+APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle,
                                        const char *path, apr_pool_t *ctx)
 {
     dllhandle *handle;
@@ -80,12 +80,12 @@ APR_DECLARE(apr_status_t) apr_dso_unload
     return apr_pool_cleanup_run(handle->pool, handle, dso_cleanup);
 }
 
-APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym, 
-                                      apr_dso_handle_t *handle, 
+APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym,
+                                      apr_dso_handle_t *handle,
                                       const char *symname)
 {
     void *func_ptr;
-    void *var_ptr; 
+    void *var_ptr;
 
     if ((var_ptr = dllqueryvar(handle->handle, symname)) != NULL) {
         *ressym = var_ptr;
@@ -99,7 +99,7 @@ APR_DECLARE(apr_status_t) apr_dso_sym(ap
     return APR_ESYMNOTFOUND;
 }
 
-APR_DECLARE(const char *) apr_dso_error(apr_dso_handle_t *handle, char *buffer, 
+APR_DECLARE(const char *) apr_dso_error(apr_dso_handle_t *handle, char *buffer,
                           apr_size_t buflen)
 {
     apr_cpystrn(buffer, strerror(handle->failing_errno), buflen);

Modified: apr/apr/trunk/dso/unix/dso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/dso/unix/dso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/dso/unix/dso.c (original)
+++ apr/apr/trunk/dso/unix/dso.c Sun Nov 20 07:14:38 2022
@@ -77,7 +77,7 @@ static apr_status_t dso_cleanup(void *th
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle, 
+APR_DECLARE(apr_status_t) apr_dso_load(apr_dso_handle_t **res_handle,
                                        const char *path, apr_pool_t *pool)
 {
 #if defined(DSO_USE_SHL)
@@ -137,7 +137,7 @@ APR_DECLARE(apr_status_t) apr_dso_load(a
     }
 #endif
     os_handle = dlopen(path, flags);
-#endif    
+#endif
 #endif /* DSO_USE_x */
 
     *res_handle = apr_pcalloc(pool, sizeof(**res_handle));
@@ -163,14 +163,14 @@ APR_DECLARE(apr_status_t) apr_dso_load(a
 
     return APR_SUCCESS;
 }
-    
+
 APR_DECLARE(apr_status_t) apr_dso_unload(apr_dso_handle_t *handle)
 {
     return apr_pool_cleanup_run(handle->pool, handle, dso_cleanup);
 }
 
-APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym, 
-                                      apr_dso_handle_t *handle, 
+APR_DECLARE(apr_status_t) apr_dso_sym(apr_dso_handle_sym_t *ressym,
+                                      apr_dso_handle_t *handle,
                                       const char *symname)
 {
 #if defined(DSO_USE_SHL)
@@ -233,12 +233,12 @@ APR_DECLARE(apr_status_t) apr_dso_sym(ap
     }
 
     *ressym = retval;
-    
+
     return APR_SUCCESS;
 #endif /* DSO_USE_x */
 }
 
-APR_DECLARE(const char *) apr_dso_error(apr_dso_handle_t *dso, char *buffer, 
+APR_DECLARE(const char *) apr_dso_error(apr_dso_handle_t *dso, char *buffer,
                                         apr_size_t buflen)
 {
     if (dso->errormsg) {