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 [5/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/ ...

Modified: apr/apr/trunk/poll/unix/epoll.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/poll/unix/epoll.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/poll/unix/epoll.c (original)
+++ apr/apr/trunk/poll/unix/epoll.c Sun Nov 20 07:14:38 2022
@@ -239,7 +239,7 @@ static apr_status_t impl_pollset_remove(
              ep != APR_RING_SENTINEL(&(pollset->p->query_ring),
                                      pfd_elem_t, link);
              ep = APR_RING_NEXT(ep, link)) {
-                
+
             if (descriptor->desc.s == ep->pfd.desc.s) {
                 APR_RING_REMOVE(ep, link);
                 APR_RING_INSERT_TAIL(&(pollset->p->dead_ring),
@@ -347,13 +347,13 @@ static apr_status_t impl_pollcb_create(a
                                        apr_uint32_t flags)
 {
     int fd;
-    
+
 #ifdef HAVE_EPOLL_CREATE1
     fd = epoll_create1(EPOLL_CLOEXEC);
 #else
     fd = epoll_create(size);
 #endif
-    
+
     if (fd < 0) {
         return apr_get_netos_error();
     }
@@ -379,7 +379,7 @@ static apr_status_t impl_pollcb_create(a
         }
     }
 #endif
-    
+
     pollcb->fd = fd;
     pollcb->pollset.epoll = apr_palloc(p, size * sizeof(struct epoll_event));
 
@@ -391,7 +391,7 @@ static apr_status_t impl_pollcb_add(apr_
 {
     struct epoll_event ev = { 0 };
     int ret;
-    
+
     ev.events = get_epoll_event(descriptor->reqevents);
     ev.data.ptr = (void *) descriptor;
 
@@ -403,11 +403,11 @@ static apr_status_t impl_pollcb_add(apr_
         ret = epoll_ctl(pollcb->fd, EPOLL_CTL_ADD,
                         descriptor->desc.f->filedes, &ev);
     }
-    
+
     if (ret == -1) {
         return apr_get_netos_error();
     }
-    
+
     return APR_SUCCESS;
 }
 
@@ -419,7 +419,7 @@ static apr_status_t impl_pollcb_remove(a
                                   * kernel < 2.6.9
                                   */
     int ret;
-    
+
     if (descriptor->desc_type == APR_POLL_SOCKET) {
         ret = epoll_ctl(pollcb->fd, EPOLL_CTL_DEL,
                         descriptor->desc.s->socketdes, &ev);
@@ -428,11 +428,11 @@ static apr_status_t impl_pollcb_remove(a
         ret = epoll_ctl(pollcb->fd, EPOLL_CTL_DEL,
                         descriptor->desc.f->filedes, &ev);
     }
-    
+
     if (ret < 0) {
         rv = APR_NOTFOUND;
     }
-    
+
     return rv;
 }
 
@@ -444,11 +444,11 @@ static apr_status_t impl_pollcb_poll(apr
 {
     int ret, i;
     apr_status_t rv = APR_SUCCESS;
-    
+
     if (timeout > 0) {
         timeout = (timeout + 999) / 1000;
     }
-    
+
     ret = epoll_wait(pollcb->fd, pollcb->pollset.epoll, pollcb->nalloc,
                      timeout);
     if (ret < 0) {
@@ -476,7 +476,7 @@ static apr_status_t impl_pollcb_poll(apr
             }
         }
     }
-    
+
     return rv;
 }
 

Modified: apr/apr/trunk/poll/unix/kqueue.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/poll/unix/kqueue.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/poll/unix/kqueue.c (original)
+++ apr/apr/trunk/poll/unix/kqueue.c Sun Nov 20 07:14:38 2022
@@ -368,7 +368,7 @@ static apr_status_t impl_pollcb_create(a
                                        apr_uint32_t flags)
 {
     int fd;
-    
+
     fd = kqueue();
     if (fd < 0) {
         return apr_get_netos_error();
@@ -393,10 +393,10 @@ static apr_status_t impl_pollcb_create(a
             return rv;
         }
     }
- 
+
     pollcb->fd = fd;
     pollcb->pollset.ke = (struct kevent *) apr_pcalloc(p, 2 * size * sizeof(struct kevent));
-    
+
     return APR_SUCCESS;
 }
 
@@ -406,30 +406,30 @@ static apr_status_t impl_pollcb_add(apr_
     apr_os_sock_t fd;
     struct kevent ev;
     apr_status_t rv = APR_SUCCESS;
-    
+
     if (descriptor->desc_type == APR_POLL_SOCKET) {
         fd = descriptor->desc.s->socketdes;
     }
     else {
         fd = descriptor->desc.f->filedes;
     }
-    
+
     if (descriptor->reqevents & APR_POLLIN) {
         EV_SET(&ev, fd, EVFILT_READ, EV_ADD, 0, 0, descriptor);
-        
+
         if (kevent(pollcb->fd, &ev, 1, NULL, 0, NULL) == -1) {
             rv = apr_get_netos_error();
         }
     }
-    
+
     if (descriptor->reqevents & APR_POLLOUT && rv == APR_SUCCESS) {
         EV_SET(&ev, fd, EVFILT_WRITE, EV_ADD, 0, 0, descriptor);
-        
+
         if (kevent(pollcb->fd, &ev, 1, NULL, 0, NULL) == -1) {
             rv = apr_get_netos_error();
         }
     }
-    
+
     return rv;
 }
 
@@ -439,7 +439,7 @@ static apr_status_t impl_pollcb_remove(a
     apr_status_t rv;
     struct kevent ev;
     apr_os_sock_t fd;
-    
+
     if (descriptor->desc_type == APR_POLL_SOCKET) {
         fd = descriptor->desc.s->socketdes;
     }
@@ -450,20 +450,20 @@ static apr_status_t impl_pollcb_remove(a
     rv = APR_NOTFOUND; /* unless at least one of the specified conditions is */
     if (descriptor->reqevents & APR_POLLIN) {
         EV_SET(&ev, fd, EVFILT_READ, EV_DELETE, 0, 0, NULL);
-        
+
         if (kevent(pollcb->fd, &ev, 1, NULL, 0, NULL) != -1) {
             rv = APR_SUCCESS;
         }
     }
-    
+
     if (descriptor->reqevents & APR_POLLOUT) {
         EV_SET(&ev, fd, EVFILT_WRITE, EV_DELETE, 0, 0, NULL);
-        
+
         if (kevent(pollcb->fd, &ev, 1, NULL, 0, NULL) != -1) {
             rv = APR_SUCCESS;
         }
     }
-    
+
     return rv;
 }
 
@@ -476,7 +476,7 @@ static apr_status_t impl_pollcb_poll(apr
     int ret, i;
     struct timespec tv, *tvptr;
     apr_status_t rv = APR_SUCCESS;
-    
+
     if (timeout < 0) {
         tvptr = NULL;
     }
@@ -485,7 +485,7 @@ static apr_status_t impl_pollcb_poll(apr
         tv.tv_nsec = (long) apr_time_usec(timeout) * 1000;
         tvptr = &tv;
     }
-    
+
     ret = kevent(pollcb->fd, NULL, 0, pollcb->pollset.ke, 2 * pollcb->nalloc,
                  tvptr);
 
@@ -508,9 +508,9 @@ static apr_status_t impl_pollcb_poll(apr
 
             pollfd->rtnevents = get_kqueue_revent(pollcb->pollset.ke[i].filter,
                                                   pollcb->pollset.ke[i].flags);
-            
+
             rv = func(baton, pollfd);
-            
+
             if (rv) {
                 return rv;
             }

Modified: apr/apr/trunk/poll/unix/poll.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/poll/unix/poll.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/poll/unix/poll.c (original)
+++ apr/apr/trunk/poll/unix/poll.c Sun Nov 20 07:14:38 2022
@@ -69,7 +69,7 @@ static apr_int16_t get_revent(apr_int16_
 #define SMALL_POLLSET_LIMIT  8
 
 APR_DECLARE(apr_status_t) apr_poll(apr_pollfd_t *aprset, apr_int32_t num,
-                                   apr_int32_t *nsds, 
+                                   apr_int32_t *nsds,
                                    apr_interval_time_t timeout)
 {
     int i, num_to_poll;
@@ -129,7 +129,7 @@ APR_DECLARE(apr_status_t) apr_poll(apr_p
             aprset[i].rtnevents = get_revent(pollset[i].revents);
         }
     }
-    
+
 #if !defined(HAVE_VLA) && !defined(HAVE_ALLOCA)
     if (num > SMALL_POLLSET_LIMIT) {
         free(pollset);
@@ -160,7 +160,7 @@ static apr_status_t impl_pollset_create(
                                         apr_pool_t *p,
                                         apr_uint32_t flags)
 {
-    if (flags & APR_POLLSET_THREADSAFE) {                
+    if (flags & APR_POLLSET_THREADSAFE) {
         return APR_ENOTIMPL;
     }
 
@@ -355,7 +355,7 @@ static apr_status_t impl_pollcb_add(apr_
         get_event(descriptor->reqevents);
     pollcb->copyset[pollcb->nelts] = descriptor;
     pollcb->nelts++;
-    
+
     return APR_SUCCESS;
 }
 
@@ -442,7 +442,7 @@ static apr_status_t impl_pollcb_poll(apr
                     return APR_EINTR;
                 }
 #endif
-                pollfd->rtnevents = get_revent(pollcb->pollset.ps[i].revents);                    
+                pollfd->rtnevents = get_revent(pollcb->pollset.ps[i].revents);
                 rv = func(baton, pollfd);
                 if (rv) {
                     return rv;

Modified: apr/apr/trunk/poll/unix/port.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/poll/unix/port.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/poll/unix/port.c (original)
+++ apr/apr/trunk/poll/unix/port.c Sun Nov 20 07:14:38 2022
@@ -86,7 +86,7 @@ struct apr_pollset_private_t
     volatile apr_uint32_t waiting;
 };
 
-static apr_status_t call_port_getn(int port, port_event_t list[], 
+static apr_status_t call_port_getn(int port, port_event_t list[],
                                    unsigned int max, unsigned int *nget,
                                    apr_interval_time_t timeout)
 {
@@ -108,7 +108,7 @@ static apr_status_t call_port_getn(int p
                                        */
 
     ret = port_getn(port, list, max, nget, tvptr);
-    /* Note: 32-bit port_getn() on Solaris 10 x86 returns large negative 
+    /* Note: 32-bit port_getn() on Solaris 10 x86 returns large negative
      * values instead of 0 when returning immediately.
      */
 
@@ -246,7 +246,7 @@ static apr_status_t impl_pollset_add(apr
      * wait until the next call to apr_pollset_poll().
      */
     if (apr_atomic_read32(&pollset->p->waiting)) {
-        res = port_associate(pollset->p->port_fd, PORT_SOURCE_FD, fd, 
+        res = port_associate(pollset->p->port_fd, PORT_SOURCE_FD, fd,
                              get_event(descriptor->reqevents), (void *)elem);
 
         if (res < 0) {
@@ -257,7 +257,7 @@ static apr_status_t impl_pollset_add(apr
             elem->on_query_ring = 1;
             APR_RING_INSERT_TAIL(&(pollset->p->query_ring), elem, pfd_elem_t, link);
         }
-    } 
+    }
     else {
         APR_RING_INSERT_TAIL(&(pollset->p->add_ring), elem, pfd_elem_t, link);
     }
@@ -287,10 +287,10 @@ static apr_status_t impl_pollset_remove(
     }
 
     /* Search the add ring first.  This ring is often shorter,
-     * and it often contains the descriptor being removed.  
-     * (For the common scenario where apr_pollset_poll() 
+     * and it often contains the descriptor being removed.
+     * (For the common scenario where apr_pollset_poll()
      * returns activity for the descriptor and the descriptor
-     * is then removed from the pollset, it will have just 
+     * is then removed from the pollset, it will have just
      * been moved to the add ring by apr_pollset_poll().)
      *
      * If it is on the add ring, it isn't associated with the
@@ -317,7 +317,7 @@ static apr_status_t impl_pollset_remove(
         if (res < 0) {
             /* The expected case for this failure is that another
              * thread's call to port_getn() returned this fd and
-             * disassociated the fd from the event port, and 
+             * disassociated the fd from the event port, and
              * impl_pollset_poll() is blocked on the ring lock,
              * which this thread holds.
              */
@@ -378,7 +378,7 @@ static apr_status_t impl_pollset_poll(ap
             fd = ep->pfd.desc.f->filedes;
         }
 
-        ret = port_associate(pollset->p->port_fd, PORT_SOURCE_FD, 
+        ret = port_associate(pollset->p->port_fd, PORT_SOURCE_FD,
                              fd, get_event(ep->pfd.reqevents), ep);
         if (ret < 0) {
             rv = apr_get_netos_error();
@@ -397,10 +397,10 @@ static apr_status_t impl_pollset_poll(ap
         return rv;
     }
 
-    rv = call_port_getn(pollset->p->port_fd, pollset->p->port_set, 
+    rv = call_port_getn(pollset->p->port_fd, pollset->p->port_set,
                         pollset->nalloc, &nget, timeout);
 
-    /* decrease the waiting ASAP to reduce the window for calling 
+    /* decrease the waiting ASAP to reduce the window for calling
        port_associate within apr_pollset_add() */
     apr_atomic_dec32(&pollset->p->waiting);
 

Modified: apr/apr/trunk/poll/unix/select.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/poll/unix/select.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/poll/unix/select.c (original)
+++ apr/apr/trunk/poll/unix/select.c Sun Nov 20 07:14:38 2022
@@ -199,7 +199,7 @@ static apr_status_t impl_pollset_create(
                                         apr_pool_t *p,
                                         apr_uint32_t flags)
 {
-    if (flags & APR_POLLSET_THREADSAFE) {                
+    if (flags & APR_POLLSET_THREADSAFE) {
         pollset->p = NULL;
         return APR_ENOTIMPL;
     }

Modified: apr/apr/trunk/poll/unix/z_asio.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/poll/unix/z_asio.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/poll/unix/z_asio.c (original)
+++ apr/apr/trunk/poll/unix/z_asio.c Sun Nov 20 07:14:38 2022
@@ -247,7 +247,7 @@ static apr_status_t asio_pollset_cleanup
     int rv;
 
     DBG(4, "entered\n");
-    if (pollset->flags & APR_POLLSET_THREADSAFE) { 
+    if (pollset->flags & APR_POLLSET_THREADSAFE) {
         rv = msgctl(pollset->p->msg_q, IPC_RMID, NULL);
         DBG1(4, "asio_pollset_cleanup: msgctl(IPC_RMID) returned %d\n", rv);
     }
@@ -484,7 +484,7 @@ static apr_status_t asio_pollset_remove(
     apr_status_t rv = APR_SUCCESS;
     apr_pollset_private_t *priv = pollset->p;
     /* AIO_CANCEL is synchronous, so autodata works fine.  */
-    struct aiocb cancel_a = {0};   
+    struct aiocb cancel_a = {0};
 
     int fd;
 
@@ -519,7 +519,7 @@ static apr_status_t asio_pollset_remove(
             cancel_a.aio_cflags  = 0;
             cancel_a.aio_cflags2 = 0;
 
-            /* we want the original aiocb to show up on the pollset message queue 
+            /* we want the original aiocb to show up on the pollset message queue
              * before recycling its memory to eliminate race conditions
              */
 
@@ -650,12 +650,12 @@ static apr_status_t asio_pollset_poll(ap
 
         if (elem->state == ASIO_REMOVED) {
 
-            /* 
+            /*
              * async i/o is done since it was found on prior_ready
-             * the state says the caller is done with it too 
-             * so recycle the elem 
+             * the state says the caller is done with it too
+             * so recycle the elem
              */
-             
+
             APR_RING_INSERT_TAIL(&(priv->free_ring), elem,
                                  asio_elem_t, link);
             continue;  /* do not re-add if it has been _removed */

Modified: apr/apr/trunk/random/unix/apr_random.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/random/unix/apr_random.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/random/unix/apr_random.c (original)
+++ apr/apr/trunk/random/unix/apr_random.c Sun Nov 20 07:14:38 2022
@@ -177,10 +177,10 @@ APR_DECLARE(void) apr_random_after_fork(
     apr_random_t *r;
 
     for (r = all_random; r; r = r->next)
-        /* 
-         * XXX Note: the pid does not provide sufficient entropy to 
-         * actually call this secure.  See Ben's paper referenced at 
-         * the top of this file. 
+        /*
+         * XXX Note: the pid does not provide sufficient entropy to
+         * actually call this secure.  See Ben's paper referenced at
+         * the top of this file.
          */
         mixer(r,proc->pid);
 }
@@ -188,7 +188,7 @@ APR_DECLARE(void) apr_random_after_fork(
 APR_DECLARE(apr_random_t *) apr_random_standard_new(apr_pool_t *p)
 {
     apr_random_t *r = apr_palloc(p,sizeof *r);
-    
+
     apr_random_init(r,p,apr_crypto_sha256_new(p),apr_crypto_sha256_new(p),
                     apr_crypto_sha256_new(p));
     return r;

Modified: apr/apr/trunk/random/unix/sha2.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/random/unix/sha2.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/random/unix/sha2.c (original)
+++ apr/apr/trunk/random/unix/sha2.c Sun Nov 20 07:14:38 2022
@@ -341,11 +341,11 @@ void apr__SHA256_Transform(SHA256_CTX* c
                 /* Part of the message block expansion: */
                 s0 = W256[(j+1)&0x0f];
                 s0 = sigma0_256(s0);
-                s1 = W256[(j+14)&0x0f]; 
+                s1 = W256[(j+14)&0x0f];
                 s1 = sigma1_256(s1);
 
                 /* Apply the SHA-256 compression function to update a..h */
-                T1 = h + Sigma1_256(e) + Ch(e, f, g) + K256[j] + 
+                T1 = h + Sigma1_256(e) + Ch(e, f, g) + K256[j] +
                      (W256[j&0x0f] += s1 + W256[(j+9)&0x0f] + s0);
                 T2 = Sigma0_256(a) + Maj(a, b, c);
                 h = g;
@@ -387,7 +387,7 @@ void apr__SHA256_Update(SHA256_CTX* cont
         /* Sanity check: */
         assert(context != (SHA256_CTX*)0 && data != (sha2_byte*)0);
 
-        usedspace = (unsigned int)((context->bitcount >> 3) 
+        usedspace = (unsigned int)((context->bitcount >> 3)
                                  % SHA256_BLOCK_LENGTH);
         if (usedspace > 0) {
                 /* Calculate how much free space is available in the buffer */
@@ -434,7 +434,7 @@ void apr__SHA256_Final(sha2_byte digest[
 
         /* If no digest buffer is passed, we don't bother doing this: */
         if (digest != (sha2_byte*)0) {
-                usedspace = (unsigned int)((context->bitcount >> 3) 
+                usedspace = (unsigned int)((context->bitcount >> 3)
                                          % SHA256_BLOCK_LENGTH);
 #if !APR_IS_BIGENDIAN
                 /* Convert FROM host byte order */

Modified: apr/apr/trunk/shmem/beos/shm.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/shmem/beos/shm.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/shmem/beos/shm.c (original)
+++ apr/apr/trunk/shmem/beos/shm.c Sun Nov 20 07:14:38 2022
@@ -33,20 +33,20 @@ struct apr_shm_t {
     area_id aid;
 };
 
-APR_DECLARE(apr_status_t) apr_shm_create(apr_shm_t **m, 
-                                         apr_size_t reqsize, 
-                                         const char *filename, 
+APR_DECLARE(apr_status_t) apr_shm_create(apr_shm_t **m,
+                                         apr_size_t reqsize,
+                                         const char *filename,
                                          apr_pool_t *p)
 {
     apr_size_t pagesize;
     area_id newid;
     char *addr;
     char shname[B_OS_NAME_LENGTH];
-    
+
     (*m) = (apr_shm_t *)apr_pcalloc(p, sizeof(apr_shm_t));
     /* we MUST allocate in pages, so calculate how big an area we need... */
     pagesize = ((reqsize + B_PAGE_SIZE - 1) / B_PAGE_SIZE) * B_PAGE_SIZE;
-     
+
     if (!filename) {
         int num = 0;
         snprintf(shname, B_OS_NAME_LENGTH, "apr_shmem_%ld", find_thread(NULL));
@@ -54,7 +54,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
             snprintf(shname, B_OS_NAME_LENGTH, "apr_shmem_%ld_%d",
                      find_thread(NULL), num++);
     }
-    newid = create_area(filename ? filename : shname, 
+    newid = create_area(filename ? filename : shname,
                         (void*)&addr, B_ANY_ADDRESS,
                         pagesize, B_LAZY_LOCK, B_READ_AREA|B_WRITE_AREA);
 
@@ -71,9 +71,9 @@ APR_DECLARE(apr_status_t) apr_shm_create
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_shm_create_ex(apr_shm_t **m, 
-                                            apr_size_t reqsize, 
-                                            const char *filename, 
+APR_DECLARE(apr_status_t) apr_shm_create_ex(apr_shm_t **m,
+                                            apr_size_t reqsize,
+                                            const char *filename,
                                             apr_pool_t *p,
                                             apr_int32_t flags)
 {
@@ -92,7 +92,7 @@ APR_DECLARE(apr_status_t) apr_shm_remove
                                          apr_pool_t *pool)
 {
     area_id deleteme = find_area(filename);
-    
+
     if (deleteme == B_NAME_NOT_FOUND)
         return APR_EINVAL;
 
@@ -108,7 +108,7 @@ APR_DECLARE(apr_status_t) apr_shm_delete
     else {
         return APR_ENOTIMPL;
     }
-} 
+}
 
 APR_DECLARE(apr_status_t) apr_shm_attach(apr_shm_t **m,
                                          const char *filename,
@@ -132,13 +132,13 @@ APR_DECLARE(apr_status_t) apr_shm_attach
 
     if (ti.team != ai.team) {
         area_id narea;
-        
+
         narea = clone_area(ai.name, &(ai.address), B_CLONE_ADDRESS,
                            B_READ_AREA|B_WRITE_AREA, ai.area);
 
         if (narea < B_OK)
             return narea;
-            
+
         get_area_info(narea, &ai);
         new_m->aid = narea;
         new_m->memblock = ai.address;
@@ -148,7 +148,7 @@ APR_DECLARE(apr_status_t) apr_shm_attach
     }
 
     (*m) = new_m;
-    
+
     return APR_SUCCESS;
 }
 
@@ -191,5 +191,5 @@ APR_DECLARE(apr_status_t) apr_os_shm_put
                                          apr_pool_t *pool)
 {
     return APR_ENOTIMPL;
-}    
+}
 

Modified: apr/apr/trunk/shmem/os2/shm.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/shmem/os2/shm.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/shmem/os2/shm.c (original)
+++ apr/apr/trunk/shmem/os2/shm.c Sun Nov 20 07:14:38 2022
@@ -56,9 +56,9 @@ APR_DECLARE(apr_status_t) apr_shm_create
     return APR_SUCCESS;
 }
 
-APR_DECLARE(apr_status_t) apr_shm_create_ex(apr_shm_t **m, 
-                                            apr_size_t reqsize, 
-                                            const char *filename, 
+APR_DECLARE(apr_status_t) apr_shm_create_ex(apr_shm_t **m,
+                                            apr_size_t reqsize,
+                                            const char *filename,
                                             apr_pool_t *p,
                                             apr_int32_t flags)
 {
@@ -80,7 +80,7 @@ APR_DECLARE(apr_status_t) apr_shm_remove
 APR_DECLARE(apr_status_t) apr_shm_delete(apr_shm_t *m)
 {
     return APR_ENOTIMPL;
-} 
+}
 
 APR_DECLARE(apr_status_t) apr_shm_attach(apr_shm_t **m,
                                          const char *filename,
@@ -164,5 +164,5 @@ APR_DECLARE(apr_status_t) apr_os_shm_put
 
     *m = newm;
     return APR_SUCCESS;
-}    
+}
 

Modified: apr/apr/trunk/shmem/unix/shm.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/shmem/unix/shm.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/shmem/unix/shm.c (original)
+++ apr/apr/trunk/shmem/unix/shm.c Sun Nov 20 07:14:38 2022
@@ -24,7 +24,7 @@
 #include "apr_hash.h"
 
 #if APR_USE_SHMEM_MMAP_SHM
-/* 
+/*
  *   For portable use, a shared memory object should be identified by a name of
  *   the form /somename; that is, a null-terminated string of up to NAME_MAX
  *   (i.e., 255) characters consisting of an initial slash, followed by one or
@@ -142,7 +142,7 @@ static apr_status_t shm_cleanup_owner(vo
 }
 
 APR_DECLARE(apr_status_t) apr_shm_create(apr_shm_t **m,
-                                         apr_size_t reqsize, 
+                                         apr_size_t reqsize,
                                          const char *filename,
                                          apr_pool_t *pool)
 {
@@ -171,12 +171,12 @@ APR_DECLARE(apr_status_t) apr_shm_create
         new_m = apr_palloc(pool, sizeof(apr_shm_t));
         new_m->pool = pool;
         new_m->reqsize = reqsize;
-        new_m->realsize = reqsize + 
+        new_m->realsize = reqsize +
             APR_ALIGN_DEFAULT(sizeof(apr_size_t)); /* room for metadata */
         new_m->filename = NULL;
-    
+
 #if APR_USE_SHMEM_MMAP_ZERO
-        status = apr_file_open(&file, "/dev/zero", APR_FOPEN_READ | APR_FOPEN_WRITE, 
+        status = apr_file_open(&file, "/dev/zero", APR_FOPEN_READ | APR_FOPEN_WRITE,
                                APR_FPROT_OS_DEFAULT, pool);
         if (status != APR_SUCCESS) {
             return status;
@@ -280,15 +280,15 @@ APR_DECLARE(apr_status_t) apr_shm_create
         const char *shm_name = make_shm_open_safe_name(filename, pool);
 #endif
 #if APR_USE_SHMEM_MMAP_TMP || APR_USE_SHMEM_MMAP_SHM
-        new_m->realsize = reqsize + 
+        new_m->realsize = reqsize +
             APR_ALIGN_DEFAULT(sizeof(apr_size_t)); /* room for metadata */
         /* FIXME: Ignore error for now. *
          * status = apr_file_remove(file, pool);*/
         status = APR_SUCCESS;
-    
+
 #if APR_USE_SHMEM_MMAP_TMP
         /* FIXME: Is APR_FPROT_OS_DEFAULT sufficient? */
-        status = apr_file_open(&file, filename, 
+        status = apr_file_open(&file, filename,
                                APR_FOPEN_READ | APR_FOPEN_WRITE | APR_FOPEN_CREATE | APR_FOPEN_EXCL,
                                APR_FPROT_OS_DEFAULT, pool);
         if (status != APR_SUCCESS) {
@@ -327,7 +327,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
 
         status = apr_os_file_put(&file, &tmpfd,
                                  APR_FOPEN_READ | APR_FOPEN_WRITE | APR_FOPEN_CREATE | APR_FOPEN_EXCL,
-                                 pool); 
+                                 pool);
         if (status != APR_SUCCESS) {
             return status;
         }
@@ -362,7 +362,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
         new_m->realsize = reqsize;
 
         /* FIXME: APR_FPROT_OS_DEFAULT is too permissive, switch to 600 I think. */
-        status = apr_file_open(&file, filename, 
+        status = apr_file_open(&file, filename,
                                APR_FOPEN_WRITE | APR_FOPEN_CREATE | APR_FOPEN_EXCL,
                                APR_FPROT_OS_DEFAULT, pool);
         if (status != APR_SUCCESS) {
@@ -415,7 +415,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
 
         apr_pool_cleanup_register(new_m->pool, new_m, shm_cleanup_owner,
                                   apr_pool_cleanup_null);
-        *m = new_m; 
+        *m = new_m;
         return APR_SUCCESS;
 
 #else
@@ -424,9 +424,9 @@ APR_DECLARE(apr_status_t) apr_shm_create
     }
 }
 
-APR_DECLARE(apr_status_t) apr_shm_create_ex(apr_shm_t **m, 
-                                            apr_size_t reqsize, 
-                                            const char *filename, 
+APR_DECLARE(apr_status_t) apr_shm_create_ex(apr_shm_t **m,
+                                            apr_size_t reqsize,
+                                            const char *filename,
                                             apr_pool_t *p,
                                             apr_int32_t flags)
 {
@@ -438,7 +438,7 @@ APR_DECLARE(apr_status_t) apr_shm_remove
 {
 #if APR_USE_SHMEM_SHMGET
     apr_status_t status;
-    apr_file_t *file;  
+    apr_file_t *file;
     key_t shmkey;
     int shmid;
 #endif
@@ -452,7 +452,7 @@ APR_DECLARE(apr_status_t) apr_shm_remove
     }
     return APR_SUCCESS;
 #elif APR_USE_SHMEM_SHMGET
-    /* Presume that the file already exists; just open for writing */    
+    /* Presume that the file already exists; just open for writing */
     status = apr_file_open(&file, filename, APR_FOPEN_WRITE,
                            APR_FPROT_OS_DEFAULT, pool);
     if (status) {
@@ -490,7 +490,7 @@ shm_remove_failed:
     /* No support for anonymous shm */
     return APR_ENOTIMPL;
 #endif
-} 
+}
 
 APR_DECLARE(apr_status_t) apr_shm_delete(apr_shm_t *m)
 {
@@ -500,7 +500,7 @@ APR_DECLARE(apr_status_t) apr_shm_delete
     else {
         return APR_ENOTIMPL;
     }
-} 
+}
 
 APR_DECLARE(apr_status_t) apr_shm_destroy(apr_shm_t *m)
 {
@@ -563,13 +563,13 @@ APR_DECLARE(apr_status_t) apr_shm_attach
 
         status = apr_os_file_put(&file, &tmpfd,
                                  APR_READ | APR_WRITE,
-                                 pool); 
+                                 pool);
         if (status != APR_SUCCESS) {
             return status;
         }
 
 #elif APR_USE_SHMEM_MMAP_TMP
-        status = apr_file_open(&file, filename, 
+        status = apr_file_open(&file, filename,
                                APR_FOPEN_READ | APR_FOPEN_WRITE,
                                APR_FPROT_OS_DEFAULT, pool);
         if (status != APR_SUCCESS) {
@@ -602,7 +602,7 @@ APR_DECLARE(apr_status_t) apr_shm_attach
         new_m->base = mmap(NULL, new_m->realsize, PROT_READ | PROT_WRITE,
                            MAP_SHARED, tmpfd, 0);
         /* FIXME: check for errors */
-        
+
         status = apr_file_close(file);
         if (status != APR_SUCCESS) {
             return status;
@@ -624,7 +624,7 @@ APR_DECLARE(apr_status_t) apr_shm_attach
 
         new_m = apr_palloc(pool, sizeof(apr_shm_t));
 
-        status = apr_file_open(&file, filename, 
+        status = apr_file_open(&file, filename,
                                APR_FOPEN_READ, APR_FPROT_OS_DEFAULT, pool);
         if (status != APR_SUCCESS) {
             return status;
@@ -727,5 +727,5 @@ APR_DECLARE(apr_status_t) apr_os_shm_put
                                          apr_pool_t *pool)
 {
     return APR_ENOTIMPL;
-}    
+}
 

Modified: apr/apr/trunk/shmem/win32/shm.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/shmem/win32/shm.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/shmem/win32/shm.c (original)
+++ apr/apr/trunk/shmem/win32/shm.c Sun Nov 20 07:14:38 2022
@@ -41,7 +41,7 @@ static apr_status_t shm_cleanup(void* sh
 {
     apr_status_t rv = APR_SUCCESS;
     apr_shm_t *m = shm;
-    
+
     if (!UnmapViewOfFile(m->memblk)) {
         rv = apr_get_os_error();
     }
@@ -140,7 +140,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
         SYSTEM_INFO si;
         GetSystemInfo(&si);
         memblock = si.dwAllocationGranularity;
-    }   
+    }
 
     /* Compute the granualar multiple of the pagesize */
     size = memblock * (1 + (reqsize - 1) / memblock);
@@ -159,7 +159,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
     else {
         int global;
 
-        /* Do file backed, which is not an inherited handle 
+        /* Do file backed, which is not an inherited handle
          * While we could open APR_FOPEN_EXCL, it doesn't seem that Unix
          * ever did.  Ignore that error here, but fail later when
          * we discover we aren't the creator of the file map object.
@@ -189,7 +189,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
         mapkey = res_name_from_filename(file, global, pool);
     }
 
-	hMap = CreateFileMappingW(hFile, NULL, PAGE_READWRITE, 
+	hMap = CreateFileMappingW(hFile, NULL, PAGE_READWRITE,
 							  sizehi, sizelo, mapkey);
     err = apr_get_os_error();
 
@@ -204,14 +204,14 @@ APR_DECLARE(apr_status_t) apr_shm_create
     if (!hMap) {
         return err;
     }
-    
+
     base = MapViewOfFile(hMap, FILE_MAP_READ | FILE_MAP_WRITE,
                          0, 0, size);
     if (!base) {
         CloseHandle(hMap);
         return apr_get_os_error();
     }
-    
+
     *m = (apr_shm_t *) apr_palloc(pool, sizeof(apr_shm_t));
     (*m)->pool = pool;
     (*m)->hMap = hMap;
@@ -220,12 +220,12 @@ APR_DECLARE(apr_status_t) apr_shm_create
 
     (*m)->usrmem = (char*)base + sizeof(memblock_t);
     (*m)->length = reqsize - sizeof(memblock_t);;
-    
+
     (*m)->memblk->length = (*m)->length;
     (*m)->memblk->size = (*m)->size;
     (*m)->filename = file ? apr_pstrdup(pool, file) : NULL;
 
-    apr_pool_cleanup_register((*m)->pool, *m, 
+    apr_pool_cleanup_register((*m)->pool, *m,
                               shm_cleanup, apr_pool_cleanup_null);
     return APR_SUCCESS;
 }
@@ -238,7 +238,7 @@ APR_DECLARE(apr_status_t) apr_shm_create
     return apr_shm_create_ex(m, reqsize, file, pool, 0);
 }
 
-APR_DECLARE(apr_status_t) apr_shm_destroy(apr_shm_t *m) 
+APR_DECLARE(apr_status_t) apr_shm_destroy(apr_shm_t *m)
 {
     apr_status_t rv = shm_cleanup(m);
     apr_pool_cleanup_kill(m->pool, m, shm_cleanup);
@@ -259,7 +259,7 @@ APR_DECLARE(apr_status_t) apr_shm_delete
     else {
         return APR_ENOTIMPL;
     }
-} 
+}
 
 static apr_status_t shm_attach_internal(apr_shm_t **m,
                                         const char *file,
@@ -280,13 +280,13 @@ static apr_status_t shm_attach_internal(
     if (!hMap) {
         return apr_get_os_error();
     }
-    
+
     base = MapViewOfFile(hMap, FILE_MAP_READ | FILE_MAP_WRITE, 0, 0, 0);
     if (!base) {
         CloseHandle(hMap);
         return apr_get_os_error();
     }
-    
+
     *m = (apr_shm_t *) apr_palloc(pool, sizeof(apr_shm_t));
     (*m)->pool = pool;
     (*m)->memblk = base;
@@ -297,7 +297,7 @@ static apr_status_t shm_attach_internal(
     (*m)->usrmem = (char*)base + sizeof(memblock_t);
     (*m)->filename = NULL;
 
-    apr_pool_cleanup_register((*m)->pool, *m, 
+    apr_pool_cleanup_register((*m)->pool, *m,
                               shm_cleanup, apr_pool_cleanup_null);
     return APR_SUCCESS;
 }
@@ -388,7 +388,7 @@ APR_DECLARE(apr_status_t) apr_os_shm_put
     if (!base) {
         return apr_get_os_error();
     }
-    
+
     *m = (apr_shm_t *) apr_palloc(pool, sizeof(apr_shm_t));
     (*m)->pool = pool;
     (*m)->hMap = *osshm;
@@ -399,8 +399,8 @@ APR_DECLARE(apr_status_t) apr_os_shm_put
     (*m)->length = (*m)->memblk->length;
     (*m)->filename = NULL;
 
-    apr_pool_cleanup_register((*m)->pool, *m, 
+    apr_pool_cleanup_register((*m)->pool, *m,
                               shm_cleanup, apr_pool_cleanup_null);
     return APR_SUCCESS;
-}    
+}
 

Modified: apr/apr/trunk/strings/apr_cpystrn.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_cpystrn.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_cpystrn.c (original)
+++ apr/apr/trunk/strings/apr_cpystrn.c Sun Nov 20 07:14:38 2022
@@ -70,10 +70,10 @@ APR_DECLARE(char *) apr_cpystrn(char *ds
 
 /*
  * This function provides a way to parse a generic argument string
- * into a standard argv[] form of argument list. It respects the 
+ * into a standard argv[] form of argument list. It respects the
  * usual "whitespace" and quoteing rules. In the future this could
  * be expanded to include support for the apr_call_exec command line
- * string processing (including converting '+' to ' ' and doing the 
+ * string processing (including converting '+' to ' ' and doing the
  * url processing. It does not currently support this function.
  *
  *    token_context: Context from which pool allocations will occur.
@@ -82,9 +82,9 @@ APR_DECLARE(char *) apr_cpystrn(char *ds
  *                   of pointers to strings (ie. &(char *argv[]).
  *                   This value will be allocated from the contexts
  *                   pool and filled in with copies of the tokens
- *                   found during parsing of the arg_str. 
+ *                   found during parsing of the arg_str.
  */
-APR_DECLARE(apr_status_t) apr_tokenize_to_argv(const char *arg_str, 
+APR_DECLARE(apr_status_t) apr_tokenize_to_argv(const char *arg_str,
                                             char ***argv_out,
                                             apr_pool_t *token_context)
 {
@@ -127,7 +127,7 @@ APR_DECLARE(apr_status_t) apr_tokenize_t
             break; \
         } \
     }
- 
+
 /* REMOVE_ESCAPE_CHARS:
  * Compresses the arg string to remove all of the '\' escape chars.
  * The final argv strings should not have any extra escape chars in it.
@@ -151,7 +151,7 @@ APR_DECLARE(apr_status_t) apr_tokenize_t
     ct = cp;
 
     /* This is ugly and expensive, but if anyone wants to figure a
-     * way to support any number of args without counting and 
+     * way to support any number of args without counting and
      * allocating, please go ahead and change the code.
      *
      * Must account for the trailing NULL arg.
@@ -220,7 +220,7 @@ APR_DECLARE(const char *) apr_filepath_n
 APR_DECLARE(char *) apr_collapse_spaces(char *dest, const char *src)
 {
     while (*src) {
-        if (!apr_isspace(*src)) 
+        if (!apr_isspace(*src))
             *dest++ = *src;
         ++src;
     }

Modified: apr/apr/trunk/strings/apr_cstr.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_cstr.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_cstr.c (original)
+++ apr/apr/trunk/strings/apr_cstr.c Sun Nov 20 07:14:38 2022
@@ -238,7 +238,7 @@ static const unsigned char ucharmap[256]
  * conformance, arbitrary election of an ISO-8859-1 ordering, and
  * very arbitrary control code assignments into C1 to achieve
  * identity and a reversible mapping of code points),
- * then folding the equivalences of ASCII 41-5A into 61-7A, 
+ * then folding the equivalences of ASCII 41-5A into 61-7A,
  * presenting comparison results in a somewhat ISO/IEC 10646
  * (ASCII-like) order, depending on the EBCDIC code page in use.
  *

Modified: apr/apr/trunk/strings/apr_fnmatch.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_fnmatch.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_fnmatch.c (original)
+++ apr/apr/trunk/strings/apr_fnmatch.c Sun Nov 20 07:14:38 2022
@@ -12,7 +12,7 @@
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- */ 
+ */
 
 
 /* Derived from The Open Group Base Specifications Issue 7, IEEE Std 1003.1-2008
@@ -22,9 +22,9 @@
  * Filename pattern matches defined in section 2.13, "Pattern Matching Notation"
  * from chapter 2. "Shell Command Language"
  *   http://pubs.opengroup.org/onlinepubs/9699919799/utilities/V3_chap02.html#tag_18_13
- * where; 1. A bracket expression starting with an unquoted <circumflex> '^' 
- * character CONTINUES to specify a non-matching list; 2. an explicit <period> '.' 
- * in a bracket expression matching list, e.g. "[.abc]" does NOT match a leading 
+ * where; 1. A bracket expression starting with an unquoted <circumflex> '^'
+ * character CONTINUES to specify a non-matching list; 2. an explicit <period> '.'
+ * in a bracket expression matching list, e.g. "[.abc]" does NOT match a leading
  * <period> in a filename; 3. a <left-square-bracket> '[' which does not introduce
  * a valid bracket expression is treated as an ordinary character; 4. a differing
  * number of consecutive slashes within pattern and string will NOT match;
@@ -33,10 +33,10 @@
  * Bracket expansion defined in section 9.3.5, "RE Bracket Expression",
  * from chapter 9, "Regular Expressions"
  *   http://pubs.opengroup.org/onlinepubs/9699919799/basedefs/V1_chap09.html#tag_09_03_05
- * with no support for collating symbols, equivalence class expressions or 
- * character class expressions.  A partial range expression with a leading 
+ * with no support for collating symbols, equivalence class expressions or
+ * character class expressions.  A partial range expression with a leading
  * hyphen following a valid range expression will match only the ordinary
- * <hyphen> and the ending character (e.g. "[a-m-z]" will match characters 
+ * <hyphen> and the ending character (e.g. "[a-m-z]" will match characters
  * 'a' through 'm', a <hyphen> '-', or a 'z').
  *
  * NOTE: Only POSIX/C single byte locales are correctly supported at this time.
@@ -65,7 +65,7 @@
 
 
 /* Most MBCS/collation/case issues handled here.  Wildcard '*' is not handled.
- * EOS '\0' and the FNM_PATHNAME '/' delimiters are not advanced over, 
+ * EOS '\0' and the FNM_PATHNAME '/' delimiters are not advanced over,
  * however the "\/" sequence is advanced to '/'.
  *
  * Both pattern and string are **char to support pointer increment of arbitrary
@@ -116,7 +116,7 @@ static APR_INLINE int fnmatch_ch(const c
                 break;
 
 leadingclosebrace:
-            /* Look at only well-formed range patterns; 
+            /* Look at only well-formed range patterns;
              * "x-]" is not allowed unless escaped ("x-\]")
              * XXX: Fix for locale/MBCS character width
              */
@@ -125,7 +125,7 @@ leadingclosebrace:
                 startch = *pattern;
                 *pattern += (escape && ((*pattern)[2] == '\\')) ? 3 : 2;
 
-                /* NOT a properly balanced [expr] pattern, EOS terminated 
+                /* NOT a properly balanced [expr] pattern, EOS terminated
                  * or ranges containing a slash in FNM_PATHNAME mode pattern
                  * fall out to to the rewind and test '[' literal code path
                  */
@@ -137,7 +137,7 @@ leadingclosebrace:
                     result = 0;
                 else if (nocase && (isupper(**string) || isupper(*startch)
                                                       || isupper(**pattern))
-                            && (tolower(**string) >= tolower(*startch)) 
+                            && (tolower(**string) >= tolower(*startch))
                             && (tolower(**string) <= tolower(**pattern)))
                     result = 0;
 
@@ -220,7 +220,7 @@ APR_DECLARE(int) apr_fnmatch(const char
         if (slash && (*pattern == '/') && (*string == '/')) {
             ++pattern;
             ++string;
-        }            
+        }
 
 firstsegment:
         /* At the beginning of each segment, validate leading period behavior.
@@ -289,7 +289,7 @@ firstsegment:
                  */
                 for (matchptr = pattern, matchlen = 0; 1; ++matchlen)
                 {
-                    if ((*matchptr == '\0') 
+                    if ((*matchptr == '\0')
                         || (slash && ((*matchptr == '/')
                                       || (escape && (*matchptr == '\\')
                                                  && (matchptr[1] == '/')))))
@@ -321,7 +321,7 @@ firstsegment:
 
                     /* Skip forward in pattern by a single character match
                      * Use a dummy fnmatch_ch() test to count one "[range]" escape
-                     */ 
+                     */
                     /* XXX: Adjust for MBCS */
                     if (escape && (*matchptr == '\\') && matchptr[1]) {
                         matchptr += 2;
@@ -357,7 +357,7 @@ firstsegment:
                 if (!fnmatch_ch(&pattern, &string, flags))
                     continue;
 
-                /* Failed to match, loop against next char offset of string segment 
+                /* Failed to match, loop against next char offset of string segment
                  * until not enough string chars remain to match the fixed pattern
                  */
                 if (wild) {
@@ -396,7 +396,7 @@ firstsegment:
 /* This function is an Apache addition
  * return non-zero if pattern has any glob chars in it
  * @bug Function does not distinguish for FNM_PATHNAME mode, which renders
- * a false positive for test[/]this (which is not a range, but 
+ * a false positive for test[/]this (which is not a range, but
  * seperate test[ and ]this segments and no glob.)
  * @bug Function does not distinguish for non-FNM_ESCAPE mode.
  * @bug Function does not parse []] correctly
@@ -435,7 +435,7 @@ APR_DECLARE(int) apr_fnmatch_test(const
 
 
 /* Find all files matching the specified pattern */
-APR_DECLARE(apr_status_t) apr_match_glob(const char *pattern, 
+APR_DECLARE(apr_status_t) apr_match_glob(const char *pattern,
                                          apr_array_header_t **result,
                                          apr_pool_t *p)
 {
@@ -454,7 +454,7 @@ APR_DECLARE(apr_status_t) apr_match_glob
      * I get to it.  rbb
      */
     char *idx = strrchr(pattern, '/');
-    
+
     if (idx == NULL) {
         idx = strrchr(pattern, '\\');
     }

Modified: apr/apr/trunk/strings/apr_snprintf.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_snprintf.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_snprintf.c (original)
+++ apr/apr/trunk/strings/apr_snprintf.c Sun Nov 20 07:14:38 2022
@@ -83,13 +83,13 @@ static const char null_string[] = "(null
 #define NDIG 80
 
 /* buf must have at least NDIG bytes */
-static char *apr_cvt(double arg, int ndigits, int *decpt, int *sign, 
+static char *apr_cvt(double arg, int ndigits, int *decpt, int *sign,
                      int eflag, char *buf)
 {
     register int r2;
     double fi, fj;
     register char *p, *p1;
-    
+
     if (ndigits >= NDIG - 1)
         ndigits = NDIG - 2;
     r2 = 0;
@@ -340,7 +340,7 @@ static char *conv_10(register apr_int32_
         *is_negative = (num < 0);
 
         /*
-         * On a 2's complement machine, negating the most negative integer 
+         * On a 2's complement machine, negating the most negative integer
          * results in a number that cannot be represented as a signed integer.
          * Here is what we do to obtain the number's magnitude:
          *      a. add 1 to the number
@@ -355,7 +355,7 @@ static char *conv_10(register apr_int32_
     }
 
     /*
-     * We use a do-while loop so that we write at least 1 digit 
+     * We use a do-while loop so that we write at least 1 digit
      */
     do {
         register apr_uint32_t new_magnitude = magnitude / 10;
@@ -392,7 +392,7 @@ static char *conv_10_quad(apr_int64_t nu
         *is_negative = (num < 0);
 
         /*
-         * On a 2's complement machine, negating the most negative integer 
+         * On a 2's complement machine, negating the most negative integer
          * results in a number that cannot be represented as a signed integer.
          * Here is what we do to obtain the number's magnitude:
          *      a. add 1 to the number
@@ -407,7 +407,7 @@ static char *conv_10_quad(apr_int64_t nu
     }
 
     /*
-     * We use a do-while loop so that we write at least 1 digit 
+     * We use a do-while loop so that we write at least 1 digit
      */
     do {
         apr_uint64_t new_magnitude = magnitude / 10;
@@ -823,7 +823,7 @@ APR_DECLARE(int) apr_vformatter(int (*fl
                 (sizeof(APR_OFF_T_FMT) == 3 &&
                  fmt[0] == APR_OFF_T_FMT[0]) ||
                 (sizeof(APR_OFF_T_FMT) > 4 &&
-                 strncmp(fmt, APR_OFF_T_FMT, 
+                 strncmp(fmt, APR_OFF_T_FMT,
                          sizeof(APR_OFF_T_FMT) - 2) == 0))) {
                 /* Need to account for trailing 'd' and null in sizeof() */
                 var_type = IS_QUAD;
@@ -835,7 +835,7 @@ APR_DECLARE(int) apr_vformatter(int (*fl
                 (sizeof(APR_INT64_T_FMT) == 3 &&
                  fmt[0] == APR_INT64_T_FMT[0]) ||
                 (sizeof(APR_INT64_T_FMT) > 4 &&
-                 strncmp(fmt, APR_INT64_T_FMT, 
+                 strncmp(fmt, APR_INT64_T_FMT,
                          sizeof(APR_INT64_T_FMT) - 2) == 0)) {
                 /* Need to account for trailing 'd' and null in sizeof() */
                 var_type = IS_QUAD;
@@ -1323,7 +1323,7 @@ APR_DECLARE(int) apr_vformatter(int (*fl
             }
 
             /*
-             * Print the string s. 
+             * Print the string s.
              */
             if (print_something == YES) {
                 for (i = s_len; i != 0; i--) {
@@ -1352,7 +1352,7 @@ static int snprintf_flush(apr_vformatter
 }
 
 
-APR_DECLARE_NONSTD(int) apr_snprintf(char *buf, apr_size_t len, 
+APR_DECLARE_NONSTD(int) apr_snprintf(char *buf, apr_size_t len,
                                      const char *format, ...)
 {
     int cc;

Modified: apr/apr/trunk/strings/apr_strings.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_strings.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_strings.c (original)
+++ apr/apr/trunk/strings/apr_strings.c Sun Nov 20 07:14:38 2022
@@ -160,7 +160,7 @@ APR_DECLARE_NONSTD(char *) apr_pstrcat(a
         else {
             len = strlen(argp);
         }
- 
+
         memcpy(cp, argp, len);
         cp += len;
     }
@@ -196,7 +196,7 @@ APR_DECLARE(char *) apr_pstrcatv(apr_poo
 
     /* Allocate the required string */
     res = (char *) apr_palloc(a, len + 1);
-    
+
     /* Pass two --- copy the argument strings into the result space */
     src = vec;
     dst = res;
@@ -325,7 +325,7 @@ APR_DECLARE(apr_int64_t) apr_strtoi64(co
      * in both the mult and add/sub operation.  Unlike the bsd impl,
      * we also work strictly in a signed int64 word as we haven't
      * implemented the unsigned type in win32.
-     * 
+     *
      * Set 'any' if any `digits' consumed; make it negative to indicate
      * overflow.
      */
@@ -352,7 +352,7 @@ APR_DECLARE(apr_int64_t) apr_strtoi64(co
 	else if (c >= 's' && c <= 'z')
 	    c -= 'z' - 28;
 #else
-#error "CANNOT COMPILE apr_strtoi64(), only ASCII and EBCDIC supported" 
+#error "CANNOT COMPILE apr_strtoi64(), only ASCII and EBCDIC supported"
 #endif
 	else
 	    break;

Modified: apr/apr/trunk/strings/apr_strnatcmp.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_strnatcmp.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_strnatcmp.c (original)
+++ apr/apr/trunk/strings/apr_strnatcmp.c Sun Nov 20 07:14:38 2022
@@ -37,7 +37,7 @@ static int
 compare_right(char const *a, char const *b)
 {
      int bias = 0;
-     
+
      /* The longest run of digits wins.  That aside, the greatest
 	value wins, but we can't know that it will until we've scanned
 	both numbers to know that they have the same magnitude, so we
@@ -80,7 +80,7 @@ compare_left(char const *a, char const *
 	  else if (*a > *b)
 	       return +1;
      }
-	  
+
      return 0;
 }
 
@@ -124,7 +124,7 @@ static int strnatcmp0(char const *a, cha
 	       ca = apr_toupper(ca);
 	       cb = apr_toupper(cb);
 	  }
-	  
+
 	  if (ca < cb)
 	       return -1;
 	  else if (ca > cb)

Modified: apr/apr/trunk/strings/apr_strtok.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/strings/apr_strtok.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/strings/apr_strtok.c (original)
+++ apr/apr/trunk/strings/apr_strtok.c Sun Nov 20 07:14:38 2022
@@ -41,7 +41,7 @@ APR_DECLARE(char *) apr_strtok(char *str
     token = str;
 
     /* skip valid token characters to terminate token and
-     * prepare for the next call (will terminate at '\0) 
+     * prepare for the next call (will terminate at '\0)
      */
     *last = token + 1;
     while (**last && !strchr(sep, **last))

Modified: apr/apr/trunk/tables/apr_hash.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/tables/apr_hash.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/tables/apr_hash.c (original)
+++ apr/apr/trunk/tables/apr_hash.c Sun Nov 20 07:14:38 2022
@@ -213,7 +213,7 @@ static unsigned int hashfunc_default(con
     const unsigned char *key = (const unsigned char *)char_key;
     const unsigned char *p;
     apr_ssize_t i;
-    
+
     /*
      * This is the popular `times 33' hash algorithm which is used by
      * perl and also appears in Berkeley DB. This is one of the best

Modified: apr/apr/trunk/tables/apr_skiplist.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/tables/apr_skiplist.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/tables/apr_skiplist.c (original)
+++ apr/apr/trunk/tables/apr_skiplist.c Sun Nov 20 07:14:38 2022
@@ -29,7 +29,7 @@ typedef struct {
     apr_skiplistnode **data;
     size_t size, pos;
     apr_pool_t *p;
-} apr_skiplist_q; 
+} apr_skiplist_q;
 
 struct apr_skiplist {
     apr_skiplist_compare compare;

Modified: apr/apr/trunk/tables/apr_tables.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/tables/apr_tables.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/tables/apr_tables.c (original)
+++ apr/apr/trunk/tables/apr_tables.c Sun Nov 20 07:14:38 2022
@@ -100,7 +100,7 @@ APR_DECLARE(void *) apr_array_pop(apr_ar
     if (apr_is_empty_array(arr)) {
         return NULL;
     }
-   
+
     return arr->elts + (arr->elt_size * (--arr->nelts));
 }
 
@@ -366,7 +366,7 @@ typedef struct
 } table_getm_t;
 
 /*
- * NOTICE: if you tweak this you should look at is_empty_table() 
+ * NOTICE: if you tweak this you should look at is_empty_table()
  * and table_elts() in alloc.h
  */
 #ifdef MAKE_TABLE_PROFILE
@@ -895,15 +895,15 @@ APR_DECLARE(apr_table_t *) apr_table_ove
  * caller can pass additional info for the task.
  *
  * ADDENDUM for apr_table_vdo():
- * 
+ *
  * The caching api will allow a user to walk the header values:
  *
- * apr_status_t apr_cache_el_header_walk(apr_cache_el *el, 
+ * apr_status_t apr_cache_el_header_walk(apr_cache_el *el,
  *    int (*comp)(void *, const char *, const char *), void *rec, ...);
  *
  * So it can be ..., however from there I use a  callback that use a va_list:
  *
- * apr_status_t (*cache_el_header_walk)(apr_cache_el *el, 
+ * apr_status_t (*cache_el_header_walk)(apr_cache_el *el,
  *    int (*comp)(void *, const char *, const char *), void *rec, va_list);
  *
  * To pass those ...'s on down to the actual module that will handle walking
@@ -911,7 +911,7 @@ APR_DECLARE(apr_table_t *) apr_table_ove
  * rather than reimplementing apr_table_do (which IMHO would be bad) I just
  * called it with the va_list. For mod_shmem_cache I don't need it since I
  * can't use apr_table's, but mod_file_cache should (though a good hash would
- * be better, but that's a different issue :). 
+ * be better, but that's a different issue :).
  *
  * So to make mod_file_cache easier to maintain, it's a good thing
  */
@@ -926,7 +926,7 @@ APR_DECLARE_NONSTD(int) apr_table_do(apr
     va_end(vp);
 
     return rv;
-} 
+}
 
 /* XXX: do the semantics of this routine make any sense?  Right now,
  * if the caller passed in a non-empty va_list of keys to search for,
@@ -1000,7 +1000,7 @@ APR_DECLARE(int) apr_table_vdo(apr_table
 }
 
 static apr_table_entry_t **table_mergesort(apr_pool_t *pool,
-                                           apr_table_entry_t **values, 
+                                           apr_table_entry_t **values,
                                            apr_size_t n)
 {
     /* Bottom-up mergesort, based on design in Sedgewick's "Algorithms

Modified: apr/apr/trunk/test/abts.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/abts.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/abts.c (original)
+++ apr/apr/trunk/test/abts.c Sun Nov 20 07:14:38 2022
@@ -97,7 +97,7 @@ abts_suite *abts_add_suite(abts_suite *s
     char *p;
     const char *suite_name;
     curr_char = 0;
-    
+
     /* Only end the suite if we actually ran it */
     if (suite && suite->tail &&!suite->tail->not_run) {
         end_suite(suite);
@@ -108,7 +108,7 @@ abts_suite *abts_add_suite(abts_suite *s
     subsuite->failed = 0;
     subsuite->skipped = 0;
     subsuite->next = NULL;
-    /* suite_name_full may be an absolute path depending on __FILE__ 
+    /* suite_name_full may be an absolute path depending on __FILE__
      * expansion */
     suite_name = strrchr(suite_name_full, '/');
     if (!suite_name) {
@@ -131,7 +131,7 @@ abts_suite *abts_add_suite(abts_suite *s
     if (list_tests) {
         fprintf(stdout, "%s\n", subsuite->name);
     }
-    
+
     subsuite->not_run = 0;
 
     if (suite == NULL) {
@@ -185,12 +185,12 @@ void abts_run_test(abts_suite *ts, test_
     tc.failed = 0;
     tc.skipped = 0;
     tc.suite = ss;
-    
+
     ss->num_test++;
     update_status();
 
     f(&tc, value);
-    
+
     if (tc.failed) {
         ss->failed++;
     }
@@ -373,7 +373,7 @@ void abts_ptr_notnull(abts_case *tc, con
         fflush(stderr);
     }
 }
- 
+
 void abts_ptr_equal(abts_case *tc, const void *expected, const void *actual, int lineno)
 {
     update_status();
@@ -456,7 +456,7 @@ int main(int argc, const char *const arg
     int rv;
     int list_provided = 0;
     abts_suite *suite = NULL;
-   
+
     initialize();
 
     quiet = !isatty(STDOUT_FILENO);
@@ -503,4 +503,4 @@ int main(int argc, const char *const arg
     abts_free_suite(suite);
     return rv;
 }
-       
+

Modified: apr/apr/trunk/test/echod.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/echod.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/echod.c (original)
+++ apr/apr/trunk/test/echod.c Sun Nov 20 07:14:38 2022
@@ -28,7 +28,7 @@
 
 #define BUF_SIZE 4096
 
-static void reportError(const char *msg, apr_status_t rv, 
+static void reportError(const char *msg, apr_status_t rv,
                         apr_pool_t *pool)
 {
     fprintf(stderr, "%s\nError: %d\n'%s'\n", msg, rv,

Modified: apr/apr/trunk/test/globalmutexchild.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/globalmutexchild.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/globalmutexchild.c (original)
+++ apr/apr/trunk/test/globalmutexchild.c Sun Nov 20 07:14:38 2022
@@ -37,7 +37,7 @@ int main(int argc, const char * const ar
 
     apr_initialize();
     atexit(apr_terminate);
-    
+
     apr_pool_create(&p, NULL);
     if (argc >= 2) {
         mech = (apr_lockmech_e)apr_strtoi64(argv[1], NULL, 0);
@@ -50,7 +50,7 @@ int main(int argc, const char * const ar
         exit(-rv);
     }
     apr_global_mutex_child_init(&global_lock, LOCKNAME, p);
-    
+
     while (1) {
         apr_global_mutex_lock(global_lock);
         if (i == MAX_ITER) {

Modified: apr/apr/trunk/test/internal/testregex.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/internal/testregex.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/internal/testregex.c (original)
+++ apr/apr/trunk/test/internal/testregex.c Sun Nov 20 07:14:38 2022
@@ -34,14 +34,14 @@ int main( int argc, char** argv) {
     apr_time_t now;
     apr_time_t end;
     apr_hash_t *h;
-    
+
 
     if (argc !=4 ) {
             fprintf(stderr, "Usage %s match string #iterations\n",argv[0]);
             return -1;
     }
     iters = atoi( argv[3]);
-    
+
     apr_initialize() ;
     atexit(apr_terminate);
     if (apr_pool_create(&context, NULL) != APR_SUCCESS) {
@@ -86,6 +86,6 @@ int main( int argc, char** argv) {
     }
     end=apr_time_now();
     puts(apr_psprintf( context, "Time to run %d hash (find)'s    %8lld\n",iters,end-now));
- 
+
     return 0;
 }

Modified: apr/apr/trunk/test/internal/testutf.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/internal/testutf.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/internal/testutf.c (original)
+++ apr/apr/trunk/test/internal/testutf.c Sun Nov 20 07:14:38 2022
@@ -82,7 +82,7 @@ void displaynw(struct testval *f, struct
     apr_size_t i;
     for (i = 0; i < f->nl; ++i)
         t += sprintf(t, "%02X ", f->n[i]);
-    *(t++) = '-'; 
+    *(t++) = '-';
     for (i = 0; i < l->nl; ++i)
         t += sprintf(t, " %02X", l->n[i]);
     *(t++) = ' ';
@@ -98,7 +98,7 @@ void displaynw(struct testval *f, struct
 }
 
 /*
- *  Test every possible byte value. 
+ *  Test every possible byte value.
  *  If the test passes or fails at this byte value we are done.
  *  Otherwise iterate test_nrange again, appending another byte.
  */
@@ -107,10 +107,10 @@ void test_nrange(struct testval *p)
     struct testval f, l, s;
     apr_status_t rc;
     int success = 0;
-    
+
     memcpy (&s, p, sizeof(s));
-    ++s.nl;    
-    
+    ++s.nl;
+
     do {
         apr_size_t nl = s.nl, wl = sizeof(s.w) / 2;
         rc = apr_conv_utf8_to_utf16(s.n, &nl, s.w, &wl);
@@ -121,13 +121,13 @@ void test_nrange(struct testval *p)
                 success = -1;
             }
             else {
-                if (s.wl != l.wl 
+                if (s.wl != l.wl
                  || memcmp(s.w, l.w, (s.wl - 1) * 2) != 0
                  || s.w[s.wl - 1] != l.w[l.wl - 1] + 1) {
                     displaynw(&f, &l);
                     memcpy(&f, &s, sizeof(s));
                 }
-            }            
+            }
             memcpy(&l, &s, sizeof(s));
         }
         else {
@@ -147,10 +147,10 @@ void test_nrange(struct testval *p)
     }
 }
 
-/* 
- *  Test every possible word value. 
+/*
+ *  Test every possible word value.
  *  Once we are finished, retest every possible word value.
- *  if the test fails on the following null word, iterate test_nrange 
+ *  if the test fails on the following null word, iterate test_nrange
  *  again, appending another word.
  *  This assures the output order of the two tests are in sync.
  */
@@ -159,12 +159,12 @@ void test_wrange(struct testval *p)
     struct testval f, l, s;
     apr_status_t rc;
     int success = 0;
-    
+
     memcpy (&s, p, sizeof(s));
-    ++s.wl;    
-    
+    ++s.wl;
+
     do {
-        apr_size_t nl = sizeof(s.n), wl = s.wl;        
+        apr_size_t nl = sizeof(s.n), wl = s.wl;
         rc = apr_conv_utf16_to_utf8(s.w, &wl, s.n, &nl);
         s.nl = sizeof(s.n) - nl;
         if (!wl && rc == APR_SUCCESS) {
@@ -173,13 +173,13 @@ void test_wrange(struct testval *p)
                 success = -1;
             }
             else {
-                if (s.nl != l.nl 
+                if (s.nl != l.nl
                  || memcmp(s.n, l.n, s.nl - 1) != 0
                  || s.n[s.nl - 1] != l.n[l.nl - 1] + 1) {
                     displaynw(&f, &l);
                     memcpy(&f, &s, sizeof(s));
                 }
-            }            
+            }
             memcpy(&l, &s, sizeof(s));
         }
         else {
@@ -206,7 +206,7 @@ void test_wrange(struct testval *p)
 }
 
 /*
- *  Test every possible byte value. 
+ *  Test every possible byte value.
  *  If the test passes or fails at this byte value we are done.
  *  Otherwise iterate test_nrange again, appending another byte.
  */

Modified: apr/apr/trunk/test/proc_child.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/proc_child.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/proc_child.c (original)
+++ apr/apr/trunk/test/proc_child.c Sun Nov 20 07:14:38 2022
@@ -12,7 +12,7 @@ int main(void)
 {
     char buf[256];
     int bytes, rv = 0;
-    
+
     bytes = (int)read(STDIN_FILENO, buf, 256);
     if (bytes > 0)
         rv = write(STDOUT_FILENO, buf, (unsigned int)bytes) == bytes ? 0 : 1;

Modified: apr/apr/trunk/test/readchild.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/readchild.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/readchild.c (original)
+++ apr/apr/trunk/test/readchild.c Sun Nov 20 07:14:38 2022
@@ -25,7 +25,7 @@ int main(int argc, char *argv[])
     apr_pool_t *p;
     char buf[128];
     apr_status_t rv;
-    
+
     apr_initialize();
     atexit(apr_terminate);
     apr_pool_create(&p, NULL);

Modified: apr/apr/trunk/test/sendfile.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/sendfile.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/sendfile.c (original)
+++ apr/apr/trunk/test/sendfile.c Sun Nov 20 07:14:38 2022
@@ -30,7 +30,7 @@
 #if !APR_HAS_SENDFILE
 int main(void)
 {
-    fprintf(stderr, 
+    fprintf(stderr,
             "This program won't work on this platform because there is no "
             "support for sendfile().\n");
     return 0;
@@ -95,13 +95,13 @@ static void create_testfile(apr_pool_t *
     apr_finfo_t finfo;
 
     printf("Creating a test file...\n");
-    rv = apr_file_open(&f, fname, 
+    rv = apr_file_open(&f, fname,
                  APR_FOPEN_CREATE | APR_FOPEN_WRITE | APR_FOPEN_TRUNCATE | APR_FOPEN_BUFFERED,
                  APR_FPROT_UREAD | APR_FPROT_UWRITE, p);
     if (rv) {
         aprerr("apr_file_open()", rv);
     }
-    
+
     buf[0] = FILE_DATA_CHAR;
     buf[1] = '\0';
     for (i = 0; i < FILE_LENGTH; i++) {
@@ -131,7 +131,7 @@ static void create_testfile(apr_pool_t *
     }
 
     if (finfo.size != FILE_LENGTH) {
-        fprintf(stderr, 
+        fprintf(stderr,
                 "test file %s should be %ld-bytes long\n"
                 "instead it is %ld-bytes long\n",
                 fname,
@@ -290,11 +290,11 @@ static int client(apr_pool_t *p, client_
     memset(hdtr.trailers[2].iov_base, TRL3_CHAR, TRL3_LEN);
     hdtr.trailers[2].iov_len  = TRL3_LEN;
 
-    expected_len = 
+    expected_len =
         strlen(HDR1) + strlen(HDR2) + HDR3_LEN +
         strlen(TRL1) + strlen(TRL2) + TRL3_LEN +
         FILE_LENGTH;
-    
+
     if (socket_mode == BLK) {
         current_file_offset = 0;
         len = FILE_LENGTH;
@@ -302,13 +302,13 @@ static int client(apr_pool_t *p, client_
         if (rv != APR_SUCCESS) {
             aprerr("apr_socket_sendfile()", rv);
         }
-        
+
         printf("apr_socket_sendfile() updated offset with %ld\n",
                (long int)current_file_offset);
-        
+
         printf("apr_socket_sendfile() updated len with %ld\n",
                (long int)len);
-        
+
         printf("bytes really sent: %" APR_SIZE_T_FMT "\n",
                expected_len);
 
@@ -333,7 +333,7 @@ static int client(apr_pool_t *p, client_
         pfd.desc.s = sock;
         pfd.client_data = NULL;
 
-        rv = apr_pollset_add(pset, &pfd);        
+        rv = apr_pollset_add(pset, &pfd);
         assert(!rv);
 
         total_bytes_sent = 0;
@@ -388,7 +388,7 @@ static int client(apr_pool_t *p, client_
                 }
                 else {
                     hdtr.headers[0].iov_len -= tmplen;
-                    hdtr.headers[0].iov_base = 
+                    hdtr.headers[0].iov_base =
 			(char*) hdtr.headers[0].iov_base + tmplen;
                     tmplen = 0;
                 }
@@ -421,14 +421,14 @@ static int client(apr_pool_t *p, client_
                 }
                 else {
                     hdtr.trailers[0].iov_len -= tmplen;
-                    hdtr.trailers[0].iov_base = 
+                    hdtr.trailers[0].iov_base =
 			(char *)hdtr.trailers[0].iov_base + tmplen;
                     tmplen = 0;
                 }
             }
 
         } while (total_bytes_sent < expected_len &&
-                 (rv == APR_SUCCESS || 
+                 (rv == APR_SUCCESS ||
                  (APR_STATUS_IS_EAGAIN(rv) && socket_mode != TIMEOUT)));
         if (total_bytes_sent != expected_len) {
             fprintf(stderr,
@@ -444,7 +444,7 @@ static int client(apr_pool_t *p, client_
             exit(1);
         }
     }
-    
+
     current_file_offset = 0;
     rv = apr_file_seek(f, APR_CUR, &current_file_offset);
     if (rv != APR_SUCCESS) {
@@ -467,7 +467,7 @@ static int client(apr_pool_t *p, client_
     if (rv != APR_SUCCESS) {
         aprerr("apr_socket_timeout_set()", rv);
     }
-    
+
     bytes_read = 1;
     rv = apr_socket_recv(sock, buf, &bytes_read);
     if (rv != APR_EOF) {
@@ -575,7 +575,7 @@ static int server(apr_pool_t *p)
                 (int)bytes_read, buf, HDR1);
         exit(1);
     }
-        
+
     assert(sizeof buf > strlen(HDR2));
     bytes_read = strlen(HDR2);
     rv = apr_socket_recv(newsock, buf, &bytes_read);
@@ -614,7 +614,7 @@ static int server(apr_pool_t *p)
             exit(1);
         }
     }
-        
+
     for (i = 0; i < FILE_LENGTH; i++) {
         bytes_read = 1;
         rv = apr_socket_recv(newsock, buf, &bytes_read);
@@ -636,7 +636,7 @@ static int server(apr_pool_t *p)
             exit(1);
         }
     }
-        
+
     assert(sizeof buf > strlen(TRL1));
     bytes_read = strlen(TRL1);
     rv = apr_socket_recv(newsock, buf, &bytes_read);
@@ -653,7 +653,7 @@ static int server(apr_pool_t *p)
                 (int)bytes_read, buf, TRL1);
         exit(1);
     }
-        
+
     assert(sizeof buf > strlen(TRL2));
     bytes_read = strlen(TRL2);
     rv = apr_socket_recv(newsock, buf, &bytes_read);
@@ -692,7 +692,7 @@ static int server(apr_pool_t *p)
             exit(1);
         }
     }
-        
+
     bytes_read = 1;
     rv = apr_socket_recv(newsock, buf, &bytes_read);
     if (rv != APR_EOF) {
@@ -752,7 +752,7 @@ int main(int argc, char *argv[])
             }
             else {
                 host = argv[i];
-            }	
+            }
         }
         return client(p, mode, host, start_server);
     }
@@ -760,7 +760,7 @@ int main(int argc, char *argv[])
         return server(p);
     }
 
-    fprintf(stderr, 
+    fprintf(stderr,
             "Usage: %s client {blocking|nonblocking|timeout} [startserver] [server-host]\n"
             "       %s server\n",
             argv[0], argv[0]);

Modified: apr/apr/trunk/test/sockchild.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/sockchild.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/sockchild.c (original)
+++ apr/apr/trunk/test/sockchild.c Sun Nov 20 07:14:38 2022
@@ -50,7 +50,7 @@ int main(int argc, char *argv[])
     }
 
     apr_socket_connect(sock, remote_sa);
-        
+
     if (!strcmp("read", argv[1])) {
         char datarecv[STRLEN];
         apr_size_t length = STRLEN;
@@ -60,13 +60,13 @@ int main(int argc, char *argv[])
         rv = apr_socket_recv(sock, datarecv, &length);
         apr_socket_close(sock);
         if (APR_STATUS_IS_TIMEUP(rv)) {
-            exit(SOCKET_TIMEOUT); 
+            exit(SOCKET_TIMEOUT);
         }
 
         if (strcmp(datarecv, DATASTR)) {
             exit(-1);
         }
-        
+
         exit((int)length);
     }
     else if (!strcmp("write", argv[1])

Modified: apr/apr/trunk/test/sockperf.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/sockperf.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/sockperf.c (original)
+++ apr/apr/trunk/test/sockperf.c Sun Nov 20 07:14:38 2022
@@ -58,14 +58,14 @@ struct testResult {
 static apr_int16_t testPort = 4747;
 static apr_sockaddr_t *sockAddr = NULL;
 
-static void reportError(const char *msg, apr_status_t rv, 
+static void reportError(const char *msg, apr_status_t rv,
                         apr_pool_t *pool)
 {
     fprintf(stderr, "%s\n", msg);
     if (rv != APR_SUCCESS)
         fprintf(stderr, "Error: %d\n'%s'\n", rv,
                 apr_psprintf(pool, "%pm", &rv));
-    
+
 }
 
 static void closeConnection(apr_socket_t *sock)
@@ -74,7 +74,7 @@ static void closeConnection(apr_socket_t
     apr_socket_send(sock, NULL, &len);
 }
 
-static apr_status_t sendRecvBuffer(apr_time_t *t, const char *buf, 
+static apr_status_t sendRecvBuffer(apr_time_t *t, const char *buf,
                                    apr_size_t size, apr_pool_t *pool)
 {
     apr_socket_t *sock;
@@ -142,14 +142,14 @@ static apr_status_t sendRecvBuffer(apr_t
 
         rv = apr_socket_send(sock, buf, &len);
         if (rv != APR_SUCCESS || len != size) {
-            reportError(apr_psprintf(pool, 
+            reportError(apr_psprintf(pool,
                          "Unable to send data correctly (iteration %d of 3)",
                          i) , rv, pool);
             closeConnection(sock);
             apr_socket_close(sock);
             return rv;
         }
-    
+
         do {
             len = thistime;
             rv = apr_socket_recv(sock, &recvBuf[size - thistime], &len);
@@ -169,7 +169,7 @@ static apr_status_t sendRecvBuffer(apr_t
     if (thistime) {
         reportError("Received less than we sent :-(", rv, pool);
         return rv;
-    }        
+    }
     if (strncmp(recvBuf, buf, size) != 0) {
         reportError("Received corrupt data :-(", 0, pool);
         printf("We sent:\n%s\nWe received:\n%s\n", buf, recvBuf);
@@ -186,7 +186,7 @@ static apr_status_t runTest(struct testS
     apr_status_t rv = APR_SUCCESS;
     int i;
     apr_size_t sz = ts->size * TEST_SIZE;
-    
+
     buffer = apr_palloc(pool, sz);
     if (!buffer) {
         reportError("Unable to allocate buffer", ENOMEM, pool);
@@ -224,7 +224,7 @@ int main(int argc, char **argv)
 
     apr_pool_create(&pool, NULL);
 
-    results = (struct testResult *)apr_pcalloc(pool, 
+    results = (struct testResult *)apr_pcalloc(pool,
                                         sizeof(*results) * nTests);
 
     for (i = 0; i < nTests; i++) {

Modified: apr/apr/trunk/test/testargs.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testargs.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testargs.c (original)
+++ apr/apr/trunk/test/testargs.c Sun Nov 20 07:14:38 2022
@@ -52,7 +52,7 @@ static void no_options_found(abts_case *
     str[0] = '\0';
     rv = apr_getopt_init(&opt, p, largc, largv);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
-   
+
     while (apr_getopt(opt, "abcd", &ch, &opt_arg) == APR_SUCCESS) {
         switch (ch) {
             case 'a':
@@ -85,7 +85,7 @@ static void no_options(abts_case *tc, vo
 
     opt->errfn = unknown_arg;
     opt->errarg = str;
-   
+
     while (apr_getopt(opt, "efgh", &ch, &opt_arg) == APR_SUCCESS) {
         switch (ch) {
             case 'a':
@@ -117,7 +117,7 @@ static void required_option(abts_case *t
 
     opt->errfn = unknown_arg;
     opt->errarg = str;
-   
+
     while (apr_getopt(opt, "a:", &ch, &opt_arg) == APR_SUCCESS) {
         switch (ch) {
             case 'a':
@@ -146,7 +146,7 @@ static void required_option_notgiven(abt
 
     opt->errfn = unknown_arg;
     opt->errarg = str;
-   
+
     while (apr_getopt(opt, "a:", &ch, &opt_arg) == APR_SUCCESS) {
         switch (ch) {
             case 'a':
@@ -175,7 +175,7 @@ static void optional_option(abts_case *t
 
     opt->errfn = unknown_arg;
     opt->errarg = str;
-   
+
     while (apr_getopt(opt, "a::", &ch, &opt_arg) == APR_SUCCESS) {
         switch (ch) {
             case 'a':
@@ -204,7 +204,7 @@ static void optional_option_notgiven(abt
 
     opt->errfn = unknown_arg;
     opt->errarg = str;
-   
+
     while (apr_getopt(opt, "a::", &ch, &opt_arg) == APR_SUCCESS) {
         switch (ch) {
             case 'a':

Modified: apr/apr/trunk/test/testbuckets.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testbuckets.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testbuckets.c (original)
+++ apr/apr/trunk/test/testbuckets.c Sun Nov 20 07:14:38 2022
@@ -39,10 +39,10 @@ static void test_simple(abts_case *tc, v
     apr_bucket_alloc_t *ba;
     apr_bucket_brigade *bb;
     apr_bucket *fb, *tb;
-    
+
     ba = apr_bucket_alloc_create(p);
     bb = apr_brigade_create(p, ba);
-    
+
     fb = APR_BRIGADE_FIRST(bb);
     ABTS_ASSERT(tc, "first bucket of empty brigade is sentinel",
                 fb == APR_BRIGADE_SENTINEL(bb));
@@ -75,12 +75,12 @@ static void test_simple(abts_case *tc, v
 }
 
 static apr_bucket_brigade *make_simple_brigade(apr_bucket_alloc_t *ba,
-                                               const char *first, 
+                                               const char *first,
                                                const char *second)
 {
     apr_bucket_brigade *bb = apr_brigade_create(p, ba);
     apr_bucket *e;
- 
+
     e = apr_bucket_transient_create(first, strlen(first), ba);
     APR_BRIGADE_INSERT_TAIL(bb, e);
 
@@ -120,7 +120,7 @@ static void test_flatten(abts_case *tc,
     flatten_match(tc, "flatten brigade", bb, "hello, world");
 
     apr_brigade_destroy(bb);
-    apr_bucket_alloc_destroy(ba);    
+    apr_bucket_alloc_destroy(ba);
 }
 
 static int count_buckets(apr_bucket_brigade *bb)
@@ -128,12 +128,12 @@ static int count_buckets(apr_bucket_brig
     apr_bucket *e;
     int count = 0;
 
-    for (e = APR_BRIGADE_FIRST(bb); 
+    for (e = APR_BRIGADE_FIRST(bb);
          e != APR_BRIGADE_SENTINEL(bb);
          e = APR_BUCKET_NEXT(e)) {
         count++;
     }
-    
+
     return count;
 }
 
@@ -173,7 +173,7 @@ static void test_bwrite(abts_case *tc, v
     int n;
 
     for (n = 0; n < COUNT; n++) {
-        APR_ASSERT_SUCCESS(tc, "brigade_write", 
+        APR_ASSERT_SUCCESS(tc, "brigade_write",
                            apr_brigade_write(bb, NULL, NULL,
                                              THESTR, sizeof THESTR));
     }
@@ -183,7 +183,7 @@ static void test_bwrite(abts_case *tc, v
 
     ABTS_ASSERT(tc, "brigade has correct length",
                 length == (COUNT * sizeof THESTR));
-    
+
     apr_brigade_destroy(bb);
     apr_bucket_alloc_destroy(ba);
 }
@@ -275,7 +275,7 @@ static void test_bucket_content(abts_cas
     apr_size_t alen;
 
     APR_ASSERT_SUCCESS(tc, "read from bucket",
-                       apr_bucket_read(e, &adata, &alen, 
+                       apr_bucket_read(e, &adata, &alen,
                                        APR_BLOCK_READ));
 
     ABTS_ASSERT(tc, "read expected length", alen == elen);
@@ -294,19 +294,19 @@ static void test_splits(abts_case *tc, v
 
     APR_BRIGADE_INSERT_TAIL(bb,
                             apr_bucket_immortal_create(str, 9, ba));
-    APR_BRIGADE_INSERT_TAIL(bb, 
+    APR_BRIGADE_INSERT_TAIL(bb,
                             apr_bucket_transient_create(str, 9, ba));
-    APR_BRIGADE_INSERT_TAIL(bb, 
+    APR_BRIGADE_INSERT_TAIL(bb,
                             apr_bucket_heap_create(strdup(str), 9, free, ba));
-    APR_BRIGADE_INSERT_TAIL(bb, 
-                            apr_bucket_pool_create(apr_pstrdup(p, str), 9, p, 
+    APR_BRIGADE_INSERT_TAIL(bb,
+                            apr_bucket_pool_create(apr_pstrdup(p, str), 9, p,
                                                    ba));
 
     ABTS_ASSERT(tc, "four buckets inserted", count_buckets(bb) == 4);
-    
+
     /* now split each of the buckets after byte 5 */
     for (n = 0, e = APR_BRIGADE_FIRST(bb); n < 4; n++) {
-        ABTS_ASSERT(tc, "reached end of brigade", 
+        ABTS_ASSERT(tc, "reached end of brigade",
                     e != APR_BRIGADE_SENTINEL(bb));
         ABTS_ASSERT(tc, "split bucket OK",
                     apr_bucket_split(e, 5) == APR_SUCCESS);
@@ -314,14 +314,14 @@ static void test_splits(abts_case *tc, v
         ABTS_ASSERT(tc, "split OK", e != APR_BRIGADE_SENTINEL(bb));
         e = APR_BUCKET_NEXT(e);
     }
-    
-    ABTS_ASSERT(tc, "four buckets split into eight", 
+
+    ABTS_ASSERT(tc, "four buckets split into eight",
                 count_buckets(bb) == 8);
 
     for (n = 0, e = APR_BRIGADE_FIRST(bb); n < 4; n++) {
         const char *data;
         apr_size_t len;
-        
+
         APR_ASSERT_SUCCESS(tc, "read alpha from bucket",
                            apr_bucket_read(e, &data, &len, APR_BLOCK_READ));
         ABTS_ASSERT(tc, "read 5 bytes", len == 5);
@@ -346,9 +346,9 @@ static void test_splits(abts_case *tc, v
         f = APR_BUCKET_NEXT(e);
         apr_bucket_delete(e);
         e = APR_BUCKET_NEXT(f);
-    }    
-    
-    ABTS_ASSERT(tc, "eight buckets reduced to four", 
+    }
+
+    ABTS_ASSERT(tc, "eight buckets reduced to four",
                 count_buckets(bb) == 4);
 
     flatten_match(tc, "flatten beta brigade", bb,
@@ -381,11 +381,11 @@ static void test_insertfile(abts_case *t
         ABTS_NOT_IMPL(tc, "Skipped: could not create large file");
         return;
     }
-    
+
     bb = apr_brigade_create(p, ba);
 
     e = apr_brigade_insert_file(bb, f, 0, bignum, p);
-    
+
     ABTS_ASSERT(tc, "inserted file was not at end of brigade",
                 e == APR_BRIGADE_LAST(bb));
 
@@ -426,7 +426,7 @@ static apr_file_t *make_test_file(abts_c
                 apr_file_open(&f, fname,
                               APR_FOPEN_READ|APR_FOPEN_WRITE|APR_FOPEN_TRUNCATE|APR_FOPEN_CREATE,
                               APR_FPROT_OS_DEFAULT, p) == APR_SUCCESS);
-    
+
     ABTS_ASSERT(tc, "write test file contents",
                 apr_file_puts(contents, f) == APR_SUCCESS);
 
@@ -486,7 +486,7 @@ static void test_truncfile(abts_case *tc
                 apr_bucket_read(e, &buf, &len, APR_BLOCK_READ) == APR_EOF);
 
     ABTS_ASSERT(tc, "read length 0", len == 0);
-    
+
     ABTS_ASSERT(tc, "still a single bucket in brigade",
                 APR_BUCKET_NEXT(e) == APR_BRIGADE_SENTINEL(bb));
 

Modified: apr/apr/trunk/test/testcond.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testcond.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testcond.c (original)
+++ apr/apr/trunk/test/testcond.c Sun Nov 20 07:14:38 2022
@@ -387,7 +387,7 @@ static void pipe_consumer(toolbox_t *box
     } while (1);
 
     /* naive fairness test - it would be good to introduce or solidify
-     * a solid test to ensure one thread is not starved.  
+     * a solid test to ensure one thread is not starved.
      * ABTS_INT_EQUAL(tc, 1, !!consumed);
      */
 }

Modified: apr/apr/trunk/test/testdate.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testdate.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testdate.c (original)
+++ apr/apr/trunk/test/testdate.c Sun Nov 20 07:14:38 2022
@@ -200,7 +200,7 @@ static void test_date_exp_get(abts_case
         1, 2, 10, 100, 1000, 9000, 10000, 100000,
         -1, -2, -10, -100, -1000, -9000, -10000, -100000,
     };
-    
+
     tm.tm_mday = 1;
     tm.tm_year = 70;
 

Modified: apr/apr/trunk/test/testdir.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testdir.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testdir.c (original)
+++ apr/apr/trunk/test/testdir.c Sun Nov 20 07:14:38 2022
@@ -45,7 +45,7 @@ static void test_mkdir_recurs(abts_case
     apr_status_t rv;
     apr_finfo_t finfo;
 
-    rv = apr_dir_make_recursive("data/one/two/three", 
+    rv = apr_dir_make_recursive("data/one/two/three",
                                 APR_FPROT_UREAD | APR_FPROT_UWRITE | APR_FPROT_UEXECUTE,
                                 p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -325,7 +325,7 @@ static void test_uncleared_errno(abts_ca
     apr_finfo_t finfo;
     apr_int32_t finfo_flags = APR_FINFO_TYPE | APR_FINFO_NAME;
     apr_dir_t *this_dir;
-    apr_status_t rv; 
+    apr_status_t rv;
 
     rv = apr_dir_make("dir1", APR_FPROT_OS_DEFAULT, p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -343,7 +343,7 @@ static void test_uncleared_errno(abts_ca
        `errno' will be set as a result. */
     rv = apr_dir_remove("dir1", p);
     ABTS_INT_EQUAL(tc, 1, APR_STATUS_IS_ENOTEMPTY(rv));
-    
+
     /* Read `.' and `..' out of dir2. */
     rv = apr_dir_open(&this_dir, "dir2", p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -361,7 +361,7 @@ static void test_uncleared_errno(abts_ca
 
     rv = apr_dir_close(this_dir);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
-		 
+
     /* Cleanup */
     rv = apr_file_remove("dir1/file1", p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);

Modified: apr/apr/trunk/test/testdso.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testdso.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testdso.c (original)
+++ apr/apr/trunk/test/testdso.c Sun Nov 20 07:14:38 2022
@@ -36,8 +36,8 @@
 #elif defined(WIN32)
 # define MOD_NAME TESTBINPATH "mod_test.dll"
 #elif defined(DARWIN)
-# define MOD_NAME ".libs/mod_test.so" 
-# define LIB_NAME ".libs/libmod_test.dylib" 
+# define MOD_NAME ".libs/mod_test.so"
+# define LIB_NAME ".libs/libmod_test.dylib"
 #elif (defined(__hpux__) || defined(__hpux)) && !defined(__ia64)
 # define MOD_NAME ".libs/mod_test.sl"
 # define LIB_NAME ".libs/libmod_test.sl"
@@ -230,7 +230,7 @@ static void test_load_notthere(abts_case
 
     ABTS_INT_EQUAL(tc, 1, APR_STATUS_IS_EDSOOPEN(status));
     ABTS_PTR_NOTNULL(tc, h);
-}    
+}
 
 #endif /* APR_HAS_DSO */
 
@@ -240,7 +240,7 @@ abts_suite *testdso(abts_suite *suite)
 
 #if APR_HAS_DSO
     apr_filepath_merge(&modname, NULL, MOD_NAME, 0, p);
-    
+
     abts_run_test(suite, test_load_module, NULL);
     abts_run_test(suite, test_dso_sym, NULL);
     abts_run_test(suite, test_dso_sym_return_value, NULL);
@@ -248,7 +248,7 @@ abts_suite *testdso(abts_suite *suite)
 
 #ifdef LIB_NAME
     apr_filepath_merge(&libname, NULL, LIB_NAME, 0, p);
-    
+
     abts_run_test(suite, test_load_library, NULL);
     abts_run_test(suite, test_dso_sym_library, NULL);
     abts_run_test(suite, test_dso_sym_return_value_library, NULL);

Modified: apr/apr/trunk/test/testdup.c
URL: http://svn.apache.org/viewvc/apr/apr/trunk/test/testdup.c?rev=1905414&r1=1905413&r2=1905414&view=diff
==============================================================================
--- apr/apr/trunk/test/testdup.c (original)
+++ apr/apr/trunk/test/testdup.c Sun Nov 20 07:14:38 2022
@@ -33,7 +33,7 @@ static void test_file_dup(abts_case *tc,
     apr_finfo_t finfo;
 
     /* First, create a new file, empty... */
-    rv = apr_file_open(&file1, FILEPATH "testdup.file", 
+    rv = apr_file_open(&file1, FILEPATH "testdup.file",
                        APR_FOPEN_READ | APR_FOPEN_WRITE | APR_FOPEN_CREATE |
                        APR_FOPEN_DELONCLOSE, APR_FPROT_OS_DEFAULT, p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -51,7 +51,7 @@ static void test_file_dup(abts_case *tc,
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
     rv = apr_stat(&finfo, FILEPATH "testdup.file", APR_FINFO_NORM, p);
     ABTS_INT_EQUAL(tc, 1, APR_STATUS_IS_ENOENT(rv));
-}  
+}
 
 static void test_file_readwrite(abts_case *tc, void *data)
 {
@@ -64,7 +64,7 @@ static void test_file_readwrite(abts_cas
     apr_off_t fpos;
 
     /* First, create a new file, empty... */
-    rv = apr_file_open(&file1, FILEPATH "testdup.readwrite.file", 
+    rv = apr_file_open(&file1, FILEPATH "testdup.readwrite.file",
                        APR_FOPEN_READ | APR_FOPEN_WRITE | APR_FOPEN_CREATE |
                        APR_FOPEN_DELONCLOSE, APR_FPROT_OS_DEFAULT, p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -96,7 +96,7 @@ static void test_file_readwrite(abts_cas
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
     rv = apr_stat(&finfo, FILEPATH "testdup.readwrite.file", APR_FINFO_NORM, p);
     ABTS_INT_EQUAL(tc, 1, APR_STATUS_IS_ENOENT(rv));
-}  
+}
 
 static void test_dup2(abts_case *tc, void *data)
 {
@@ -105,7 +105,7 @@ static void test_dup2(abts_case *tc, voi
     apr_file_t *saveerr = NULL;
     apr_status_t rv;
 
-    rv = apr_file_open(&testfile, FILEPATH "testdup2.file", 
+    rv = apr_file_open(&testfile, FILEPATH "testdup2.file",
                        APR_FOPEN_READ | APR_FOPEN_WRITE | APR_FOPEN_CREATE |
                        APR_FOPEN_DELONCLOSE, APR_FPROT_OS_DEFAULT, p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -142,7 +142,7 @@ static void test_dup2_readwrite(abts_cas
     char buff[50];
     apr_off_t fpos;
 
-    rv = apr_file_open(&testfile, FILEPATH "testdup2.readwrite.file", 
+    rv = apr_file_open(&testfile, FILEPATH "testdup2.readwrite.file",
                        APR_FOPEN_READ | APR_FOPEN_WRITE | APR_FOPEN_CREATE |
                        APR_FOPEN_DELONCLOSE, APR_FPROT_OS_DEFAULT, p);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
@@ -174,7 +174,7 @@ static void test_dup2_readwrite(abts_cas
     rv = apr_file_read(testfile, buff, &txtlen);
     ABTS_INT_EQUAL(tc, APR_SUCCESS, rv);
     ABTS_STR_EQUAL(tc, TEST2, buff);
-      
+
     apr_file_close(testfile);
 
     rv = apr_file_dup2(errfile, saveerr, p);