You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@httpd.apache.org by Dean Gaudet <dg...@hyperreal.org> on 1997/09/14 13:36:35 UTC

cvs commit: apachen/src/main alloc.c alloc.h

dgaudet     97/09/14 04:36:34

  Modified:    src      INDENT
               src/main alloc.c alloc.h
  Log:
  indent
  
  Revision  Changes    Path
  1.8       +2 -2      apachen/src/INDENT
  
  Index: INDENT
  ===================================================================
  RCS file: /export/home/cvs/apachen/src/INDENT,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- INDENT	1997/09/14 11:13:51	1.7
  +++ INDENT	1997/09/14 11:36:32	1.8
  @@ -3,8 +3,8 @@
   If a file has already been indent'd, or doesn't need it, mark it as DONE
   
   ./main:				STATUS
  -   alloc.c			RESERVED by Dean
  -   alloc.h			RESERVED by Dean
  +   alloc.c			DONE by Dean
  +   alloc.h			DONE by Dean
      buff.c			DONE by Dean
      buff.h			DONE by Dean
      conf.h
  
  
  
  1.48      +854 -808  apachen/src/main/alloc.c
  
  Index: alloc.c
  ===================================================================
  RCS file: /export/home/cvs/apachen/src/main/alloc.c,v
  retrieving revision 1.47
  retrieving revision 1.48
  diff -u -r1.47 -r1.48
  --- alloc.c	1997/08/20 01:22:50	1.47
  +++ alloc.c	1997/09/14 11:36:33	1.48
  @@ -68,32 +68,30 @@
    * Managing free storage blocks...
    */
   
  -union align
  -{
  -  /* Types which are likely to have the longest RELEVANT alignment
  -   * restrictions...
  -   */
  -  
  -  char *cp;
  -  void (*f)(void);
  -  long l;
  -  FILE *fp;
  -  double d;
  +union align {
  +    /* Types which are likely to have the longest RELEVANT alignment
  +     * restrictions...
  +     */
  +
  +    char *cp;
  +    void (*f) (void);
  +    long l;
  +    FILE *fp;
  +    double d;
   };
   
   #define CLICK_SZ (sizeof(union align))
   
  -union block_hdr
  -{
  -  union align a;
  -  
  -  /* Actual header... */
  -  
  -  struct {
  -    char *endp;
  -    union block_hdr *next;
  -    char *first_avail;
  -  } h;
  +union block_hdr {
  +    union align a;
  +
  +    /* Actual header... */
  +
  +    struct {
  +	char *endp;
  +	union block_hdr *next;
  +	char *first_avail;
  +    } h;
   };
   
   union block_hdr *block_freelist = NULL;
  @@ -102,75 +100,76 @@
   
   
   /* Get a completely new block from the system pool. Note that we rely on
  -malloc() to provide aligned memory. */
  +   malloc() to provide aligned memory. */
   
  -union block_hdr *malloc_block (int size)
  +union block_hdr *malloc_block(int size)
   {
  -  union block_hdr *blok =
  -    (union block_hdr *)malloc(size + sizeof(union block_hdr));
  +    union block_hdr *blok =
  +    (union block_hdr *) malloc(size + sizeof(union block_hdr));
  +
  +    if (blok == NULL) {
  +	fprintf(stderr, "Ouch!  malloc failed in malloc_block()\n");
  +	exit(1);
  +    }
  +    blok->h.next = NULL;
  +    blok->h.first_avail = (char *) (blok + 1);
  +    blok->h.endp = size + blok->h.first_avail;
   
  -  if (blok == NULL) {
  -      fprintf (stderr, "Ouch!  malloc failed in malloc_block()\n");
  -      exit (1);
  -  }
  -  blok->h.next = NULL;
  -  blok->h.first_avail = (char *)(blok + 1);
  -  blok->h.endp = size + blok->h.first_avail;
  -  
  -  return blok;
  +    return blok;
   }
   
   
   
  -void chk_on_blk_list (union block_hdr *blok, union block_hdr *free_blk)
  +void chk_on_blk_list(union block_hdr *blok, union block_hdr *free_blk)
   {
  -  /* Debugging code.  Left in for the moment. */
  -    
  -  while (free_blk) {
  -    if (free_blk == blok) {
  -      fprintf (stderr, "Ouch!  Freeing free block\n");
  -      exit (1);
  +    /* Debugging code.  Left in for the moment. */
  +
  +    while (free_blk) {
  +	if (free_blk == blok) {
  +	    fprintf(stderr, "Ouch!  Freeing free block\n");
  +	    exit(1);
  +	}
  +	free_blk = free_blk->h.next;
       }
  -    free_blk = free_blk->h.next;
  -  }
   }
   
   /* Free a chain of blocks --- must be called with alarms blocked. */
   
  -void free_blocks (union block_hdr *blok)
  +void free_blocks(union block_hdr *blok)
   {
  -  /* First, put new blocks at the head of the free list ---
  -   * we'll eventually bash the 'next' pointer of the last block
  -   * in the chain to point to the free blocks we already had.
  -   */
  -  
  -  union block_hdr *old_free_list;
  -
  -  if (blok == NULL) return;	/* Sanity check --- freeing empty pool? */
  -  
  -  (void)acquire_mutex(alloc_mutex);
  -  old_free_list = block_freelist;
  -  block_freelist = blok;
  -  
  -  /*
  -   * Next, adjust first_avail pointers of each block --- have to do it
  -   * sooner or later, and it simplifies the search in new_block to do it
  -   * now.
  -   */
  -
  -  while (blok->h.next != NULL) {
  -    chk_on_blk_list (blok, old_free_list);
  -    blok->h.first_avail = (char *)(blok + 1);
  -    blok = blok->h.next;
  -  }
  +    /* First, put new blocks at the head of the free list ---
  +     * we'll eventually bash the 'next' pointer of the last block
  +     * in the chain to point to the free blocks we already had.
  +     */
  +
  +    union block_hdr *old_free_list;
  +
  +    if (blok == NULL)
  +	return;			/* Sanity check --- freeing empty pool? */
  +
  +    (void) acquire_mutex(alloc_mutex);
  +    old_free_list = block_freelist;
  +    block_freelist = blok;
  +
  +    /*
  +     * Next, adjust first_avail pointers of each block --- have to do it
  +     * sooner or later, and it simplifies the search in new_block to do it
  +     * now.
  +     */
  +
  +    while (blok->h.next != NULL) {
  +	chk_on_blk_list(blok, old_free_list);
  +	blok->h.first_avail = (char *) (blok + 1);
  +	blok = blok->h.next;
  +    }
   
  -  chk_on_blk_list (blok, old_free_list);
  -  blok->h.first_avail = (char *)(blok + 1);
  +    chk_on_blk_list(blok, old_free_list);
  +    blok->h.first_avail = (char *) (blok + 1);
   
  -  /* Finally, reset next pointer to get the old free blocks back */
  +    /* Finally, reset next pointer to get the old free blocks back */
   
  -  blok->h.next = old_free_list;
  -  (void)release_mutex(alloc_mutex);
  +    blok->h.next = old_free_list;
  +    (void) release_mutex(alloc_mutex);
   }
   
   
  @@ -180,47 +179,47 @@
    * if necessary.  Must be called with alarms blocked.
    */
   
  -union block_hdr *new_block (int min_size)
  +union block_hdr *new_block(int min_size)
   {
  -  union block_hdr **lastptr = &block_freelist;
  -  union block_hdr *blok = block_freelist;
  -  
  -  /* First, see if we have anything of the required size
  -   * on the free list...
  -   */
  -
  -  while (blok != NULL) {
  -    if (min_size + BLOCK_MINFREE <= blok->h.endp - blok->h.first_avail) {
  -      *lastptr = blok->h.next;
  -      blok->h.next = NULL;
  -      return blok;
  -    }
  -    else {
  -      lastptr = &blok->h.next;
  -      blok = blok->h.next;
  +    union block_hdr **lastptr = &block_freelist;
  +    union block_hdr *blok = block_freelist;
  +
  +    /* First, see if we have anything of the required size
  +     * on the free list...
  +     */
  +
  +    while (blok != NULL) {
  +	if (min_size + BLOCK_MINFREE <= blok->h.endp - blok->h.first_avail) {
  +	    *lastptr = blok->h.next;
  +	    blok->h.next = NULL;
  +	    return blok;
  +	}
  +	else {
  +	    lastptr = &blok->h.next;
  +	    blok = blok->h.next;
  +	}
       }
  -  }
   
  -  /* Nope. */
  +    /* Nope. */
   
  -  min_size += BLOCK_MINFREE;
  -  return malloc_block((min_size > BLOCK_MINALLOC) ? min_size : BLOCK_MINALLOC);
  +    min_size += BLOCK_MINFREE;
  +    return malloc_block((min_size > BLOCK_MINALLOC) ? min_size : BLOCK_MINALLOC);
   }
   
   
   
   /* Accounting */
   
  -long bytes_in_block_list (union block_hdr *blok)
  +long bytes_in_block_list(union block_hdr *blok)
   {
  -  long size = 0;
  +    long size = 0;
   
  -  while (blok) {
  -    size += blok->h.endp - (char *)(blok + 1);
  -    blok = blok->h.next;
  -  }
  +    while (blok) {
  +	size += blok->h.endp - (char *) (blok + 1);
  +	blok = blok->h.next;
  +    }
   
  -  return size;
  +    return size;
   }
   
   
  @@ -235,19 +234,19 @@
   struct process_chain;
   struct cleanup;
   
  -static void run_cleanups (struct cleanup *);
  -static void free_proc_chain (struct process_chain *);
  +static void run_cleanups(struct cleanup *);
  +static void free_proc_chain(struct process_chain *);
   
   struct pool {
  -  union block_hdr *first;
  -  union block_hdr *last;
  -  struct cleanup *cleanups;
  -  struct process_chain *subprocesses;
  -  struct pool *sub_pools;
  -  struct pool *sub_next;
  -  struct pool *sub_prev;
  -  struct pool *parent;
  -  char *free_first_avail;
  +    union block_hdr *first;
  +    union block_hdr *last;
  +    struct cleanup *cleanups;
  +    struct process_chain *subprocesses;
  +    struct pool *sub_pools;
  +    struct pool *sub_next;
  +    struct pool *sub_prev;
  +    struct pool *parent;
  +    char *free_first_avail;
   };
   
   pool *permanent_pool;
  @@ -260,84 +259,93 @@
    */
   
   #define POOL_HDR_CLICKS (1 + ((sizeof(struct pool) - 1) / CLICK_SZ))
  -#define POOL_HDR_BYTES (POOL_HDR_CLICKS * CLICK_SZ)			 
  +#define POOL_HDR_BYTES (POOL_HDR_CLICKS * CLICK_SZ)
   
  -API_EXPORT(struct pool *) make_sub_pool (struct pool *p)
  +API_EXPORT(struct pool *) make_sub_pool(struct pool *p)
   {
  -  union block_hdr *blok;
  -  pool *new_pool;
  +    union block_hdr *blok;
  +    pool *new_pool;
  +
  +    block_alarms();
  +
  +    (void) acquire_mutex(alloc_mutex);
   
  -  block_alarms();
  +    blok = new_block(0);
  +    new_pool = (pool *) blok->h.first_avail;
  +    blok->h.first_avail += POOL_HDR_BYTES;
   
  -  (void)acquire_mutex(alloc_mutex);
  -  
  -  blok = new_block (0);
  -  new_pool = (pool *)blok->h.first_avail;
  -  blok->h.first_avail += POOL_HDR_BYTES;
  -
  -  memset ((char *)new_pool, '\0', sizeof (struct pool));
  -  new_pool->free_first_avail = blok->h.first_avail;
  -  new_pool->first = new_pool->last = blok;
  -    
  -  if (p) {
  -    new_pool->parent = p;
  -    new_pool->sub_next = p->sub_pools;
  -    if (new_pool->sub_next) new_pool->sub_next->sub_prev = new_pool;
  -    p->sub_pools = new_pool;
  -  }
  -  
  -  (void)release_mutex(alloc_mutex);
  -  unblock_alarms();
  -  
  -  return new_pool;
  +    memset((char *) new_pool, '\0', sizeof(struct pool));
  +    new_pool->free_first_avail = blok->h.first_avail;
  +    new_pool->first = new_pool->last = blok;
  +
  +    if (p) {
  +	new_pool->parent = p;
  +	new_pool->sub_next = p->sub_pools;
  +	if (new_pool->sub_next)
  +	    new_pool->sub_next->sub_prev = new_pool;
  +	p->sub_pools = new_pool;
  +    }
  +
  +    (void) release_mutex(alloc_mutex);
  +    unblock_alarms();
  +
  +    return new_pool;
   }
   
   void init_alloc(void)
   {
       alloc_mutex = create_mutex(NULL);
       spawn_mutex = create_mutex(NULL);
  -    permanent_pool = make_sub_pool (NULL);
  +    permanent_pool = make_sub_pool(NULL);
   }
   
  -API_EXPORT(void) clear_pool (struct pool *a)
  +API_EXPORT(void) clear_pool(struct pool *a)
   {
  -  block_alarms();
  -  
  -  while (a->sub_pools)
  -    destroy_pool (a->sub_pools);
  -    
  -  a->sub_pools = NULL;
  -  
  -  run_cleanups (a->cleanups);        a->cleanups = NULL;
  -  free_proc_chain (a->subprocesses); a->subprocesses = NULL;
  -  free_blocks (a->first->h.next);    a->first->h.next = NULL;
  +    block_alarms();
   
  -  a->last = a->first;
  -  a->first->h.first_avail = a->free_first_avail;
  +    while (a->sub_pools)
  +	destroy_pool(a->sub_pools);
   
  -  unblock_alarms();
  +    a->sub_pools = NULL;
  +
  +    run_cleanups(a->cleanups);
  +    a->cleanups = NULL;
  +    free_proc_chain(a->subprocesses);
  +    a->subprocesses = NULL;
  +    free_blocks(a->first->h.next);
  +    a->first->h.next = NULL;
  +
  +    a->last = a->first;
  +    a->first->h.first_avail = a->free_first_avail;
  +
  +    unblock_alarms();
   }
   
  -API_EXPORT(void) destroy_pool (pool *a)
  +API_EXPORT(void) destroy_pool(pool *a)
   {
  -  block_alarms();
  -  clear_pool (a);
  +    block_alarms();
  +    clear_pool(a);
  +
  +    if (a->parent) {
  +	if (a->parent->sub_pools == a)
  +	    a->parent->sub_pools = a->sub_next;
  +	if (a->sub_prev)
  +	    a->sub_prev->sub_next = a->sub_next;
  +	if (a->sub_next)
  +	    a->sub_next->sub_prev = a->sub_prev;
  +    }
   
  -  if (a->parent) {
  -    if (a->parent->sub_pools == a) a->parent->sub_pools = a->sub_next;
  -    if (a->sub_prev) a->sub_prev->sub_next = a->sub_next;
  -    if (a->sub_next) a->sub_next->sub_prev = a->sub_prev;
  -  }
  -  
  -  free_blocks (a->first);
  -  unblock_alarms();
  +    free_blocks(a->first);
  +    unblock_alarms();
   }
   
  -API_EXPORT(long) bytes_in_pool (pool *p) {
  -    return bytes_in_block_list (p->first);
  +API_EXPORT(long) bytes_in_pool(pool *p)
  +{
  +    return bytes_in_block_list(p->first);
   }
  -API_EXPORT(long) bytes_in_free_blocks (void) {
  -    return bytes_in_block_list (block_freelist);
  +API_EXPORT(long) bytes_in_free_blocks(void)
  +{
  +    return bytes_in_block_list(block_freelist);
   }
   
   /*****************************************************************
  @@ -346,116 +354,118 @@
    */
   
   
  -API_EXPORT(void *) palloc (struct pool *a, int reqsize)
  +API_EXPORT(void *) palloc(struct pool *a, int reqsize)
   {
  -  /* Round up requested size to an even number of alignment units (core clicks)
  -   */
  -  
  -  int nclicks = 1 + ((reqsize - 1) / CLICK_SZ);
  -  int size = nclicks * CLICK_SZ;
  -
  -  /* First, see if we have space in the block most recently
  -   * allocated to this pool
  -   */
  -  
  -  union block_hdr *blok = a->last; 
  -  char *first_avail = blok->h.first_avail;
  -  char *new_first_avail;
  -
  -  if(reqsize <= 0)
  -      return NULL;
  -  
  -  new_first_avail = first_avail + size;
  -  
  -  if (new_first_avail <= blok->h.endp) {
  -    blok->h.first_avail = new_first_avail;
  -    return (void *)first_avail;
  -  }
  -
  -  /* Nope --- get a new one that's guaranteed to be big enough */
  -  
  -  block_alarms();
  -  
  -  (void)acquire_mutex(alloc_mutex);
  -
  -  blok = new_block (size);
  -  a->last->h.next = blok;
  -  a->last = blok;
  -  
  -  (void)release_mutex(alloc_mutex);
  +    /* Round up requested size to an even number of alignment units (core clicks)
  +     */
  +
  +    int nclicks = 1 + ((reqsize - 1) / CLICK_SZ);
  +    int size = nclicks * CLICK_SZ;
   
  -  unblock_alarms();
  +    /* First, see if we have space in the block most recently
  +     * allocated to this pool
  +     */
  +
  +    union block_hdr *blok = a->last;
  +    char *first_avail = blok->h.first_avail;
  +    char *new_first_avail;
  +
  +    if (reqsize <= 0)
  +	return NULL;
  +
  +    new_first_avail = first_avail + size;
  +
  +    if (new_first_avail <= blok->h.endp) {
  +	blok->h.first_avail = new_first_avail;
  +	return (void *) first_avail;
  +    }
  +
  +    /* Nope --- get a new one that's guaranteed to be big enough */
  +
  +    block_alarms();
  +
  +    (void) acquire_mutex(alloc_mutex);
  +
  +    blok = new_block(size);
  +    a->last->h.next = blok;
  +    a->last = blok;
  +
  +    (void) release_mutex(alloc_mutex);
  +
  +    unblock_alarms();
   
  -  first_avail = blok->h.first_avail;
  -  blok->h.first_avail += size;
  +    first_avail = blok->h.first_avail;
  +    blok->h.first_avail += size;
   
  -  return (void *)first_avail;
  +    return (void *) first_avail;
   }
   
   API_EXPORT(void *) pcalloc(struct pool *a, int size)
   {
  -  void *res = palloc (a, size);
  -  memset (res, '\0', size);
  -  return res;
  +    void *res = palloc(a, size);
  +    memset(res, '\0', size);
  +    return res;
   }
   
   API_EXPORT(char *) pstrdup(struct pool *a, const char *s)
   {
  -  char *res;
  -  if (s == NULL) return NULL;
  -  res = palloc (a, strlen(s) + 1);
  -  strcpy (res, s);
  -  return res;
  +    char *res;
  +    if (s == NULL)
  +	return NULL;
  +    res = palloc(a, strlen(s) + 1);
  +    strcpy(res, s);
  +    return res;
   }
   
   API_EXPORT(char *) pstrndup(struct pool *a, const char *s, int n)
   {
  -  char *res;
  -  if (s == NULL) return NULL;
  -  res = palloc (a, n + 1);
  -  strncpy (res, s, n);
  -  res[n] = '\0';
  -  return res;
  +    char *res;
  +    if (s == NULL)
  +	return NULL;
  +    res = palloc(a, n + 1);
  +    strncpy(res, s, n);
  +    res[n] = '\0';
  +    return res;
   }
   
  -char *pstrcat(pool *a, ...)
  +char *pstrcat(pool *a,...)
   {
  -  char *cp, *argp, *res;
  -  
  -  /* Pass one --- find length of required string */
  -  
  -  int len = 0;
  -  va_list adummy;
  -  
  -  va_start (adummy, a);
  +    char *cp, *argp, *res;
  +
  +    /* Pass one --- find length of required string */
  +
  +    int len = 0;
  +    va_list adummy;
   
  -  while ((cp = va_arg (adummy, char *)) != NULL) 
  -    len += strlen(cp);
  +    va_start(adummy, a);
   
  -  va_end (adummy);
  +    while ((cp = va_arg(adummy, char *)) != NULL)
  +	     len += strlen(cp);
   
  -  /* Allocate the required string */
  +    va_end(adummy);
  +
  +    /* Allocate the required string */
  +
  +    if (len == 0) {
  +	return NULL;
  +    }
  +    res = (char *) palloc(a, len + 1);
  +    cp = res;
   
  -  if (len == 0) {
  -      return NULL;
  -  }
  -  res = (char *)palloc(a, len + 1);
  -  cp = res;
  +    /* Pass two --- copy the argument strings into the result space */
   
  -  /* Pass two --- copy the argument strings into the result space */
  +    va_start(adummy, a);
   
  -  va_start (adummy, a);
  -  
  -  while ((argp = va_arg (adummy, char *)) != NULL) {
  -    strcpy (cp, argp);
  -    cp += strlen(argp);
  -  }
  +    while ((argp = va_arg(adummy, char *)) != NULL) {
  +	strcpy(cp, argp);
  +	cp += strlen(argp);
  +    }
   
  -  va_end (adummy);
  +    va_end(adummy);
   
  -  /* Return the result string */
  +    /* Return the result string */
   
  -  return res;
  +    return res;
   }
   
   
  @@ -464,70 +474,71 @@
    * The 'array' functions...
    */
   
  -API_EXPORT(array_header *) make_array (pool *p, int nelts, int elt_size)
  +API_EXPORT(array_header *) make_array(pool *p, int nelts, int elt_size)
   {
  -  array_header *res = (array_header *)palloc(p, sizeof(array_header));
  +    array_header *res = (array_header *) palloc(p, sizeof(array_header));
   
  -  if (nelts < 1) nelts = 1;	/* Assure sanity if someone asks for
  +    if (nelts < 1)
  +	nelts = 1;		/* Assure sanity if someone asks for
   				 * array of zero elts.
   				 */
  -  
  -  res->elts = pcalloc (p, nelts * elt_size);
  -  
  -  res->pool = p;
  -  res->elt_size = elt_size;
  -  res->nelts = 0;		/* No active elements yet... */
  -  res->nalloc = nelts;		/* ...but this many allocated */
   
  -  return res;
  +    res->elts = pcalloc(p, nelts * elt_size);
  +
  +    res->pool = p;
  +    res->elt_size = elt_size;
  +    res->nelts = 0;		/* No active elements yet... */
  +    res->nalloc = nelts;	/* ...but this many allocated */
  +
  +    return res;
   }
   
  -API_EXPORT(void *) push_array (array_header *arr)
  +API_EXPORT(void *) push_array(array_header *arr)
   {
  -  if (arr->nelts == arr->nalloc) {
  -    int new_size = (arr->nalloc <= 0) ? 1 : arr->nalloc * 2;
  -    char *new_data;
  -    
  -    new_data = pcalloc (arr->pool, arr->elt_size * new_size);
  +    if (arr->nelts == arr->nalloc) {
  +	int new_size = (arr->nalloc <= 0) ? 1 : arr->nalloc * 2;
  +	char *new_data;
  +
  +	new_data = pcalloc(arr->pool, arr->elt_size * new_size);
   
  -    memcpy (new_data, arr->elts, arr->nalloc * arr->elt_size);
  -    arr->elts = new_data;
  -    arr->nalloc = new_size;
  -  }
  +	memcpy(new_data, arr->elts, arr->nalloc * arr->elt_size);
  +	arr->elts = new_data;
  +	arr->nalloc = new_size;
  +    }
   
  -  ++arr->nelts;
  -  return arr->elts + (arr->elt_size * (arr->nelts - 1));
  +    ++arr->nelts;
  +    return arr->elts + (arr->elt_size * (arr->nelts - 1));
   }
   
  -API_EXPORT(void) array_cat (array_header *dst, const array_header *src)
  +API_EXPORT(void) array_cat(array_header *dst, const array_header *src)
   {
  -  int elt_size = dst->elt_size;
  -  
  -  if (dst->nelts + src->nelts > dst->nalloc) {
  -    int new_size = (dst->nalloc <= 0) ? 1 : dst->nalloc * 2;
  -    char *new_data;
  +    int elt_size = dst->elt_size;
  +
  +    if (dst->nelts + src->nelts > dst->nalloc) {
  +	int new_size = (dst->nalloc <= 0) ? 1 : dst->nalloc * 2;
  +	char *new_data;
   
  -    while (dst->nelts + src->nelts > new_size)
  -      new_size *= 2;
  +	while (dst->nelts + src->nelts > new_size)
  +	    new_size *= 2;
   
  -    new_data = pcalloc (dst->pool, elt_size * new_size);
  -    memcpy (new_data, dst->elts, dst->nalloc * elt_size);
  -    
  -    dst->elts = new_data;
  -    dst->nalloc = new_size;
  -  }
  +	new_data = pcalloc(dst->pool, elt_size * new_size);
  +	memcpy(new_data, dst->elts, dst->nalloc * elt_size);
  +
  +	dst->elts = new_data;
  +	dst->nalloc = new_size;
  +    }
   
  -  memcpy (dst->elts + dst->nelts * elt_size, src->elts, elt_size * src->nelts);
  -  dst->nelts += src->nelts;
  +    memcpy(dst->elts + dst->nelts * elt_size, src->elts, elt_size * src->nelts);
  +    dst->nelts += src->nelts;
   }
   
  -API_EXPORT(array_header *) copy_array (pool *p, const array_header *arr)
  +API_EXPORT(array_header *) copy_array(pool *p, const array_header *arr)
   {
  -  array_header *res = make_array (p, arr->nalloc, arr->elt_size);
  +    array_header *res = make_array(p, arr->nalloc, arr->elt_size);
   
  -  memcpy (res->elts, arr->elts, arr->elt_size * arr->nelts);
  -  res->nelts = arr->nelts;
  -  return res;
  +    memcpy(res->elts, arr->elts, arr->elt_size * arr->nelts);
  +    res->nelts = arr->nelts;
  +    return res;
   }
   
   /* This cute function copies the array header *only*, but arranges
  @@ -537,30 +548,30 @@
    * overhead of the full copy only where it is really needed.
    */
   
  -API_EXPORT(array_header *) copy_array_hdr (pool *p, const array_header *arr)
  +API_EXPORT(array_header *) copy_array_hdr(pool *p, const array_header *arr)
   {
  -  array_header *res = (array_header *)palloc(p, sizeof(array_header));
  +    array_header *res = (array_header *) palloc(p, sizeof(array_header));
   
  -  res->elts = arr->elts;
  -  
  -  res->pool = p;
  -  res->elt_size = arr->elt_size;
  -  res->nelts = arr->nelts;
  -  res->nalloc = arr->nelts;	/* Force overflow on push */
  +    res->elts = arr->elts;
   
  -  return res;
  +    res->pool = p;
  +    res->elt_size = arr->elt_size;
  +    res->nelts = arr->nelts;
  +    res->nalloc = arr->nelts;	/* Force overflow on push */
  +
  +    return res;
   }
   
   /* The above is used here to avoid consing multiple new array bodies... */
   
  -API_EXPORT(array_header *) append_arrays (pool *p,
  -			     const array_header *first,
  -			     const array_header *second)
  +API_EXPORT(array_header *) append_arrays(pool *p,
  +					 const array_header *first,
  +					 const array_header *second)
   {
  -  array_header *res = copy_array_hdr (p, first);
  +    array_header *res = copy_array_hdr(p, first);
   
  -  array_cat (res, second);
  -  return res;
  +    array_cat(res, second);
  +    return res;
   }
   
   
  @@ -569,116 +580,122 @@
    * The "table" functions.
    */
   
  -API_EXPORT(table *) make_table (pool *p, int nelts) {
  -    return make_array (p, nelts, sizeof (table_entry));
  +API_EXPORT(table *) make_table(pool *p, int nelts)
  +{
  +    return make_array(p, nelts, sizeof(table_entry));
   }
   
  -API_EXPORT(table *) copy_table (pool *p, const table *t) {
  -    return copy_array (p, t);
  +API_EXPORT(table *) copy_table(pool *p, const table *t)
  +{
  +    return copy_array(p, t);
   }
   
  -API_EXPORT(void) clear_table (table *t)
  +API_EXPORT(void) clear_table(table *t)
   {
       t->nelts = 0;
   }
   
  -API_EXPORT(array_header *) table_elts (table *t) { return t; }
  +API_EXPORT(array_header *) table_elts(table *t)
  +{
  +    return t;
  +}
   
  -API_EXPORT(char *) table_get (const table *t, const char *key)
  +API_EXPORT(char *) table_get(const table *t, const char *key)
   {
  -    table_entry *elts = (table_entry *)t->elts;
  +    table_entry *elts = (table_entry *) t->elts;
       int i;
   
  -    if (key == NULL) return NULL;
  -    
  +    if (key == NULL)
  +	return NULL;
  +
       for (i = 0; i < t->nelts; ++i)
  -        if (!strcasecmp (elts[i].key, key))
  +	if (!strcasecmp(elts[i].key, key))
   	    return elts[i].val;
   
       return NULL;
   }
   
  -API_EXPORT(void) table_set (table *t, const char *key, const char *val)
  +API_EXPORT(void) table_set(table *t, const char *key, const char *val)
   {
       register int i, j, k;
  -    table_entry *elts = (table_entry *)t->elts;
  +    table_entry *elts = (table_entry *) t->elts;
       int done = 0;
   
       for (i = 0; i < t->nelts; ++i)
  -	if (!strcasecmp (elts[i].key, key)) {
  +	if (!strcasecmp(elts[i].key, key)) {
   	    if (!done) {
  -	        elts[i].val = pstrdup(t->pool, val);
  -	        done = 1;
  +		elts[i].val = pstrdup(t->pool, val);
  +		done = 1;
   	    }
  -	    else {     /* delete an extraneous element */
  -                for (j = i, k = i + 1; k < t->nelts; ++j, ++k) {
  -                    elts[j].key = elts[k].key;
  -                    elts[j].val = elts[k].val;
  -                }
  -                --t->nelts;
  +	    else {		/* delete an extraneous element */
  +		for (j = i, k = i + 1; k < t->nelts; ++j, ++k) {
  +		    elts[j].key = elts[k].key;
  +		    elts[j].val = elts[k].val;
  +		}
  +		--t->nelts;
   	    }
   	}
   
       if (!done) {
  -        elts = (table_entry *)push_array(t);
  -        elts->key = pstrdup (t->pool, key);
  -        elts->val = pstrdup (t->pool, val);
  +	elts = (table_entry *) push_array(t);
  +	elts->key = pstrdup(t->pool, key);
  +	elts->val = pstrdup(t->pool, val);
       }
   }
   
  -API_EXPORT(void) table_unset( table *t, const char *key ) 
  +API_EXPORT(void) table_unset(table *t, const char *key)
   {
  -    register int i, j, k;   
  -    table_entry *elts = (table_entry *)t->elts;
  - 
  +    register int i, j, k;
  +    table_entry *elts = (table_entry *) t->elts;
  +
       for (i = 0; i < t->nelts; ++i)
  -        if (!strcasecmp (elts[i].key, key)) {
  - 
  -            /* found an element to skip over
  -             * there are any number of ways to remove an element from
  -             * a contiguous block of memory.  I've chosen one that
  -             * doesn't do a memcpy/bcopy/array_delete, *shrug*...
  -             */
  -            for (j = i, k = i + 1; k < t->nelts; ++j, ++k) {
  -                elts[j].key = elts[k].key;
  -                elts[j].val = elts[k].val;
  -            }
  -            --t->nelts;
  -        }
  -}     
  +	if (!strcasecmp(elts[i].key, key)) {
  +
  +	    /* found an element to skip over
  +	     * there are any number of ways to remove an element from
  +	     * a contiguous block of memory.  I've chosen one that
  +	     * doesn't do a memcpy/bcopy/array_delete, *shrug*...
  +	     */
  +	    for (j = i, k = i + 1; k < t->nelts; ++j, ++k) {
  +		elts[j].key = elts[k].key;
  +		elts[j].val = elts[k].val;
  +	    }
  +	    --t->nelts;
  +	}
  +}
   
  -API_EXPORT(void) table_merge (table *t, const char *key, const char *val)
  +API_EXPORT(void) table_merge(table *t, const char *key, const char *val)
   {
  -    table_entry *elts = (table_entry *)t->elts;
  +    table_entry *elts = (table_entry *) t->elts;
       int i;
   
       for (i = 0; i < t->nelts; ++i)
  -        if (!strcasecmp (elts[i].key, key)) {
  -	    elts[i].val = pstrcat (t->pool, elts[i].val, ", ", val, NULL);
  +	if (!strcasecmp(elts[i].key, key)) {
  +	    elts[i].val = pstrcat(t->pool, elts[i].val, ", ", val, NULL);
   	    return;
   	}
   
  -    elts = (table_entry *)push_array(t);
  -    elts->key = pstrdup (t->pool, key);
  -    elts->val = pstrdup (t->pool, val);
  +    elts = (table_entry *) push_array(t);
  +    elts->key = pstrdup(t->pool, key);
  +    elts->val = pstrdup(t->pool, val);
   }
   
  -API_EXPORT(void) table_add (table *t, const char *key, const char *val)
  +API_EXPORT(void) table_add(table *t, const char *key, const char *val)
   {
  -    table_entry *elts = (table_entry *)t->elts;
  +    table_entry *elts = (table_entry *) t->elts;
   
  -    elts = (table_entry *)push_array(t);
  -    elts->key = pstrdup (t->pool, key);
  -    elts->val = pstrdup (t->pool, val);
  +    elts = (table_entry *) push_array(t);
  +    elts->key = pstrdup(t->pool, key);
  +    elts->val = pstrdup(t->pool, val);
   }
   
  -API_EXPORT(table *) overlay_tables (pool *p, const table *overlay, const table *base)
  +API_EXPORT(table *) overlay_tables(pool *p, const table *overlay, const table *base)
   {
  -    return append_arrays (p, overlay, base);
  +    return append_arrays(p, overlay, base);
   }
   
   /* And now for something completely abstract ...
  - *
  +
    * For each key value given as a vararg:
    *   run the function pointed to as
    *     int comp(void *r, char *key, char *value);
  @@ -699,24 +716,24 @@
    * Note that rec is simply passed-on to the comp function, so that the
    * caller can pass additional info for the task.
    */
  -void table_do (int (*comp)(void *, const char *, const char *), void *rec,
  -               const table *t, ...)
  +void table_do(int (*comp) (void *, const char *, const char *), void *rec,
  +	      const table *t,...)
   {
       va_list vp;
       char *argp;
  -    table_entry *elts = (table_entry *)t->elts;
  +    table_entry *elts = (table_entry *) t->elts;
       int rv, i;
  -  
  +
       va_start(vp, t);
   
       argp = va_arg(vp, char *);
   
       do {
  -        for (rv = 1, i = 0; rv && (i < t->nelts); ++i) {
  -            if (elts[i].key && (!argp || !strcasecmp(elts[i].key, argp))) {
  -                rv = (*comp)(rec, elts[i].key, elts[i].val);
  -            }
  -        }
  +	for (rv = 1, i = 0; rv && (i < t->nelts); ++i) {
  +	    if (elts[i].key && (!argp || !strcasecmp(elts[i].key, argp))) {
  +		rv = (*comp) (rec, elts[i].key, elts[i].val);
  +	    }
  +	}
       } while (argp && ((argp = va_arg(vp, char *)) != NULL));
   
       va_end(vp);
  @@ -728,70 +745,70 @@
    */
   
   struct cleanup {
  -  void *data;
  -  void (*plain_cleanup)(void *);
  -  void (*child_cleanup)(void *);
  -  struct cleanup *next;
  +    void *data;
  +    void (*plain_cleanup) (void *);
  +    void (*child_cleanup) (void *);
  +    struct cleanup *next;
   };
   
  -API_EXPORT(void) register_cleanup (pool *p, void *data, void (*plain_cleanup)(void *),
  -		       void (*child_cleanup)(void *))
  +API_EXPORT(void) register_cleanup(pool *p, void *data, void (*plain_cleanup) (void *),
  +				  void (*child_cleanup) (void *))
   {
  -  struct cleanup *c = (struct cleanup *)palloc(p, sizeof (struct cleanup));
  -  c->data = data;
  -  c->plain_cleanup = plain_cleanup;
  -  c->child_cleanup = child_cleanup;
  -  c->next = p->cleanups;
  -  p->cleanups = c;
  -}
  +    struct cleanup *c = (struct cleanup *) palloc(p, sizeof(struct cleanup));
  +    c->data = data;
  +    c->plain_cleanup = plain_cleanup;
  +    c->child_cleanup = child_cleanup;
  +    c->next = p->cleanups;
  +    p->cleanups = c;
  +}
  +
  +API_EXPORT(void) kill_cleanup(pool *p, void *data, void (*cleanup) (void *))
  +{
  +    struct cleanup *c = p->cleanups;
  +    struct cleanup **lastp = &p->cleanups;
  +
  +    while (c) {
  +	if (c->data == data && c->plain_cleanup == cleanup) {
  +	    *lastp = c->next;
  +	    break;
  +	}
   
  -API_EXPORT(void) kill_cleanup (pool *p, void *data, void (*cleanup)(void *))
  -{
  -  struct cleanup *c = p->cleanups;
  -  struct cleanup **lastp = &p->cleanups;
  -    
  -  while (c) {
  -    if (c->data == data && c->plain_cleanup == cleanup) {
  -      *lastp = c->next;
  -      break;
  +	lastp = &c->next;
  +	c = c->next;
       }
  -
  -    lastp = &c->next;
  -    c = c->next;
  -  }
   }
   
  -API_EXPORT(void) run_cleanup (pool *p, void *data, void (*cleanup)(void *))
  +API_EXPORT(void) run_cleanup(pool *p, void *data, void (*cleanup) (void *))
   {
  -  block_alarms();		/* Run cleanup only once! */
  -  (*cleanup)(data);
  -  kill_cleanup (p, data, cleanup);
  -  unblock_alarms();
  +    block_alarms();		/* Run cleanup only once! */
  +    (*cleanup) (data);
  +    kill_cleanup(p, data, cleanup);
  +    unblock_alarms();
   }
   
  -static void run_cleanups (struct cleanup *c)
  +static void run_cleanups(struct cleanup *c)
   {
  -  while (c) {
  -    (*c->plain_cleanup)(c->data);
  -    c = c->next;
  -  }
  +    while (c) {
  +	(*c->plain_cleanup) (c->data);
  +	c = c->next;
  +    }
   }
   
  -static void run_child_cleanups (struct cleanup *c)
  +static void run_child_cleanups(struct cleanup *c)
   {
  -  while (c) {
  -    (*c->child_cleanup)(c->data);
  -    c = c->next;
  -  }
  +    while (c) {
  +	(*c->child_cleanup) (c->data);
  +	c = c->next;
  +    }
   }
   
  -static void cleanup_pool_for_exec (pool *p)
  +static void cleanup_pool_for_exec(pool *p)
   {
  -  run_child_cleanups (p->cleanups);
  -  p->cleanups = NULL;
  +    run_child_cleanups(p->cleanups);
  +    p->cleanups = NULL;
   
  -  for (p = p->sub_pools; p; p = p->sub_next)
  -    cleanup_pool_for_exec (p);
  +    for (p = p->sub_pools; p; p = p->sub_next)
  +	cleanup_pool_for_exec(p);
   }
   
   API_EXPORT(void) cleanup_for_exec(void)
  @@ -806,9 +823,9 @@
        * I can do about that (except if the child decides
        * to go out and close them
        */
  -  block_alarms();
  -  cleanup_pool_for_exec (permanent_pool);
  -  unblock_alarms();
  +    block_alarms();
  +    cleanup_pool_for_exec(permanent_pool);
  +    unblock_alarms();
   #endif /* ndef WIN32 */
   }
   
  @@ -818,46 +835,50 @@
    * generic cleanup interface.
    */
   
  -static void fd_cleanup (void *fdv) { close ((int)(long)fdv); }
  +static void fd_cleanup(void *fdv)
  +{
  +    close((int) (long) fdv);
  +}
   
  -API_EXPORT(void) note_cleanups_for_fd (pool *p, int fd) {
  -  register_cleanup (p, (void *)(long)fd, fd_cleanup, fd_cleanup);
  +API_EXPORT(void) note_cleanups_for_fd(pool *p, int fd)
  +{
  +    register_cleanup(p, (void *) (long) fd, fd_cleanup, fd_cleanup);
   }
   
  -API_EXPORT(void) kill_cleanups_for_fd(pool *p,int fd)
  -    {
  -    kill_cleanup(p,(void *)(long)fd,fd_cleanup);
  -    }
  +API_EXPORT(void) kill_cleanups_for_fd(pool *p, int fd)
  +{
  +    kill_cleanup(p, (void *) (long) fd, fd_cleanup);
  +}
   
   API_EXPORT(int) popenf(pool *a, const char *name, int flg, int mode)
   {
  -  int fd;
  -  int save_errno;
  +    int fd;
  +    int save_errno;
   
  -  block_alarms();
  -  fd = open(name, flg, mode);
  -  save_errno = errno;
  -  if (fd >= 0) {
  -    fd = ap_slack (fd, AP_SLACK_HIGH);
  -    note_cleanups_for_fd (a, fd);
  -  }
  -  unblock_alarms();
  -  errno = save_errno;
  -  return fd;
  +    block_alarms();
  +    fd = open(name, flg, mode);
  +    save_errno = errno;
  +    if (fd >= 0) {
  +	fd = ap_slack(fd, AP_SLACK_HIGH);
  +	note_cleanups_for_fd(a, fd);
  +    }
  +    unblock_alarms();
  +    errno = save_errno;
  +    return fd;
   }
   
   API_EXPORT(int) pclosef(pool *a, int fd)
   {
  -  int res;
  -  int save_errno;
  -  
  -  block_alarms();
  -  res = close(fd);
  -  save_errno = errno;
  -  kill_cleanup(a, (void *)(long)fd, fd_cleanup);
  -  unblock_alarms();
  -  errno = save_errno;
  -  return res;
  +    int res;
  +    int save_errno;
  +
  +    block_alarms();
  +    res = close(fd);
  +    save_errno = errno;
  +    kill_cleanup(a, (void *) (long) fd, fd_cleanup);
  +    unblock_alarms();
  +    errno = save_errno;
  +    return res;
   }
   
   /* Note that we have separate plain_ and child_ cleanups for FILE *s,
  @@ -865,102 +886,111 @@
    * we just close the descriptor.
    */
   
  -static void file_cleanup (void *fpv) { fclose ((FILE *)fpv); }
  -static void file_child_cleanup (void *fpv) { close (fileno ((FILE *)fpv)); }
  +static void file_cleanup(void *fpv)
  +{
  +    fclose((FILE *) fpv);
  +}
  +static void file_child_cleanup(void *fpv)
  +{
  +    close(fileno((FILE *) fpv));
  +}
   
  -API_EXPORT(void) note_cleanups_for_file (pool *p, FILE *fp) {
  -  register_cleanup (p, (void *)fp, file_cleanup, file_child_cleanup);
  +API_EXPORT(void) note_cleanups_for_file(pool *p, FILE *fp)
  +{
  +    register_cleanup(p, (void *) fp, file_cleanup, file_child_cleanup);
   }
   
   API_EXPORT(FILE *) pfopen(pool *a, const char *name, const char *mode)
   {
  -  FILE *fd = NULL;
  -  int baseFlag, desc;
  -  int modeFlags = 0;
  +    FILE *fd = NULL;
  +    int baseFlag, desc;
  +    int modeFlags = 0;
   
   #ifdef WIN32
  -  modeFlags = _S_IREAD | _S_IWRITE;
  +    modeFlags = _S_IREAD | _S_IWRITE;
   #else
  -  modeFlags = S_IRUSR | S_IWUSR | S_IRGRP | S_IWGRP | S_IROTH | S_IWOTH;
  +    modeFlags = S_IRUSR | S_IWUSR | S_IRGRP | S_IWGRP | S_IROTH | S_IWOTH;
   #endif
   
  -  block_alarms();
  +    block_alarms();
  +
  +    if (*mode == 'a') {
  +	/* Work around faulty implementations of fopen */
  +	baseFlag = (*(mode + 1) == '+') ? O_RDWR : O_WRONLY;
  +	desc = open(name, baseFlag | O_APPEND | O_CREAT,
  +		    modeFlags);
  +	if (desc >= 0) {
  +	    desc = ap_slack(desc, AP_SLACK_LOW);
  +	    fd = fdopen(desc, mode);
  +	}
  +    }
  +    else {
  +	fd = fopen(name, mode);
  +    }
  +
  +    if (fd != NULL)
  +	note_cleanups_for_file(a, fd);
  +    unblock_alarms();
  +    return fd;
  +}
  +
  +API_EXPORT(FILE *) pfdopen(pool *a, int fd, const char *mode)
  +{
  +    FILE *f;
   
  -  if (*mode == 'a') {
  -    /* Work around faulty implementations of fopen */
  -    baseFlag = (*(mode+1) == '+') ? O_RDWR : O_WRONLY;
  -    desc = open(name, baseFlag | O_APPEND | O_CREAT,
  -		modeFlags);
  -    if (desc >= 0) {
  -      desc = ap_slack(desc, AP_SLACK_LOW);
  -      fd = fdopen(desc, mode);
  -    }
  -  } else {
  -    fd = fopen(name, mode);
  -  }
  -
  -  if (fd != NULL) note_cleanups_for_file (a, fd);
  -  unblock_alarms();
  -  return fd;
  -}
  -
  -API_EXPORT(FILE *) pfdopen(pool *a,int fd, const char *mode)
  -{
  -  FILE *f;
  -
  -  block_alarms();
  -  f=fdopen(fd,mode);
  -  if(f != NULL)
  -    note_cleanups_for_file(a,f);
  -  unblock_alarms();
  -  return f;
  +    block_alarms();
  +    f = fdopen(fd, mode);
  +    if (f != NULL)
  +	note_cleanups_for_file(a, f);
  +    unblock_alarms();
  +    return f;
   }
   
   
   API_EXPORT(int) pfclose(pool *a, FILE *fd)
   {
  -  int res;
  -  
  -  block_alarms();
  -  res = fclose(fd);
  -  kill_cleanup(a, (void *)fd, file_cleanup);
  -  unblock_alarms();
  -  return res;
  +    int res;
  +
  +    block_alarms();
  +    res = fclose(fd);
  +    kill_cleanup(a, (void *) fd, file_cleanup);
  +    unblock_alarms();
  +    return res;
   }
   
   /*
    * DIR * with cleanup
    */
   
  -static void dir_cleanup (void *dv)
  +static void dir_cleanup(void *dv)
   {
  -    closedir ((DIR *)dv);
  +    closedir((DIR *) dv);
   }
   
  -API_EXPORT(DIR *) popendir (pool *p, const char *name)
  +API_EXPORT(DIR *) popendir(pool *p, const char *name)
   {
       DIR *d;
       int save_errno;
   
  -    block_alarms ();
  -    d = opendir (name);
  +    block_alarms();
  +    d = opendir(name);
       if (d == NULL) {
   	save_errno = errno;
  -	unblock_alarms ();
  +	unblock_alarms();
   	errno = save_errno;
   	return NULL;
       }
  -    register_cleanup (p, (void *)d, dir_cleanup, dir_cleanup);
  -    unblock_alarms ();
  +    register_cleanup(p, (void *) d, dir_cleanup, dir_cleanup);
  +    unblock_alarms();
       return d;
   }
   
  -API_EXPORT(void) pclosedir (pool *p, DIR *d)
  +API_EXPORT(void) pclosedir(pool *p, DIR * d)
   {
  -    block_alarms ();
  -    kill_cleanup (p, (void *)d, dir_cleanup);
  -    closedir (d);
  -    unblock_alarms ();
  +    block_alarms();
  +    kill_cleanup(p, (void *) d, dir_cleanup);
  +    closedir(d);
  +    unblock_alarms();
   }
   
   /*****************************************************************
  @@ -969,52 +999,53 @@
    * generic cleanup interface.
    */
   
  -static void socket_cleanup (void *fdv)
  +static void socket_cleanup(void *fdv)
   {
  -    closesocket((int)(long)fdv);
  +    closesocket((int) (long) fdv);
   }
   
  -API_EXPORT(void) note_cleanups_for_socket (pool *p, int fd) {
  -  register_cleanup (p, (void *)(long)fd, socket_cleanup, socket_cleanup);
  +API_EXPORT(void) note_cleanups_for_socket(pool *p, int fd)
  +{
  +    register_cleanup(p, (void *) (long) fd, socket_cleanup, socket_cleanup);
   }
   
  -API_EXPORT(void) kill_cleanups_for_socket(pool *p,int sock)
  +API_EXPORT(void) kill_cleanups_for_socket(pool *p, int sock)
   {
  -    kill_cleanup(p,(void *)(long)sock,socket_cleanup);
  +    kill_cleanup(p, (void *) (long) sock, socket_cleanup);
   }
   
  -API_EXPORT(int) psocket (pool *p, int domain, int type, int protocol)
  +API_EXPORT(int) psocket(pool *p, int domain, int type, int protocol)
   {
       int fd;
   
       block_alarms();
  -    fd = socket (domain, type, protocol);
  +    fd = socket(domain, type, protocol);
       if (fd == -1) {
   	int save_errno = errno;
   	unblock_alarms();
   	errno = save_errno;
   	return -1;
       }
  -    note_cleanups_for_socket (p, fd);
  +    note_cleanups_for_socket(p, fd);
       unblock_alarms();
       return fd;
   }
   
   API_EXPORT(int) pclosesocket(pool *a, int sock)
   {
  -  int res;
  -  int save_errno;
  -  
  -  block_alarms();
  -  res = closesocket(sock);
  +    int res;
  +    int save_errno;
  +
  +    block_alarms();
  +    res = closesocket(sock);
   #ifdef WIN32
  -  errno = WSAGetLastError() - WSABASEERR;
  +    errno = WSAGetLastError() - WSABASEERR;
   #endif /* WIN32 */
  -  save_errno = errno;
  -  kill_cleanup(a, (void *)(long)sock, socket_cleanup);
  -  unblock_alarms();
  -  errno = save_errno;
  -  return res;
  +    save_errno = errno;
  +    kill_cleanup(a, (void *) (long) sock, socket_cleanup);
  +    unblock_alarms();
  +    errno = save_errno;
  +    return res;
   }
   
   
  @@ -1026,25 +1057,29 @@
    * regfree() doesn't clear it. So we don't allow it.
    */
   
  -static void regex_cleanup (void *preg) { regfree ((regex_t *)preg); }
  +static void regex_cleanup(void *preg)
  +{
  +    regfree((regex_t *) preg);
  +}
   
  -API_EXPORT(regex_t *) pregcomp(pool *p, const char *pattern, int cflags) {
  +API_EXPORT(regex_t *) pregcomp(pool *p, const char *pattern, int cflags)
  +{
       regex_t *preg = palloc(p, sizeof(regex_t));
   
       if (regcomp(preg, pattern, cflags))
   	return NULL;
   
  -    register_cleanup (p, (void *)preg, regex_cleanup, regex_cleanup);
  +    register_cleanup(p, (void *) preg, regex_cleanup, regex_cleanup);
   
       return preg;
   }
   
   
  -API_EXPORT(void) pregfree(pool *p, regex_t *reg)
  +API_EXPORT(void) pregfree(pool *p, regex_t * reg)
   {
       block_alarms();
  -    regfree (reg);
  -    kill_cleanup (p, (void *)reg, regex_cleanup);
  +    regfree(reg);
  +    kill_cleanup(p, (void *) reg, regex_cleanup);
       unblock_alarms();
   }
   
  @@ -1060,20 +1095,20 @@
    */
   
   struct process_chain {
  -  pid_t pid;
  -  enum kill_conditions kill_how;
  -  struct process_chain *next;
  +    pid_t pid;
  +    enum kill_conditions kill_how;
  +    struct process_chain *next;
   };
   
  -API_EXPORT(void) note_subprocess (pool *a, int pid, enum kill_conditions how)
  +API_EXPORT(void) note_subprocess(pool *a, int pid, enum kill_conditions how)
   {
  -  struct process_chain *new =
  -    (struct process_chain *)palloc(a, sizeof(struct process_chain));
  +    struct process_chain *new =
  +    (struct process_chain *) palloc(a, sizeof(struct process_chain));
   
  -  new->pid = pid;
  -  new->kill_how = how;
  -  new->next = a->subprocesses;
  -  a->subprocesses = new;
  +    new->pid = pid;
  +    new->kill_how = how;
  +    new->next = a->subprocesses;
  +    a->subprocesses = new;
   }
   
   #ifdef WIN32
  @@ -1089,192 +1124,193 @@
   #define BINMODE
   #endif
   
  -static int spawn_child_err_core (pool *p, int (*func)(void *), void *data,
  -		     enum kill_conditions kill_how,
  -		     int *pipe_in, int *pipe_out, int *pipe_err)
  -{
  -  int pid;
  -  int in_fds[2];
  -  int out_fds[2];
  -  int err_fds[2];
  -  int save_errno;
  -
  -  if (pipe_in && enc_pipe (in_fds) < 0) {
  -      return 0;
  -  }
  -  
  -  if (pipe_out && enc_pipe (out_fds) < 0) {
  -    save_errno = errno;
  -    if (pipe_in) {
  -      close (in_fds[0]); close (in_fds[1]);
  +static int spawn_child_err_core(pool *p, int (*func) (void *), void *data,
  +				enum kill_conditions kill_how,
  +				int *pipe_in, int *pipe_out, int *pipe_err)
  +{
  +    int pid;
  +    int in_fds[2];
  +    int out_fds[2];
  +    int err_fds[2];
  +    int save_errno;
  +
  +    if (pipe_in && enc_pipe(in_fds) < 0) {
  +	return 0;
       }
  -    errno = save_errno;
  -    return 0;
  -  }
   
  -  if (pipe_err && enc_pipe (err_fds) < 0) {
  -    save_errno = errno;
  -    if (pipe_in) {
  -      close (in_fds[0]); close (in_fds[1]);
  +    if (pipe_out && enc_pipe(out_fds) < 0) {
  +	save_errno = errno;
  +	if (pipe_in) {
  +	    close(in_fds[0]);
  +	    close(in_fds[1]);
  +	}
  +	errno = save_errno;
  +	return 0;
       }
  -    if (pipe_out) {
  -      close (out_fds[0]); close (out_fds[1]);
  +
  +    if (pipe_err && enc_pipe(err_fds) < 0) {
  +	save_errno = errno;
  +	if (pipe_in) {
  +	    close(in_fds[0]);
  +	    close(in_fds[1]);
  +	}
  +	if (pipe_out) {
  +	    close(out_fds[0]);
  +	    close(out_fds[1]);
  +	}
  +	errno = save_errno;
  +	return 0;
       }
  -    errno = save_errno;
  -    return 0;
  -  }
   
   #ifdef WIN32
   
  -  {
  -      HANDLE thread_handle;
  -      int hStdIn, hStdOut, hStdErr;
  -      int old_priority;
  -      
  -      (void)acquire_mutex(spawn_mutex);
  -      thread_handle = GetCurrentThread(); /* doesn't need to be closed */
  -      old_priority = GetThreadPriority(thread_handle);
  -      SetThreadPriority(thread_handle, THREAD_PRIORITY_HIGHEST);
  -      /* Now do the right thing with your pipes */
  -      if(pipe_in)
  -      {
  -          hStdIn = dup(fileno(stdin));
  -          dup2(in_fds[0], fileno(stdin));
  -          close(in_fds[0]);
  -      }
  -      if(pipe_out)
  -      {
  -          hStdOut = dup(fileno(stdout));
  -          dup2(out_fds[1], fileno(stdout));
  -          close(out_fds[1]);
  -      }
  -      if(pipe_err)
  -      {
  -          hStdErr = dup(fileno(stderr));
  -          dup2(err_fds[1], fileno(stderr));
  -          close(err_fds[1]);
  -      }
  -
  -      pid = (*func)(data);
  -      if(!pid)
  -      {
  -          save_errno = errno;
  -          close(in_fds[1]);
  -          close(out_fds[0]);
  -          close(err_fds[0]);
  -      }
  -
  -      /* restore the original stdin, stdout and stderr */
  -      if(pipe_in)
  -          dup2(hStdIn, fileno(stdin));
  -      if(pipe_out)
  -          dup2(hStdOut, fileno(stdout));
  -      if(pipe_err)
  -          dup2(hStdErr, fileno(stderr));
  -
  -      if(pid)
  -      {
  -          note_subprocess(p, pid, kill_how);
  -          if(pipe_in) {
  -	      *pipe_in = in_fds[1];
  -          }
  -          if(pipe_out) {
  -	      *pipe_out = out_fds[0];
  -          }
  -          if(pipe_err) {
  -              *pipe_err = err_fds[0];
  -          }
  -      }
  -      SetThreadPriority(thread_handle, old_priority);
  -      (void)release_mutex(spawn_mutex);
  -      /*
  -       * go on to the end of the function, where you can
  -       * unblock alarms and return the pid
  -       */
  +    {
  +	HANDLE thread_handle;
  +	int hStdIn, hStdOut, hStdErr;
  +	int old_priority;
  +
  +	(void) acquire_mutex(spawn_mutex);
  +	thread_handle = GetCurrentThread();	/* doesn't need to be closed */
  +	old_priority = GetThreadPriority(thread_handle);
  +	SetThreadPriority(thread_handle, THREAD_PRIORITY_HIGHEST);
  +	/* Now do the right thing with your pipes */
  +	if (pipe_in) {
  +	    hStdIn = dup(fileno(stdin));
  +	    dup2(in_fds[0], fileno(stdin));
  +	    close(in_fds[0]);
  +	}
  +	if (pipe_out) {
  +	    hStdOut = dup(fileno(stdout));
  +	    dup2(out_fds[1], fileno(stdout));
  +	    close(out_fds[1]);
  +	}
  +	if (pipe_err) {
  +	    hStdErr = dup(fileno(stderr));
  +	    dup2(err_fds[1], fileno(stderr));
  +	    close(err_fds[1]);
  +	}
   
  -  }
  -#else
  +	pid = (*func) (data);
  +	if (!pid) {
  +	    save_errno = errno;
  +	    close(in_fds[1]);
  +	    close(out_fds[0]);
  +	    close(err_fds[0]);
  +	}
  +
  +	/* restore the original stdin, stdout and stderr */
  +	if (pipe_in)
  +	    dup2(hStdIn, fileno(stdin));
  +	if (pipe_out)
  +	    dup2(hStdOut, fileno(stdout));
  +	if (pipe_err)
  +	    dup2(hStdErr, fileno(stderr));
  +
  +	if (pid) {
  +	    note_subprocess(p, pid, kill_how);
  +	    if (pipe_in) {
  +		*pipe_in = in_fds[1];
  +	    }
  +	    if (pipe_out) {
  +		*pipe_out = out_fds[0];
  +	    }
  +	    if (pipe_err) {
  +		*pipe_err = err_fds[0];
  +	    }
  +	}
  +	SetThreadPriority(thread_handle, old_priority);
  +	(void) release_mutex(spawn_mutex);
  +	/*
  +	 * go on to the end of the function, where you can
  +	 * unblock alarms and return the pid
  +	 */
   
  -  if ((pid = fork()) < 0) {
  -    save_errno = errno;
  -    if (pipe_in) {
  -      close (in_fds[0]); close (in_fds[1]);
       }
  -    if (pipe_out) {
  -      close (out_fds[0]); close (out_fds[1]);
  +#else
  +
  +    if ((pid = fork()) < 0) {
  +	save_errno = errno;
  +	if (pipe_in) {
  +	    close(in_fds[0]);
  +	    close(in_fds[1]);
  +	}
  +	if (pipe_out) {
  +	    close(out_fds[0]);
  +	    close(out_fds[1]);
  +	}
  +	if (pipe_err) {
  +	    close(err_fds[0]);
  +	    close(err_fds[1]);
  +	}
  +	errno = save_errno;
  +	return 0;
       }
  -    if (pipe_err) {
  -      close (err_fds[0]); close (err_fds[1]);
  +
  +    if (!pid) {
  +	/* Child process */
  +
  +	if (pipe_out) {
  +	    close(out_fds[0]);
  +	    dup2(out_fds[1], STDOUT_FILENO);
  +	    close(out_fds[1]);
  +	}
  +
  +	if (pipe_in) {
  +	    close(in_fds[1]);
  +	    dup2(in_fds[0], STDIN_FILENO);
  +	    close(in_fds[0]);
  +	}
  +
  +	if (pipe_err) {
  +	    close(err_fds[0]);
  +	    dup2(err_fds[1], STDERR_FILENO);
  +	    close(err_fds[1]);
  +	}
  +
  +	/* HP-UX SIGCHLD fix goes here, if someone will remind me what it is... */
  +	signal(SIGCHLD, SIG_DFL);	/* Was that it? */
  +
  +	func(data);
  +	exit(1);		/* Should only get here if the exec in func() failed */
       }
  -    errno = save_errno;
  -    return 0;
  -  }
   
  -  if (!pid) {
  -    /* Child process */
  -    
  +    /* Parent process */
  +
  +    note_subprocess(p, pid, kill_how);
  +
       if (pipe_out) {
  -      close (out_fds[0]);
  -      dup2 (out_fds[1], STDOUT_FILENO);
  -      close (out_fds[1]);
  +	close(out_fds[1]);
  +	*pipe_out = out_fds[0];
       }
   
       if (pipe_in) {
  -      close (in_fds[1]);
  -      dup2 (in_fds[0], STDIN_FILENO);
  -      close (in_fds[0]);
  +	close(in_fds[0]);
  +	*pipe_in = in_fds[1];
       }
   
       if (pipe_err) {
  -      close (err_fds[0]);
  -      dup2 (err_fds[1], STDERR_FILENO);
  -      close (err_fds[1]);
  -    }
  -
  -    /* HP-UX SIGCHLD fix goes here, if someone will remind me what it is... */
  -    signal (SIGCHLD, SIG_DFL);	/* Was that it? */
  -    
  -    func (data);
  -    exit (1);		/* Should only get here if the exec in func() failed */
  -  }
  -
  -  /* Parent process */
  -
  -  note_subprocess (p, pid, kill_how);
  -  
  -  if (pipe_out) {
  -    close (out_fds[1]);
  -    *pipe_out = out_fds[0];
  -  }
  -
  -  if (pipe_in) {
  -    close (in_fds[0]);
  -    *pipe_in = in_fds[1];
  -  }
  -
  -  if (pipe_err) {
  -    close (err_fds[1]);
  -    *pipe_err = err_fds[0];
  -  }
  +	close(err_fds[1]);
  +	*pipe_err = err_fds[0];
  +    }
   #endif /* WIN32 */
   
  -  return pid;
  +    return pid;
   }
   
   
  -API_EXPORT(int) spawn_child_err (pool *p, int (*func)(void *), void *data,
  -		     enum kill_conditions kill_how,
  -		     FILE **pipe_in, FILE **pipe_out, FILE **pipe_err)
  +API_EXPORT(int) spawn_child_err(pool *p, int (*func) (void *), void *data,
  +				enum kill_conditions kill_how,
  +			   FILE **pipe_in, FILE **pipe_out, FILE **pipe_err)
   {
       int fd_in, fd_out, fd_err;
       int pid, save_errno;
   
       block_alarms();
   
  -    pid = spawn_child_err_core (p, func, data, kill_how,
  -	    pipe_in ? &fd_in : NULL,
  -	    pipe_out ? &fd_out : NULL,
  -	    pipe_err ? &fd_err : NULL );
  +    pid = spawn_child_err_core(p, func, data, kill_how,
  +			       pipe_in ? &fd_in : NULL,
  +			       pipe_out ? &fd_out : NULL,
  +			       pipe_err ? &fd_err : NULL);
   
       if (pid == 0) {
   	save_errno = errno;
  @@ -1284,21 +1320,27 @@
       }
   
       if (pipe_out) {
  -	*pipe_out = fdopen (fd_out, "r" BINMODE);
  -	if (*pipe_out) note_cleanups_for_file (p, *pipe_out);
  -	else close (fd_out);
  +	*pipe_out = fdopen(fd_out, "r" BINMODE);
  +	if (*pipe_out)
  +	    note_cleanups_for_file(p, *pipe_out);
  +	else
  +	    close(fd_out);
       }
   
       if (pipe_in) {
  -	*pipe_in = fdopen (fd_in, "w" BINMODE);
  -	if (*pipe_in) note_cleanups_for_file (p, *pipe_in);
  -	else close (fd_in);
  +	*pipe_in = fdopen(fd_in, "w" BINMODE);
  +	if (*pipe_in)
  +	    note_cleanups_for_file(p, *pipe_in);
  +	else
  +	    close(fd_in);
       }
   
       if (pipe_err) {
  -	*pipe_err = fdopen (fd_err, "r" BINMODE);
  -	if (*pipe_err) note_cleanups_for_file (p, *pipe_err);
  -	else close (fd_err);
  +	*pipe_err = fdopen(fd_err, "r" BINMODE);
  +	if (*pipe_err)
  +	    note_cleanups_for_file(p, *pipe_err);
  +	else
  +	    close(fd_err);
       }
   
       unblock_alarms();
  @@ -1306,19 +1348,19 @@
   }
   
   
  -API_EXPORT(int) spawn_child_err_buff (pool *p, int (*func)(void *), void *data,
  -			  enum kill_conditions kill_how,
  -			  BUFF **pipe_in, BUFF **pipe_out, BUFF **pipe_err)
  +API_EXPORT(int) spawn_child_err_buff(pool *p, int (*func) (void *), void *data,
  +				     enum kill_conditions kill_how,
  +			   BUFF **pipe_in, BUFF **pipe_out, BUFF **pipe_err)
   {
       int fd_in, fd_out, fd_err;
       int pid, save_errno;
   
       block_alarms();
   
  -    pid = spawn_child_err_core (p, func, data, kill_how,
  -	    pipe_in ? &fd_in : NULL,
  -	    pipe_out ? &fd_out : NULL,
  -	    pipe_err ? &fd_err : NULL );
  +    pid = spawn_child_err_core(p, func, data, kill_how,
  +			       pipe_in ? &fd_in : NULL,
  +			       pipe_out ? &fd_out : NULL,
  +			       pipe_err ? &fd_err : NULL);
   
       if (pid == 0) {
   	save_errno = errno;
  @@ -1326,22 +1368,22 @@
   	errno = save_errno;
   	return 0;
       }
  -  
  +
       if (pipe_out) {
   	*pipe_out = bcreate(p, B_RD);
  -	note_cleanups_for_fd (p, fd_out);
  +	note_cleanups_for_fd(p, fd_out);
   	bpushfd(*pipe_out, fd_out, fd_out);
       }
   
       if (pipe_in) {
   	*pipe_in = bcreate(p, B_WR);
  -	note_cleanups_for_fd (p, fd_in);
  +	note_cleanups_for_fd(p, fd_in);
   	bpushfd(*pipe_in, fd_in, fd_in);
       }
   
       if (pipe_err) {
   	*pipe_err = bcreate(p, B_RD);
  -	note_cleanups_for_fd (p, fd_err);
  +	note_cleanups_for_fd(p, fd_err);
   	bpushfd(*pipe_err, fd_err, fd_err);
       }
   
  @@ -1349,96 +1391,100 @@
       return pid;
   }
   
  -static void free_proc_chain (struct process_chain *procs)
  +static void free_proc_chain(struct process_chain *procs)
   {
  -  /* Dispose of the subprocesses we've spawned off in the course of
  -   * whatever it was we're cleaning up now.  This may involve killing
  -   * some of them off...
  -   */
  -
  -  struct process_chain *p;
  -  int need_timeout = 0;
  -  int status;
  -
  -  if (procs == NULL) return;	/* No work.  Whew! */
  -
  -  /* First, check to see if we need to do the SIGTERM, sleep, SIGKILL
  -   * dance with any of the processes we're cleaning up.  If we've got
  -   * any kill-on-sight subprocesses, ditch them now as well, so they
  -   * don't waste any more cycles doing whatever it is that they shouldn't
  -   * be doing anymore.
  -   */
  +    /* Dispose of the subprocesses we've spawned off in the course of
  +     * whatever it was we're cleaning up now.  This may involve killing
  +     * some of them off...
  +     */
  +
  +    struct process_chain *p;
  +    int need_timeout = 0;
  +    int status;
  +
  +    if (procs == NULL)
  +	return;			/* No work.  Whew! */
  +
  +    /* First, check to see if we need to do the SIGTERM, sleep, SIGKILL
  +     * dance with any of the processes we're cleaning up.  If we've got
  +     * any kill-on-sight subprocesses, ditch them now as well, so they
  +     * don't waste any more cycles doing whatever it is that they shouldn't
  +     * be doing anymore.
  +     */
   #ifdef WIN32
  -  /* Pick up all defunct processes */
  -  for (p = procs; p; p = p->next) {
  -    if (GetExitCodeProcess((HANDLE)p->pid, &status)) {
  -      p->kill_how = kill_never;
  -    }
  -  }
  -
  -
  -  for (p = procs; p; p = p->next) {
  -    if (p->kill_how == kill_after_timeout) {
  -	need_timeout = 1;
  -    } else if (p->kill_how == kill_always) {
  -      TerminateProcess((HANDLE)p->pid, 1);
  -    }
  -  }
  -  /* Sleep only if we have to... */
  -
  -  if (need_timeout) sleep (3);
  -
  -  /* OK, the scripts we just timed out for have had a chance to clean up
  -   * --- now, just get rid of them, and also clean up the system accounting
  -   * goop...
  -   */
  -
  -  for (p = procs; p; p = p->next){
  -    if (p->kill_how == kill_after_timeout) 
  -      TerminateProcess((HANDLE)p->pid, 1);
  -  }
  -
  -  for (p = procs; p; p = p->next){
  -    CloseHandle((HANDLE)p->pid);
  -  }
  +    /* Pick up all defunct processes */
  +    for (p = procs; p; p = p->next) {
  +	if (GetExitCodeProcess((HANDLE) p->pid, &status)) {
  +	    p->kill_how = kill_never;
  +	}
  +    }
  +
  +
  +    for (p = procs; p; p = p->next) {
  +	if (p->kill_how == kill_after_timeout) {
  +	    need_timeout = 1;
  +	}
  +	else if (p->kill_how == kill_always) {
  +	    TerminateProcess((HANDLE) p->pid, 1);
  +	}
  +    }
  +    /* Sleep only if we have to... */
  +
  +    if (need_timeout)
  +	sleep(3);
  +
  +    /* OK, the scripts we just timed out for have had a chance to clean up
  +     * --- now, just get rid of them, and also clean up the system accounting
  +     * goop...
  +     */
  +
  +    for (p = procs; p; p = p->next) {
  +	if (p->kill_how == kill_after_timeout)
  +	    TerminateProcess((HANDLE) p->pid, 1);
  +    }
  +
  +    for (p = procs; p; p = p->next) {
  +	CloseHandle((HANDLE) p->pid);
  +    }
   #else
   #ifndef NEED_WAITPID
  -  /* Pick up all defunct processes */
  -  for (p = procs; p; p = p->next) {
  -    if (waitpid (p->pid, (int *) 0, WNOHANG) > 0) {
  -      p->kill_how = kill_never;
  +    /* Pick up all defunct processes */
  +    for (p = procs; p; p = p->next) {
  +	if (waitpid(p->pid, (int *) 0, WNOHANG) > 0) {
  +	    p->kill_how = kill_never;
  +	}
       }
  -  }
   #endif
   
  -  for (p = procs; p; p = p->next) {
  -    if ((p->kill_how == kill_after_timeout)
  -	|| (p->kill_how == kill_only_once)) {
  -      /* Subprocess may be dead already.  Only need the timeout if not. */
  -      if (kill (p->pid, SIGTERM) != -1)
  -	need_timeout = 1;
  -    } else if (p->kill_how == kill_always) {
  -      kill (p->pid, SIGKILL);
  -    }
  -  }
  -
  -  /* Sleep only if we have to... */
  -
  -  if (need_timeout) sleep (3);
  -
  -  /* OK, the scripts we just timed out for have had a chance to clean up
  -   * --- now, just get rid of them, and also clean up the system accounting
  -   * goop...
  -   */
  -
  -  for (p = procs; p; p = p->next){
  -    
  -    if (p->kill_how == kill_after_timeout) 
  -      kill (p->pid, SIGKILL);
  -
  -    if (p->kill_how != kill_never)
  -      waitpid (p->pid, &status, 0);
  -  }
  +    for (p = procs; p; p = p->next) {
  +	if ((p->kill_how == kill_after_timeout)
  +	    || (p->kill_how == kill_only_once)) {
  +	    /* Subprocess may be dead already.  Only need the timeout if not. */
  +	    if (kill(p->pid, SIGTERM) != -1)
  +		need_timeout = 1;
  +	}
  +	else if (p->kill_how == kill_always) {
  +	    kill(p->pid, SIGKILL);
  +	}
  +    }
  +
  +    /* Sleep only if we have to... */
  +
  +    if (need_timeout)
  +	sleep(3);
  +
  +    /* OK, the scripts we just timed out for have had a chance to clean up
  +     * --- now, just get rid of them, and also clean up the system accounting
  +     * goop...
  +     */
  +
  +    for (p = procs; p; p = p->next) {
  +
  +	if (p->kill_how == kill_after_timeout)
  +	    kill(p->pid, SIGKILL);
  +
  +	if (p->kill_how != kill_never)
  +	    waitpid(p->pid, &status, 0);
  +    }
   #endif /* WIN32 */
   }
  -
  
  
  
  1.34      +67 -65    apachen/src/main/alloc.h
  
  Index: alloc.h
  ===================================================================
  RCS file: /export/home/cvs/apachen/src/main/alloc.h,v
  retrieving revision 1.33
  retrieving revision 1.34
  diff -u -r1.33 -r1.34
  --- alloc.h	1997/08/13 08:37:17	1.33
  +++ alloc.h	1997/09/14 11:36:33	1.34
  @@ -81,18 +81,18 @@
   
   extern pool *permanent_pool;
   void init_alloc(void);		/* Set up everything */
  -API_EXPORT(pool *) make_sub_pool (pool *);	/* All pools are subpools of permanent_pool */
  -API_EXPORT(void) destroy_pool (pool *);
  +API_EXPORT(pool *) make_sub_pool(pool *);	/* All pools are subpools of permanent_pool */
  +API_EXPORT(void) destroy_pool(pool *);
   
   /* Clearing out EVERYTHING in an pool... destroys any sub-pools */
   
  -API_EXPORT(void) clear_pool (struct pool *);
  +API_EXPORT(void) clear_pool(struct pool *);
   
   /* Preparing for exec() --- close files, etc., but *don't* flush I/O
    * buffers, *don't* wait for subprocesses, and *don't* free any memory.
    */
   
  -API_EXPORT(void) cleanup_for_exec (void);
  +API_EXPORT(void) cleanup_for_exec(void);
   
   /* routines to allocate memory from an pool... */
   
  @@ -100,34 +100,34 @@
   API_EXPORT(void *) pcalloc(struct pool *, int nbytes);
   API_EXPORT(char *) pstrdup(struct pool *, const char *s);
   API_EXPORT(char *) pstrndup(struct pool *, const char *s, int n);
  -API_EXPORT(char *) pstrcat(struct pool *, ...); /* all '...' must be char* */
  +API_EXPORT(char *) pstrcat(struct pool *,...);	/* all '...' must be char* */
   
   /* array and alist management... keeping lists of things.
    * Common enough to want common support code ...
    */
   
  -typedef struct {
  -    pool *pool;
  -    int elt_size;
  -    int nelts;
  -    int nalloc;
  -    char *elts;
  -} array_header;
  -
  -API_EXPORT(array_header *) make_array (pool *p, int nelts, int elt_size);
  -API_EXPORT(void *) push_array (array_header *);
  -API_EXPORT(void) array_cat (array_header *dst, const array_header *src);
  -API_EXPORT(array_header *) append_arrays (pool *, const array_header *,
  -			     const array_header *);
  +     typedef struct {
  +	 pool *pool;
  +	 int elt_size;
  +	 int nelts;
  +	 int nalloc;
  +	 char *elts;
  +     } array_header;
  +
  +API_EXPORT(array_header *) make_array(pool *p, int nelts, int elt_size);
  +API_EXPORT(void *) push_array(array_header *);
  +API_EXPORT(void) array_cat(array_header *dst, const array_header *src);
  +API_EXPORT(array_header *) append_arrays(pool *, const array_header *,
  +					 const array_header *);
   
   /* copy_array copies the *entire* array.  copy_array_hdr just copies
    * the header, and arranges for the elements to be copied if (and only
    * if) the code subsequently does a push or arraycat.
    */
  -     
  -API_EXPORT(array_header *) copy_array (pool *p, const array_header *src);
  -API_EXPORT(array_header *) copy_array_hdr (pool *p, const array_header *src);
  -			   
  +
  +API_EXPORT(array_header *) copy_array(pool *p, const array_header *src);
  +API_EXPORT(array_header *) copy_array_hdr(pool *p, const array_header *src);
  +
   
   /* Tables.  Implemented alist style, for now, though we try to keep
    * it so that imposing a hash table structure on top in the future
  @@ -138,29 +138,29 @@
    * currently being used...
    */
   
  -typedef array_header table;     
  -     
  -typedef struct {
  -    char *key;			/* maybe NULL in future;
  +     typedef array_header table;
  +
  +     typedef struct {
  +	 char *key;		/* maybe NULL in future;
   				 * check when iterating thru table_elts
   				 */
  -    char *val;
  -} table_entry;
  +	 char *val;
  +     } table_entry;
   
  -API_EXPORT(table *) make_table (pool *p, int nelts);
  -API_EXPORT(table *) copy_table (pool *p, const table *);     
  -API_EXPORT(void) clear_table (table *);     
  -API_EXPORT(char *) table_get (const table *, const char *);
  -API_EXPORT(void) table_set (table *, const char *name, const char *val);
  -API_EXPORT(void) table_merge (table *, const char *name, const char *more_val);
  -API_EXPORT(void) table_unset (table *, const char *key);
  -API_EXPORT(void) table_add (table *, const char *name, const char *val);
  -API_EXPORT(void) table_do (int (*comp)(void *, const char *, const char *), void *rec,
  -               const table *t, ...);
  +API_EXPORT(table *) make_table(pool *p, int nelts);
  +API_EXPORT(table *) copy_table(pool *p, const table *);
  +API_EXPORT(void) clear_table(table *);
  +API_EXPORT(char *) table_get(const table *, const char *);
  +API_EXPORT(void) table_set(table *, const char *name, const char *val);
  +API_EXPORT(void) table_merge(table *, const char *name, const char *more_val);
  +API_EXPORT(void) table_unset(table *, const char *key);
  +API_EXPORT(void) table_add(table *, const char *name, const char *val);
  +API_EXPORT(void) table_do(int (*comp) (void *, const char *, const char *), void *rec,
  +			  const table *t,...);
   
  -API_EXPORT(table *) overlay_tables (pool *p, const table *overlay, const table *base);     
  +API_EXPORT(table *) overlay_tables(pool *p, const table *overlay, const table *base);
   
  -API_EXPORT(array_header *) table_elts (table *);     
  +API_EXPORT(array_header *) table_elts(table *);
   
   #define is_empty_table(t) (((t) == NULL)||((t)->nelts == 0))
   
  @@ -186,12 +186,12 @@
    * unblock_alarms() below...
    */
   
  -API_EXPORT(void) register_cleanup (pool *p, void *data,
  -		       void (*plain_cleanup)(void *),
  -		       void (*child_cleanup)(void *));
  +API_EXPORT(void) register_cleanup(pool *p, void *data,
  +				  void (*plain_cleanup) (void *),
  +				  void (*child_cleanup) (void *));
   
  -API_EXPORT(void) kill_cleanup (pool *p, void *data, void (*plain_cleanup)(void *));
  -API_EXPORT(void) run_cleanup (pool *p, void *data, void (*cleanup)(void *));
  +API_EXPORT(void) kill_cleanup(pool *p, void *data, void (*plain_cleanup) (void *));
  +API_EXPORT(void) run_cleanup(pool *p, void *data, void (*cleanup) (void *));
   
   /* The time between when a resource is actually allocated, and when it
    * its cleanup is registered is a critical section, during which the
  @@ -212,19 +212,19 @@
   
   API_EXPORT(FILE *) pfopen(struct pool *, const char *name, const char *fmode);
   API_EXPORT(FILE *) pfdopen(struct pool *, int fd, const char *fmode);
  -API_EXPORT(int) popenf(struct pool *, const char *name, int flg, int mode); 
  +API_EXPORT(int) popenf(struct pool *, const char *name, int flg, int mode);
   
  -API_EXPORT(void) note_cleanups_for_file (pool *, FILE *);
  -API_EXPORT(void) note_cleanups_for_fd (pool *, int);
  -API_EXPORT(void) kill_cleanups_for_fd (pool *p, int fd);
  -
  -API_EXPORT(void) note_cleanups_for_socket (pool *, int);
  -API_EXPORT(void) kill_cleanups_for_socket (pool *p, int sock);
  -API_EXPORT(int) psocket (pool *p, int, int, int);
  +API_EXPORT(void) note_cleanups_for_file(pool *, FILE *);
  +API_EXPORT(void) note_cleanups_for_fd(pool *, int);
  +API_EXPORT(void) kill_cleanups_for_fd(pool *p, int fd);
  +
  +API_EXPORT(void) note_cleanups_for_socket(pool *, int);
  +API_EXPORT(void) kill_cleanups_for_socket(pool *p, int sock);
  +API_EXPORT(int) psocket(pool *p, int, int, int);
   API_EXPORT(int) pclosesocket(pool *a, int sock);
   
  -API_EXPORT(regex_t *) pregcomp (pool *p, const char *pattern, int cflags);
  -API_EXPORT(void) pregfree (pool *p, regex_t *reg);
  +API_EXPORT(regex_t *) pregcomp(pool *p, const char *pattern, int cflags);
  +API_EXPORT(void) pregfree(pool *p, regex_t * reg);
   
   /* routines to note closes... file descriptors are constrained enough
    * on some systems that we want to support this.
  @@ -234,8 +234,8 @@
   API_EXPORT(int) pclosef(struct pool *, int fd);
   
   /* routines to deal with directories */
  -API_EXPORT(DIR *) popendir (pool *p, const char *name);
  -API_EXPORT(void) pclosedir (pool *p, DIR *d);
  +API_EXPORT(DIR *) popendir(pool *p, const char *name);
  +API_EXPORT(void) pclosedir(pool *p, DIR * d);
   
   /* ... even child processes (which we may want to wait for,
    * or to kill outright, on unexpected termination).
  @@ -246,14 +246,16 @@
    * set the associated args to NULL).  It takes as args a function
    * to call in the child, and an argument to be passed to the function.
    */
  -     
  -enum kill_conditions { kill_never, kill_always, kill_after_timeout, just_wait,
  -    kill_only_once };
  -
  -API_EXPORT(void) note_subprocess (pool *a, int pid, enum kill_conditions how);
  -API_EXPORT(int) spawn_child_err (pool *, int (*)(void *), void *,
  -		 enum kill_conditions, FILE **pipe_in, FILE **pipe_out,
  -                 FILE **pipe_err);
  +
  +     enum kill_conditions {
  +	 kill_never, kill_always, kill_after_timeout, just_wait,
  +	 kill_only_once
  +     };
  +
  +API_EXPORT(void) note_subprocess(pool *a, int pid, enum kill_conditions how);
  +API_EXPORT(int) spawn_child_err(pool *, int (*)(void *), void *,
  +		      enum kill_conditions, FILE **pipe_in, FILE **pipe_out,
  +				FILE **pipe_err);
   #define spawn_child(p,f,v,k,in,out) spawn_child_err(p,f,v,k,in,out,NULL)
   
   /* magic numbers --- min free bytes to consider a free pool block useable,