You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apr.apache.org by ia...@apache.org on 2001/09/09 07:54:35 UTC

cvs commit: apr-util/include apr_base64.h apr_buckets.h apr_date.h apr_dbm.h apr_hooks.h apr_md4.h apr_optional.h apr_optional_hooks.h apr_sdbm.h apu.h.in apu.hw

ianh        01/09/08 22:54:35

  Modified:    include  apr_base64.h apr_buckets.h apr_date.h apr_dbm.h
                        apr_hooks.h apr_md4.h apr_optional.h
                        apr_optional_hooks.h apr_sdbm.h apu.h.in apu.hw
  Log:
  DOxygen'ization of header files
  
  Revision  Changes    Path
  1.17      +8 -7      apr-util/include/apr_base64.h
  
  Index: apr_base64.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_base64.h,v
  retrieving revision 1.16
  retrieving revision 1.17
  diff -u -r1.16 -r1.17
  --- apr_base64.h	2001/02/16 04:17:10	1.16
  +++ apr_base64.h	2001/09/09 05:54:35	1.17
  @@ -56,6 +56,10 @@
    * Tsirigotis <pa...@alumni.cs.colorado.edu> for xinetd.
    */
   
  +/**
  + * @file apr_base64.h
  + * @brief APR-UTIL Base64 Encoding
  + */
   #ifndef APR_BASE64_H
   #define APR_BASE64_H
   
  @@ -67,7 +71,9 @@
   #endif
   
   /**
  - * @package Base64 Encoding
  + * @defgroup APR_Util_Base64 Base64 Encoding
  + * @ingroup APR_Util
  + * @{
    */
   
   /* Simple BASE64 encode/decode functions.
  @@ -88,7 +94,6 @@
    * encrypted string.
    * @param len the length of an unencrypted string.
    * @return the length of the string after it is encrypted
  - * @deffunc int apr_base64_encode_len(int len)
    */ 
   APU_DECLARE(int) apr_base64_encode_len(int len);
   
  @@ -98,7 +103,6 @@
    * @param plain_src The original string in plain text
    * @param len_plain_src The length of the plain text string
    * @return the length of the encoded string
  - * @deffunc int apr_base64_encode(char *coded_dst, const char *plain_src, int len_plain_src)
    */ 
   APU_DECLARE(int) apr_base64_encode(char * coded_dst, const char *plain_src, 
                                    int len_plain_src);
  @@ -109,7 +113,6 @@
    * @param plain_src The original string in plain text
    * @param len_plain_src The length of the plain text string
    * @return the length of the encoded string
  - * @deffunc int apr_base64_encode_binary(char *coded_dst, const char *plain_src, int len_plain_src)
    */ 
   APU_DECLARE(int) apr_base64_encode_binary(char * coded_dst, 
                                           const unsigned char *plain_src,
  @@ -119,7 +122,6 @@
    * Determine the length of a plain text string given the encoded version
    * @param coded_src The encoded string
    * @return the length of the plain text string
  - * @deffunc int apr_base64_decode_len(const char *coded_src)
    */ 
   APU_DECLARE(int) apr_base64_decode_len(const char * coded_src);
   
  @@ -128,7 +130,6 @@
    * @param plain_dst The destination string for the plain text
    * @param coded_src The encoded string 
    * @return the length of the plain text string
  - * @deffunc int apr_base64_decode(char *plain_dst, const char *coded_src)
    */ 
   APU_DECLARE(int) apr_base64_decode(char * plain_dst, const char *coded_src);
   
  @@ -137,11 +138,11 @@
    * @param plain_dst The destination string for the plain text
    * @param coded_src The encoded string 
    * @return the length of the plain text string
  - * @deffunc int apr_base64_decode_binary(char *plain_dst, const char *coded_src)
    */ 
   APU_DECLARE(int) apr_base64_decode_binary(unsigned char * plain_dst, 
                                           const char *coded_src);
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.117     +22 -93    apr-util/include/apr_buckets.h
  
  Index: apr_buckets.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_buckets.h,v
  retrieving revision 1.116
  retrieving revision 1.117
  diff -u -r1.116 -r1.117
  --- apr_buckets.h	2001/08/31 20:39:09	1.116
  +++ apr_buckets.h	2001/09/09 05:54:35	1.117
  @@ -51,6 +51,10 @@
    * information on the Apache Software Foundation, please see
    * <http://www.apache.org/>.
    */
  +/**
  + * @file apr_buckets.h
  + * @brief APR-UTIL Buckets/Bucket Brigades
  + */
   
   #ifndef APR_BUCKETS_H
   #define APR_BUCKETS_H
  @@ -76,17 +80,20 @@
   #endif
   
   /**
  - * @package Bucket Brigades
  + * @defgroup APR_Util_Bucket_Brigades Bucket Brigades
  + * @ingroup APR_Util
  + * @{ 
    */
   
  +/** default bucket buffer size */
   #define APR_BUCKET_BUFF_SIZE 8192
   
   typedef enum {
  -    APR_BLOCK_READ,
  -    APR_NONBLOCK_READ
  +    APR_BLOCK_READ, /**< wait until we data is available to read before return*/
  +    APR_NONBLOCK_READ /**< don't wait for data if it isn't available */
   } apr_read_type_e;
   
  -/*
  +/**
    * The one-sentence buzzword-laden overview: Bucket brigades represent
    * a complex data stream that can be passed through a layered IO
    * system without unnecessary copying. A longer overview follows...
  @@ -138,10 +145,11 @@
    * iovec, or possibly while we are converting to an iovec.
    */
   
  -/**
  +/*
    * Forward declaration of the main types.
    */
   
  +/** bucket brigade structure */
   typedef struct apr_bucket_brigade apr_bucket_brigade;
   
   typedef struct apr_bucket apr_bucket;
  @@ -175,7 +183,6 @@
        * @param len The amount of data read.
        * @param block Should this read function block if there is more data that
        *              cannot be read immediately.
  -     * @deffunc apr_status_t read(apr_bucket *b, const char **str, apr_size_t *len, apr_read_type_e block)
        */
       apr_status_t (*read)(apr_bucket *b, const char **str, apr_size_t *len, 
                            apr_read_type_e block);
  @@ -187,10 +194,9 @@
        *  the given pool, or in a disjoint pool) must somehow copy, shift, or
        *  transform the data to have the proper lifetime.
        * @param e The bucket to convert
  -     * @deffunc apr_status_t setaside(apr_bucket *e)
  -     * @tip Some bucket types contain data that will always outlive the
  -     *      bucket itself. For example no data (EOS and FLUSH), or the data
  -     *      resides in global, constant memory (IMMORTAL), or the data is on
  +     * @remark Some bucket types contain data that will always outlive the
  +     *         bucket itself. For example no data (EOS and FLUSH), or the data
  +     *         resides in global, constant memory (IMMORTAL), or the data is on
        *      the heap (HEAP). For these buckets, apr_bucket_setaside_noop can
        *      be used.
        */
  @@ -204,7 +210,6 @@
        *  as with pipe and socket buckets), then APR_ENOTIMPL is returned.
        * @param e The bucket to split
        * @param point The offset of the first byte in the new bucket
  -     * @deffunc apr_status_t split(apr_bucket *e, apr_size_t point)
        */
       apr_status_t (*split)(apr_bucket *e, apr_size_t point);
   
  @@ -213,7 +218,6 @@
        *  possible for the bucket type. If it's not, APR_ENOTIMPL is returned.
        * @param e The bucket to copy
        * @param c Returns a pointer to the new bucket
  -     * @deffunc apr_status_t copy
        */
       apr_status_t (*copy)(apr_bucket *e, apr_bucket **c);
   
  @@ -295,7 +299,6 @@
    * </pre>
    * @param  b The brigade
    * @return The magic pointer value
  - * @deffunc apr_bucket *APR_BRIGADE_SENTINEL(apr_bucket_brigade *b)
    */
   #define APR_BRIGADE_SENTINEL(b)	APR_RING_SENTINEL(&(b)->list, apr_bucket, link)
   
  @@ -303,7 +306,6 @@
    * Determine if the bucket brigade is empty
    * @param b The brigade to check
    * @return true or false
  - * @deffunc int APR_BRIGADE_EMPTY(apr_bucket_brigade *b)
    */
   #define APR_BRIGADE_EMPTY(b)	APR_RING_EMPTY(&(b)->list, apr_bucket, link)
   
  @@ -311,14 +313,12 @@
    * Return the first bucket in a brigade
    * @param b The brigade to query
    * @return The first bucket in the brigade
  - * @deffunc apr_bucket *APR_BRIGADE_FIRST(apr_bucket_brigade *b)
    */
   #define APR_BRIGADE_FIRST(b)	APR_RING_FIRST(&(b)->list)
   /**
    * Return the last bucket in a brigade
    * @param b The brigade to query
    * @return The last bucket in the brigade
  - * @deffunc apr_bucket *APR_BRIGADE_LAST(apr_bucket_brigade *b)
    */
   #define APR_BRIGADE_LAST(b)	APR_RING_LAST(&(b)->list)
   
  @@ -358,7 +358,6 @@
    *          apr_bucket_delete(e);
    *      }
    * </pre>
  - * @deffunc void APR_BRIGADE_FOREACH(apr_bucket *e, apr_bucket_brigade *b)
    */
   #define APR_BRIGADE_FOREACH(e, b)					\
   	APR_RING_FOREACH((e), &(b)->list, apr_bucket, link)
  @@ -367,7 +366,6 @@
    * Insert a list of buckets at the front of a brigade
    * @param b The brigade to add to
    * @param e The first bucket in a list of buckets to insert
  - * @deffunc void APR_BRIGADE_INSERT_HEAD(apr_bucket_brigade *b, apr_bucket *e)
    */
   #define APR_BRIGADE_INSERT_HEAD(b, e) do {				\
   	apr_bucket *ap__b = (e);                                        \
  @@ -378,7 +376,6 @@
    * Insert a list of buckets at the end of a brigade
    * @param b The brigade to add to
    * @param e The first bucket in a list of buckets to insert
  - * @deffunc void APR_BRIGADE_INSERT_TAIL(apr_bucket_brigade *b, apr_bucket *e)
    */
   #define APR_BRIGADE_INSERT_TAIL(b, e) do {				\
   	apr_bucket *ap__b = (e);					\
  @@ -389,7 +386,6 @@
    * Concatenate brigade b onto the end of brigade a, leaving brigade b empty
    * @param a The first brigade
    * @param b The second brigade
  - * @deffunc void APR_BRIGADE_CONCAT(apr_bucket_brigade *a, apr_bucket_brigade *b)
    */
   #define APR_BRIGADE_CONCAT(a, b)					\
   	APR_RING_CONCAT(&(a)->list, &(b)->list, apr_bucket, link)
  @@ -398,7 +394,6 @@
    * Insert a list of buckets before a specified bucket
    * @param a The bucket to insert before
    * @param b The buckets to insert
  - * @deffunc void APR_BUCKET_INSERT_BEFORE(apr_bucket *a, apr_bucket *b)
    */
   #define APR_BUCKET_INSERT_BEFORE(a, b) do {				\
   	apr_bucket *ap__a = (a), *ap__b = (b);				\
  @@ -409,7 +404,6 @@
    * Insert a list of buckets after a specified bucket
    * @param a The bucket to insert after
    * @param b The buckets to insert
  - * @deffunc void APR_BUCKET_INSERT_AFTER(apr_bucket *a, apr_bucket *b)
    */
   #define APR_BUCKET_INSERT_AFTER(a, b) do {				\
   	apr_bucket *ap__a = (a), *ap__b = (b);				\
  @@ -420,28 +414,24 @@
    * Get the next bucket in the list
    * @param e The current bucket
    * @return The next bucket
  - * @deffunc apr_bucket *APR_BUCKET_NEXT(apr_bucket *e)
    */
   #define APR_BUCKET_NEXT(e)	APR_RING_NEXT((e), link)
   /**
    * Get the previous bucket in the list
    * @param e The current bucket
    * @return The previous bucket
  - * @deffunc apr_bucket *APR_BUCKET_PREV(apr_bucket *e)
    */
   #define APR_BUCKET_PREV(e)	APR_RING_PREV((e), link)
   
   /**
    * Remove a bucket from its bucket brigade
    * @param e The bucket to remove
  - * @deffunc void APR_BUCKET_REMOVE(apr_bucket *e)
    */
   #define APR_BUCKET_REMOVE(e)	APR_RING_REMOVE((e), link)
   
   /**
    * Initialize a new bucket's prev/next pointers
    * @param e The bucket to initialize
  - * @deffunc void APR_BUCKET_INIT(apr_bucket *e)
    */
   #define APR_BUCKET_INIT(e)	APR_RING_ELEM_INIT((e), link);
   
  @@ -449,56 +439,48 @@
    * Determine if a bucket is a FLUSH bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_FLUSH(apr_bucket *e)
    */
   #define APR_BUCKET_IS_FLUSH(e)       (e->type == &apr_bucket_type_flush)
   /**
    * Determine if a bucket is an EOS bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_EOS(apr_bucket *e)
    */
   #define APR_BUCKET_IS_EOS(e)         (e->type == &apr_bucket_type_eos)
   /**
    * Determine if a bucket is a FILE bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_FILE(apr_bucket *e)
    */
   #define APR_BUCKET_IS_FILE(e)        (e->type == &apr_bucket_type_file)
   /**
    * Determine if a bucket is a PIPE bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_PIPE(apr_bucket *e)
    */
   #define APR_BUCKET_IS_PIPE(e)        (e->type == &apr_bucket_type_pipe)
   /**
    * Determine if a bucket is a SOCKET bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_SOCKET(apr_bucket *e)
    */
   #define APR_BUCKET_IS_SOCKET(e)      (e->type == &apr_bucket_type_socket)
   /**
    * Determine if a bucket is a HEAP bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_HEAP(apr_bucket *e)
    */
   #define APR_BUCKET_IS_HEAP(e)        (e->type == &apr_bucket_type_heap)
   /**
    * Determine if a bucket is a TRANSIENT bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_TRANSIENT(apr_bucket *e)
    */
   #define APR_BUCKET_IS_TRANSIENT(e)   (e->type == &apr_bucket_type_transient)
   /**
    * Determine if a bucket is a IMMORTAL bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_IMMORTAL(apr_bucket *e)
    */
   #define APR_BUCKET_IS_IMMORTAL(e)    (e->type == &apr_bucket_type_immortal)
   #if APR_HAS_MMAP
  @@ -506,7 +488,6 @@
    * Determine if a bucket is a MMAP bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_MMAP(apr_bucket *e)
    */
   #define APR_BUCKET_IS_MMAP(e)        (e->type == &apr_bucket_type_mmap)
   #endif
  @@ -514,7 +495,6 @@
    * Determine if a bucket is a POOL bucket
    * @param e The bucket to inspect
    * @return true or false
  - * @deffunc int APR_BUCKET_IS_POOL(apr_bucket *e)
    */
   #define APR_BUCKET_IS_POOL(e)        (e->type == &apr_bucket_type_pool)
   
  @@ -647,7 +627,6 @@
    * @param The pool to associate with the brigade.  Data is not allocated out
    *        of the pool, but a cleanup is registered.
    * @return The empty bucket brigade
  - * @deffunc apr_bucket_brigade *apr_brigade_create(apr_pool_t *p)
    */
   APU_DECLARE(apr_bucket_brigade *) apr_brigade_create(apr_pool_t *p);
   
  @@ -655,7 +634,6 @@
    * destroy an entire bucket brigade.  This includes destroying all of the
    * buckets within the bucket brigade's bucket list. 
    * @param b The bucket brigade to destroy
  - * @deffunc apr_status_t apr_brigade_destroy(apr_bucket_brigade *b)
    */
   APU_DECLARE(apr_status_t) apr_brigade_destroy(apr_bucket_brigade *b);
   
  @@ -664,12 +642,11 @@
    * buckets within the bucket brigade's bucket list.  This is similar to
    * apr_brigade_destroy(), except that it does not deregister the brigade's
    * pool cleanup function.
  - * @tip Generally, you should use apr_brigade_destroy().  This function
  - *      can be useful in situations where you have a single brigade that
  - *      you wish to reuse many times by destroying all of the buckets in
  - *      the brigade and putting new buckets into it later.
    * @param b The bucket brigade to clean up
  - * @deffunc apr_status_t apr_brigade_cleanup(apr_bucket_brigade *b)
  + * @remark Generally, you should use apr_brigade_destroy().  This function
  + *         can be useful in situations where you have a single brigade that
  + *         you wish to reuse many times by destroying all of the buckets in
  + *         the brigade and putting new buckets into it later.
    */
   APU_DECLARE(apr_status_t) apr_brigade_cleanup(void *data);
   
  @@ -681,7 +658,6 @@
    * @param b The brigade to split
    * @param e The first element of the new brigade
    * @return The new brigade
  - * @deffunc apr_bucket_brigade *apr_brigade_split(apr_bucket_brigade *b, apr_bucket *e)
    */
   APU_DECLARE(apr_bucket_brigade *) apr_brigade_split(apr_bucket_brigade *b,
                                                       apr_bucket *e);
  @@ -693,7 +669,6 @@
    * @param b The brigade to partition
    * @param point The offset at which to partition the brigade
    * @param after_point Returns a pointer to the first bucket after the partition
  - * @deffunc apr_status_t apr_brigade_partition(apr_bucket_brigade *b, apr_off_t point, apr_bucket **after_point)
    */
   APU_DECLARE(apr_status_t) apr_brigade_partition(apr_bucket_brigade *b,
                                                   apr_off_t point,
  @@ -705,7 +680,6 @@
    * appropriate, and/or modify start on last element 
    * @param b The brigade to consume data from
    * @param nbytes The number of bytes to consume
  - * @deffunc void apr_brigade_consume(apr_bucket_brigade *b, apr_off_t nbytes)
    */
   APU_DECLARE(void) apr_brigade_consume(apr_bucket_brigade *b,
                                         apr_off_t nbytes);
  @@ -715,8 +689,7 @@
    * Return the total length of the brigade.
    * @param bb The brigade to compute the length of
    * @param read_all Read unknown-length buckets to force a size
  - @ @param length Set to length of the brigade, or -1 if it has unknown-length buckets
  - * @deffunc apr_status_t apr_brigade_length(apr_bucket_brigade *bb, int read_all, apr_off_t *length)
  + * @param length Set to length of the brigade, or -1 if it has unknown-length buckets
    */
   APU_DECLARE(apr_status_t) apr_brigade_length(apr_bucket_brigade *bb,
                                                int read_all,
  @@ -730,7 +703,6 @@
    * @param vec The iovec to create
    * @param nvec The number of elements in the iovec. On return, it is the
    *             number of iovec elements actually filled out.
  - * @deffunc apr_status_t apr_brigade_to_iovec(apr_bucket_brigade *b, struct iovec *vec, int *nvec);
    */
   APU_DECLARE(apr_status_t) apr_brigade_to_iovec(apr_bucket_brigade *b, 
                                                  struct iovec *vec, int *nvec);
  @@ -740,7 +712,6 @@
    * @param b The bucket brigade to add to
    * @param va A list of strings to add
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_vputstrs(apr_bucket_brigade *b, apr_brigade_flush flush, void *ctx, va_list va)
    */
   APU_DECLARE(apr_status_t) apr_brigade_vputstrs(apr_bucket_brigade *b,
                                                  apr_brigade_flush flush,
  @@ -752,7 +723,6 @@
    * @param b The bucket brigade to add to
    * @param str The string to add
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_write(ap_bucket_brigade *b, apr_brigade_flush flush, void *ctx, const char *str, apr_size_t nbyte)
    */
   APU_DECLARE(apr_status_t) apr_brigade_write(apr_bucket_brigade *b,
                                               apr_brigade_flush flush, void *ctx,
  @@ -763,7 +733,6 @@
    * @param b The bucket brigade to add to
    * @param str The string to add
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_puts(ap_bucket_brigade *b, apr_brigade_flush flush, void *ctx, const char *str)
    */
   APU_DECLARE(apr_status_t) apr_brigade_puts(apr_bucket_brigade *b,
                                              apr_brigade_flush flush, void *ctx,
  @@ -774,7 +743,6 @@
    * @param b The bucket brigade to add to
    * @param c The character to add
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_putc(apr_bucket_brigade *b, apr_brigade_flush flush, void *ctx, const char c)
    */
   APU_DECLARE(apr_status_t) apr_brigade_putc(apr_bucket_brigade *b,
                                              apr_brigade_flush flush, void *ctx,
  @@ -785,7 +753,6 @@
    * @param b The bucket brigade to add to
    * @param ... The strings to add
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_putstrs(apr_bucket_brigade *b, apr_brigade_flush flush, void *ctx, ...)
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_brigade_putstrs(apr_bucket_brigade *b,
                                                        apr_brigade_flush flush,
  @@ -798,7 +765,6 @@
    * @param fmt The format of the string to write
    * @param ... The arguments to fill out the format
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_printf(apr_bucket_brigade *b, apr_brigade_flush flush, void *ctx, const char *fmt, ...) 
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_brigade_printf(apr_bucket_brigade *b, 
                                                       apr_brigade_flush flush,
  @@ -813,7 +779,6 @@
    * @param fmt The format of the string to write
    * @param va The arguments to fill out the format
    * @return The number of bytes added to the brigade
  - * @deffunc apr_status_t apr_brigade_vprintf(apr_bucket_brigade *b, apr_brigade_flush flush, void *ctx, const char *fmt, va_list va) 
    */
   APU_DECLARE(apr_status_t) apr_brigade_vprintf(apr_bucket_brigade *b, 
                                                 apr_brigade_flush flush,
  @@ -827,7 +792,6 @@
    * the same resource it is freed when the last one goes away.
    * @see apr_bucket_delete()
    * @param e The bucket to destroy
  - * @deffunc void apr_bucket_destroy(apr_bucket *e)
    */
   #define apr_bucket_destroy(e) do {					\
           (e)->type->destroy((e)->data);					\
  @@ -844,7 +808,6 @@
    *      apr_bucket_destroy(e);
    * </pre>
    * @param e The bucket to delete
  - * @deffunc void apr_bucket_delete(apr_bucket *e)
    */
   #define apr_bucket_delete(e) do {					\
           APR_BUCKET_REMOVE(e);						\
  @@ -857,7 +820,6 @@
    * @param str The location to store the data in
    * @param len The amount of data read
    * @param block Whether the read function blocks
  - * @deffunc apr_status_t apr_bucket_read(apr_bucket *e, const char **str, apr_size_t *len, apr_read_type_e block)
    */
   #define apr_bucket_read(e,str,len,block) (e)->type->read(e, str, len, block)
   
  @@ -865,7 +827,6 @@
    * Setaside data so that stack data is not destroyed on returning from
    * the function
    * @param e The bucket to setaside
  - * @deffunc apr_status_t apr_bucket_setaside(apr_bucket *e)
    */
   #define apr_bucket_setaside(e,p) (e)->type->setaside(e,p)
   
  @@ -873,7 +834,6 @@
    * Split one bucket in two.
    * @param e The bucket to split
    * @param point The offset to split the bucket at
  - * @deffunc apr_status_t apr_bucket_split(apr_bucket *e, apr_size_t point)
    */
   #define apr_bucket_split(e,point) (e)->type->split(e, point)
   
  @@ -881,7 +841,6 @@
    * Copy a bucket.
    * @param e The bucket to copy
    * @param c Returns a pointer to the new bucket
  - * @deffunc apr_status_t apr_bucket_copy(apr_bucket *e, apr_bucket **c)
    */
   #define apr_bucket_copy(e,c) (e)->type->copy(e, c)
   
  @@ -895,7 +854,6 @@
    * @param data The bucket to setaside
    * @param pool The pool defining the desired lifetime of the bucket data
    * @return APR_SUCCESS
  - * @deffunc apr_status_t apr_bucket_setaside_notimpl(apr_bucket *data, apr_pool_t *pool)
    */ 
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_setaside_noop(apr_bucket *data,
                                                             apr_pool_t *pool);
  @@ -906,7 +864,6 @@
    * @param data The bucket to setaside
    * @param pool The pool defining the desired lifetime of the bucket data
    * @return APR_ENOTIMPL
  - * @deffunc apr_status_t apr_bucket_setaside_notimpl(apr_bucket *data, apr_pool_t *pool)
    */ 
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_setaside_notimpl(apr_bucket *data,
                                                                apr_pool_t *pool);
  @@ -917,7 +874,6 @@
    * @param data The bucket to split
    * @param point The location to split the bucket
    * @return APR_ENOTIMPL
  - * @deffunc apr_status_t apr_bucket_split_notimpl(apr_bucket *data, apr_size_t point)
    */ 
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_split_notimpl(apr_bucket *data,
                                                             apr_size_t point);
  @@ -928,7 +884,6 @@
    * @param e The bucket to copy
    * @param c Returns a pointer to the new bucket
    * @return APR_ENOTIMPL
  - * @deffunc apr_status_t apr_bucket_copy_notimpl(apr_bucket *e, apr_bucket **c)
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_copy_notimpl(apr_bucket *e,
                                                            apr_bucket **c);
  @@ -941,7 +896,6 @@
    * simple buckets where data points to a string and pipe buckets where data
    * points directly to the apr_file_t.
    * @param data The bucket data to destroy
  - * @deffunc void apr_bucket_destroy_noop(void *data)
    */ 
   APU_DECLARE_NONSTD(void) apr_bucket_destroy_noop(void *data);
   
  @@ -1022,7 +976,6 @@
    * @return APR_EINVAL if the point is not within the bucket;
    *         APR_ENOMEM if allocation failed;
    *         or APR_SUCCESS
  - * @deffunc apr_status_t apr_bucket_simple_split(apr_bucket *b, apr_size_t point)
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_simple_split(apr_bucket *b,
                                                            apr_size_t point);
  @@ -1036,7 +989,6 @@
    * @param b Returns a pointer to the new bucket
    * @return APR_ENOMEM if allocation failed;
    *         or APR_SUCCESS
  - * @deffunc apr_status_t apr_bucket_simple_copy(apr_bucket *a, apr_bucket **b)
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_simple_copy(apr_bucket *a,
                                                           apr_bucket **b);
  @@ -1057,7 +1009,6 @@
    *              relative to the private base pointer
    * @param length The length of the data in the bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_shared_make(apr_bucket_refcount *r, void *data, apr_off_t start, apr_size_t length) 
    */
   APU_DECLARE(apr_bucket *) apr_bucket_shared_make(apr_bucket *b, void *data,
   				                 apr_off_t start, 
  @@ -1070,7 +1021,6 @@
    * @return TRUE or FALSE; TRUE if the reference count is now
    *         zero, indicating that the shared resource itself can
    *         be destroyed by the caller.
  - * @deffunc int apr_bucket_shared_destroy(void *data)
    */
   APU_DECLARE(int) apr_bucket_shared_destroy(void *data);
   
  @@ -1084,7 +1034,6 @@
    * @return APR_EINVAL if the point is not within the bucket;
    *         APR_ENOMEM if allocation failed;
    *         or APR_SUCCESS
  - * @deffunc apr_status_t apr_bucket_shared_split(apr_bucket *b, apr_size_t point)
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_shared_split(apr_bucket *b,
                                                            apr_size_t point);
  @@ -1097,7 +1046,6 @@
    * @param b Returns a pointer to the new bucket
    * @return APR_ENOMEM if allocation failed;
              or APR_SUCCESS
  - * @deffunc apr_status_t apr_bucket_shared_copy(apr_bucket *a, apr_bucket **b)
    */
   APU_DECLARE_NONSTD(apr_status_t) apr_bucket_shared_copy(apr_bucket *a,
                                                           apr_bucket **b);
  @@ -1119,7 +1067,6 @@
    * Create an End of Stream bucket.  This indicates that there is no more data
    * coming from down the filter stack.  All filters should flush at this point.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_eos_create(void)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_eos_create(void);
   
  @@ -1129,7 +1076,6 @@
    * this point.
    * @param b The bucket to make into an EOS bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_eos_make(apr_bucket *b)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_eos_make(apr_bucket *b);
   
  @@ -1138,7 +1084,6 @@
    * data.  There is no guarantee that they will flush it, but this is the
    * best we can do.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_flush_create(void)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_flush_create(void);
   
  @@ -1148,7 +1093,6 @@
    * but this is the best we can do.
    * @param b The bucket to make into a FLUSH bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_flush_make(apr_bucket *b)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_flush_make(apr_bucket *b);
   
  @@ -1157,7 +1101,6 @@
    * @param buf The data to insert into the bucket
    * @param nbyte The size of the data to insert.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_immortal_create(const char *buf, apr_size_t nbyte)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_immortal_create(const char *buf, 
                                                        apr_size_t nbyte);
  @@ -1168,7 +1111,6 @@
    * @param buf The data to insert into the bucket
    * @param nbyte The size of the data to insert.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_immortal_make(apr_bucket *b, const char *buf, apr_size_t nbyte)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_immortal_make(apr_bucket *b, 
                                                      const char *buf, 
  @@ -1179,7 +1121,6 @@
    * @param buf The data to insert into the bucket
    * @param nbyte The size of the data to insert.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_transient_create(const char *buf, apr_size_t nbyte)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_transient_create(const char *buf, 
                                                         apr_size_t nbyte);
  @@ -1190,7 +1131,6 @@
    * @param buf The data to insert into the bucket
    * @param nbyte The size of the data to insert.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_transient_make(apr_bucket *b, const char *buf, apr_size_t nbyte)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_transient_make(apr_bucket *b, 
                                                       const char *buf,
  @@ -1209,7 +1149,6 @@
    * @param w The number of bytes actually copied into the bucket.
    *          If copy is zero then this return value can be ignored by passing a NULL pointer.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_heap_create(const char *buf, apr_size_t nbyte, int copy, apr_size_t *w)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_heap_create(const char *buf, 
                                                    apr_size_t nbyte, int copy, 
  @@ -1223,7 +1162,6 @@
    * @param w The number of bytes actually copied into the bucket.
    *          If copy is zero then this return value can be ignored by passing a NULL pointer.
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_heap_make(apr_bucket *b, const char *buf, apr_size_t nbyte, int copy, apr_size_t *w)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_heap_make(apr_bucket *b, const char *buf,
                                                  apr_size_t nbyte, int copy, 
  @@ -1236,7 +1174,6 @@
    * @param length The number of bytes referred to by this bucket
    * @param pool The pool the memory was allocated from
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_pool_create(const char *buf, apr_size_t *length, apr_pool_t *pool)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_pool_create(const char *buf, 
                                                    apr_size_t length,
  @@ -1249,7 +1186,6 @@
    * @param length The number of bytes referred to by this bucket
    * @param pool The pool the memory was allocated from
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_pool_make(apr_bucket *b, const char *buf, apr_size_t *length, apr_pool_t *pool)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_pool_make(apr_bucket *b, const char *buf,
                                                  apr_size_t length, 
  @@ -1263,7 +1199,6 @@
    *              that this bucket refers to
    * @param length The number of bytes referred to by this bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_mmap_create(const apr_mmap_t *mm, apr_size_t start, apr_size_t length)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_mmap_create(apr_mmap_t *mm, 
                                                    apr_off_t start,
  @@ -1277,7 +1212,6 @@
    *              that this bucket refers to
    * @param length The number of bytes referred to by this bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_mmap_make(apr_bucket *b, const apr_mmap_t *mm, apr_size_t start, apr_size_t length)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_mmap_make(apr_bucket *b, apr_mmap_t *mm,
                                                  apr_off_t start, 
  @@ -1288,7 +1222,6 @@
    * Create a bucket referring to a socket.
    * @param thissocket The socket to put in the bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_socket_create(apr_socket_t *thissocket)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_socket_create(apr_socket_t *thissock);
   /**
  @@ -1296,7 +1229,6 @@
    * @param b The bucket to make into a SOCKET bucket
    * @param thissocket The socket to put in the bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_socket_make(apr_bucket *b, apr_socket_t *thissocket)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_socket_make(apr_bucket *b, 
                                                    apr_socket_t *thissock);
  @@ -1305,7 +1237,6 @@
    * Create a bucket referring to a pipe.
    * @param thispipe The pipe to put in the bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_pipe_create(apr_file_t *thispipe)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_pipe_create(apr_file_t *thispipe);
   
  @@ -1314,7 +1245,6 @@
    * @param b The bucket to make into a PIPE bucket
    * @param thispipe The pipe to put in the bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_pipe_make(apr_bucket *b, apr_file_t *thispipe)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_pipe_make(apr_bucket *b, 
                                                  apr_file_t *thispipe);
  @@ -1327,7 +1257,6 @@
    * @param p The pool into which any needed structures should be created
    *          while reading from this file bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_file_create(apr_file_t *fd, apr_off_t offset, apr_size_t len, apr_pool_t *p)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_file_create(apr_file_t *fd,
                                                    apr_off_t offset,
  @@ -1343,12 +1272,12 @@
    * @param p The pool into which any needed structures should be created
    *          while reading from this file bucket
    * @return The new bucket, or NULL if allocation failed
  - * @deffunc apr_bucket *apr_bucket_file_make(apr_bucket *b, apr_file_t *fd, apr_off_t offset, apr_size_t len, apr_pool_t *p)
    */
   APU_DECLARE(apr_bucket *) apr_bucket_file_make(apr_bucket *b, apr_file_t *fd,
                                                  apr_off_t offset,
                                                  apr_size_t len, apr_pool_t *p);
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.5       +8 -5      apr-util/include/apr_date.h
  
  Index: apr_date.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_date.h,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- apr_date.h	2001/06/06 21:29:44	1.4
  +++ apr_date.h	2001/09/09 05:54:35	1.5
  @@ -58,13 +58,18 @@
   
   #ifndef APR_DATE_H
   #define APR_DATE_H
  -
  +/**
  + * @file apr_date.h
  + * @brief APR-UTIL date routines
  + */
   #ifdef __cplusplus
   extern "C" {
   #endif
   
   /**
  - * @package Apache date routines
  + * @defgroup APR_Util_Date Date routines
  + * @ingroup APR_Util
  + * @{
    */
   
   /*
  @@ -90,7 +95,6 @@
    *  <x> - exact match for any other character
    * </PRE>
    * @return 1 if the string matches, 0 otherwise
  - * @deffunc int apr_date_checkmask(const char *data, const char *mask)
    */
   APU_DECLARE(int) apr_date_checkmask(const char *data, const char *mask);
   
  @@ -104,7 +108,6 @@
    * @param date The date in one of the three formats above
    * @return the apr_time_t number of microseconds since 1 Jan 1970 GMT, or
    *         0 if this would be out of range or if the date is invalid.
  - * @deffunc apr_time_t apr_date_parse_http(const char *date)
    */
   APU_DECLARE(apr_time_t) apr_date_parse_http(const char *date);
   
  @@ -131,10 +134,10 @@
    * @param date The date in one of the formats above
    * @return the apr_time_t number of microseconds since 1 Jan 1970 GMT, or
    *         0 if this would be out of range or if the date is invalid.
  - * @deffunc apr_time_t apr_date_parse_rfc(char *date)
    */
   APU_DECLARE(apr_time_t) apr_date_parse_rfc(char *date);
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.12      +6 -1      apr-util/include/apr_dbm.h
  
  Index: apr_dbm.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_dbm.h,v
  retrieving revision 1.11
  retrieving revision 1.12
  diff -u -r1.11 -r1.12
  --- apr_dbm.h	2001/09/06 17:18:52	1.11
  +++ apr_dbm.h	2001/09/09 05:54:35	1.12
  @@ -69,7 +69,11 @@
    * @file apr_dbm.h
    * @brief APR-UTIL DBM library
    */
  -
  +/** 
  + * @defgroup APR_Util_DBM DBM routines
  + * @ingroup APR_Util
  + * @{
  + */
   /**
    * Structure for referencing a dbm
    */
  @@ -208,6 +212,7 @@
                                           const char **used1,
                                           const char **used2);
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.43      +9 -4      apr-util/include/apr_hooks.h
  
  Index: apr_hooks.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_hooks.h,v
  retrieving revision 1.42
  retrieving revision 1.43
  diff -u -r1.42 -r1.43
  --- apr_hooks.h	2001/09/06 17:18:52	1.42
  +++ apr_hooks.h	2001/09/09 05:54:35	1.43
  @@ -59,15 +59,19 @@
   /* For apr_array_header_t */
   #include "apr_tables.h"
   
  -#ifdef __cplusplus
  -extern "C" {
  -#endif
  -
   /**
    * @file apr_hooks.h
    * @brief Apache hook functions
    */
   
  +#ifdef __cplusplus
  +extern "C" {
  +#endif
  +/**
  + * @defgroup APR_Util_Hook Hook Functions
  + * @ingroup APR_Util
  + * @{
  + */
   /** macro to return the prototype of the hook function */    
   #define APR_IMPLEMENT_HOOK_GET_PROTO(ns,link,name) \
   link##_DECLARE(apr_array_header_t *) ns##_hook_get_##name(void)
  @@ -274,6 +278,7 @@
    */
   APU_DECLARE(void) apr_hook_deregister_all(void);
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.3       +8 -7      apr-util/include/apr_md4.h
  
  Index: apr_md4.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_md4.h,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- apr_md4.h	2001/06/04 17:21:54	1.2
  +++ apr_md4.h	2001/09/09 05:54:35	1.3
  @@ -81,13 +81,18 @@
   
   #include "apu.h"
   #include "apr_xlate.h"
  -
  +/**
  + * @file apr_md4.h
  + * @brief APR-UTIL MD4 Library
  + */
   #ifdef __cplusplus
   extern "C" {
   #endif
   
   /**
  - * @package APR MD4 Library
  + * @defgroup APR_Util_MD4 MD4 Library
  + * @ingroup APR_Util
  + * @{
    */
   
   #define APR_MD4_DIGESTSIZE 16
  @@ -111,7 +116,6 @@
   /**
    * MD4 Initialize.  Begins an MD4 operation, writing a new context.
    * @param context The MD4 context to initialize.
  - * @deffunc apr_status_t apr_md4_init(apr_md4_ctx_t *context)
    */
   APU_DECLARE(apr_status_t) apr_md4_init(apr_md4_ctx_t *context);
   
  @@ -121,7 +125,6 @@
    * for translating the content before calculating the digest.
    * @param context The MD4 content to set the translation for.
    * @param xlate The translation handle to use for this MD4 context 
  - * @deffunc apr_status_t apr_md4_set_xlate(apr_md4_ctx_t *context, apr_xlate_t *xlate)
    */
   APU_DECLARE(apr_status_t) apr_md4_set_xlate(apr_md4_ctx_t *context,
                                               apr_xlate_t *xlate);
  @@ -135,7 +138,6 @@
    * @param context The MD4 content to update.
    * @param input next message block to update
    * @param inputLen The length of the next message block
  - * @deffunc apr_status_t apr_md4_update(apr_md4_ctx_t *context, const unsigned char *input, apr_size_t inputLen)
    */
   APU_DECLARE(apr_status_t) apr_md4_update(apr_md4_ctx_t *context,
                                            const unsigned char *input,
  @@ -146,7 +148,6 @@
    * message digest and zeroing the context
    * @param digest The final MD4 digest
    * @param context The MD4 content we are finalizing.
  - * @deffunc apr_status_t apr_md4_final(unsigned char digest[APR_MD4_DIGESTSIZE], apr_md4_ctx_t *context)
    */
   APU_DECLARE(apr_status_t) apr_md4_final(
                                       unsigned char digest[APR_MD4_DIGESTSIZE],
  @@ -157,12 +158,12 @@
    * @param digest The MD4 digest
    * @param input message block to use
    * @param inputLen The length of the message block
  - * @deffunc apr_status_t apr_md4(unsigned char digest[APR_MD4_DIGESTSIZE], const unsigned char *input, apr_size_t inputLen);
    */
   APU_DECLARE(apr_status_t) apr_md4(unsigned char digest[APR_MD4_DIGESTSIZE],
                                     const unsigned char *input,
                                     apr_size_t inputLen);
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.7       +17 -8     apr-util/include/apr_optional.h
  
  Index: apr_optional.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_optional.h,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- apr_optional.h	2001/04/05 09:08:48	1.6
  +++ apr_optional.h	2001/09/09 05:54:35	1.7
  @@ -56,20 +56,26 @@
   #define APR_OPTIONAL_H
   
   #include "apu.h"
  -
  +/** 
  + * @file apr_optional.h
  + * @brief APR-UTIL registration of functions exported by modules
  + */
   #ifdef __cplusplus
   extern "C" {
   #endif
   
  -/*
  +/** 
  + * @defgroup APR_Util_Opt Optional Functions
  + * @ingroup APR_Util
  + *
    * Typesafe registration and retrieval of functions that may not be present
    * (i.e. functions exported by optional modules)
  + * @{
    */
   
   /**
    * The type of an optional function.
    * @param name The name of the function
  - * @deffunc APR_OPTIONAL_FN_TYPE(name)
    */
   #define APR_OPTIONAL_FN_TYPE(name) apr_OFN_##name##_t
   
  @@ -82,12 +88,14 @@
   #define APR_DECLARE_OPTIONAL_FN(ret,name,args) \
   typedef ret (APR_OPTIONAL_FN_TYPE(name)) args
   
  -/* XXX: This doesn't belong here, then!
  +/**
  + * XXX: This doesn't belong here, then!
    * Private function! DO NOT USE! 
  + * @internal
    */
   
   typedef void (apr_opt_fn_t)(void);
  -
  +/** @internal */
   APU_DECLARE_NONSTD(void) apr_register_optional_fn(const char *szName, 
                                                     apr_opt_fn_t *pfn);
       
  @@ -97,13 +105,14 @@
    * name. Like all global functions, the name must be unique. Note that,
    * confusingly but correctly, the function itself can be static!
    * @param name The name of the function
  - * @deffunc void APR_REGISTER_OPTIONAL_FN(name)
    */
   #define APR_REGISTER_OPTIONAL_FN(name) \
       (((void (*)(const char *, APR_OPTIONAL_FN_TYPE(name) *)) \
                  &apr_register_optional_fn)(#name,name))
   
  -/* Private function! DO NOT USE! */
  +/** @internal
  + * Private function! DO NOT USE! 
  + */
   APU_DECLARE(apr_opt_fn_t *) apr_retrieve_optional_fn(const char *szName);
   
   /**
  @@ -112,8 +121,8 @@
    */
   #define APR_RETRIEVE_OPTIONAL_FN(name) \
   	(APR_OPTIONAL_FN_TYPE(name) *)apr_retrieve_optional_fn(#name)
  -
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.4       +10 -5     apr-util/include/apr_optional_hooks.h
  
  Index: apr_optional_hooks.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_optional_hooks.h,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- apr_optional_hooks.h	2001/09/06 17:18:52	1.3
  +++ apr_optional_hooks.h	2001/09/09 05:54:35	1.4
  @@ -51,6 +51,11 @@
    * information on the Apache Software Foundation, please see
    * <http://www.apache.org/>.
    */
  +/**
  + * @file apr_optional_hooks.h
  + * @brief Apache optional hook functions
  + */
  +
   
   #ifndef APR_OPTIONAL_HOOK_H
   #define APR_OPTIONAL_HOOK_H
  @@ -60,12 +65,11 @@
   #ifdef __cplusplus
   extern "C" {
   #endif
  -
  -/**
  - * @file apr_optional_hooks.h
  - * @brief Apache optional hook functions
  +/** 
  + * @defgroup APR_Util_OPT_HOOK Optional Hook Functions
  + * @ingroup APR_Util_Hook
  + * @{
    */
  -
   /**
    * Function to implemnt the APR_OPTIONAL_HOOK Macro
    * @internal
  @@ -138,6 +142,7 @@
       return ok; \
       }
   
  +/** @} */
   #ifdef __cplusplus
   }
   #endif
  
  
  
  1.9       +14 -18    apr-util/include/apr_sdbm.h
  
  Index: apr_sdbm.h
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apr_sdbm.h,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- apr_sdbm.h	2001/05/09 19:12:33	1.8
  +++ apr_sdbm.h	2001/09/09 05:54:35	1.9
  @@ -66,22 +66,28 @@
   #include "apr_errno.h"
   #include "apr_file_io.h"   /* for apr_fileperms_t */
   
  +/** 
  + * @file apr_sdbm.h
  + * @brief apr-util SDBM library
  + */
   /**
  - * @package apr-util SDBM library
  + * @defgroup APR_Util_DBM_SDBM SDBM library
  + * @ingroup APR_Util_DBM
  + * @{
    */
   
   /**
    * Structure for referencing an sdbm
  - * @defvar apr_sdbm_t
    */
   typedef struct apr_sdbm_t apr_sdbm_t;
   
   /**
    * Structure for referencing the datum record within an sdbm
  - * @defvar apr_sdbm_datum_t
    */
   typedef struct {
  +    /** pointer to the data stored/retrieved */
       char *dptr;
  +    /** size of data */
       int dsize;
   } apr_sdbm_datum_t;
   
  @@ -109,8 +115,7 @@
    * </PRE>
    * @param perm Permissions to apply to if created
    * @param pool The pool to use when creating the sdbm
  - * @deffunc apr_status_t apr_sdbm_open(apr_sdbm_t **db, const char *name, apr_int32_t mode, apr_fileperms_t perms, apr_pool_t *p)
  - * @tip The sdbm name is not a true file name, as sdbm appends suffixes 
  + * @remark The sdbm name is not a true file name, as sdbm appends suffixes 
    * for seperate data and index files.
    */
   APU_DECLARE(apr_status_t) apr_sdbm_open(apr_sdbm_t **db, const char *name, 
  @@ -120,7 +125,6 @@
   /**
    * Close an sdbm file previously opened by apr_sdbm_open
    * @param db The database to close
  - * @deffunc apr_status_t apr_sdbm_close(apr_sdbm_t *db)
    */
   APU_DECLARE(apr_status_t) apr_sdbm_close(apr_sdbm_t *db);
   
  @@ -132,8 +136,7 @@
    *           APR_FLOCK_SHARED
    *           APR_FLOCK_EXCLUSIVE
    * </PRE>
  - * @deffunc apr_status_t apr_sdbm_lock(apr_sdbm_t *db, int type)
  - * @tip Calls to apr_sdbm_lock may be nested.  All apr_sdbm functions
  + * @remark Calls to apr_sdbm_lock may be nested.  All apr_sdbm functions
    * perform implicit locking.  Since an APR_FLOCK_SHARED lock cannot be 
    * portably promoted to an APR_FLOCK_EXCLUSIVE lock, apr_sdbm_store and 
    * apr_sdbm_delete calls will fail if an APR_FLOCK_SHARED lock is held.
  @@ -145,7 +148,6 @@
   /**
    * Release an sdbm lock previously aquired by apr_sdbm_lock
    * @param db The database to unlock
  - * @deffunc apr_status_t apr_sdbm_unlock(apr_sdbm_t *db)
    */
   APU_DECLARE(apr_status_t) apr_sdbm_unlock(apr_sdbm_t *db);
   
  @@ -154,7 +156,6 @@
    * @param db The database 
    * @param value The value datum retrieved for this record
    * @param key The key datum to find this record
  - * @deffunc apr_status_t apr_status_t apr_sdbm_fetch(apr_sdbm_t *db, apr_sdbm_datum_t *value, apr_sdbm_datum_t key)
    */
   APU_DECLARE(apr_status_t) apr_sdbm_fetch(apr_sdbm_t *db, 
                                            apr_sdbm_datum_t *value, 
  @@ -170,7 +171,6 @@
    *           APR_SDBM_INSERT     return an error if the record exists
    *           APR_SDBM_REPLACE    overwrite any existing record for key
    * </PRE>
  - * @deffunc apr_status_t apr_sdbm_store(apr_sdbm_t *db, apr_sdbm_datum_t key, apr_sdbm_datum_t value, int opt)
    */
   APU_DECLARE(apr_status_t) apr_sdbm_store(apr_sdbm_t *db, apr_sdbm_datum_t key,
                                            apr_sdbm_datum_t value, int opt);
  @@ -179,8 +179,7 @@
    * Delete an sdbm record value by key
    * @param db The database 
    * @param key The key datum of the record to delete
  - * @deffunc apr_status_t apr_sdbm_delete(apr_sdbm_t *db, const apr_sdbm_datum_t key)
  - * @tip It is not an error to delete a non-existent record.
  + * @remark It is not an error to delete a non-existent record.
    */
   APU_DECLARE(apr_status_t) apr_sdbm_delete(apr_sdbm_t *db, 
                                             const apr_sdbm_datum_t key);
  @@ -189,8 +188,7 @@
    * Retrieve the first record key from a dbm
    * @param dbm The database 
    * @param key The key datum of the first record
  - * @deffunc apr_status_t apr_sdbm_nextkey(apr_sdbm_t *db, apr_sdbm_datum_t *key)
  - * @tip The keys returned are not ordered.  To traverse the list of keys
  + * @remark The keys returned are not ordered.  To traverse the list of keys
    * for an sdbm opened with APR_SHARELOCK, the caller must use apr_sdbm_lock
    * prior to retrieving the first record, and hold the lock until after the
    * last call to apr_sdbm_nextkey.
  @@ -201,15 +199,13 @@
    * Retrieve the next record key from an sdbm
    * @param db The database 
    * @param key The key datum of the next record
  - * @deffunc apr_status_t apr_sdbm_nextkey(apr_sdbm_t *db, apr_sdbm_datum_t *key)
    */
   APU_DECLARE(apr_status_t) apr_sdbm_nextkey(apr_sdbm_t *db, apr_sdbm_datum_t *key);
   
   /**
    * Returns true if the sdbm database opened for read-only access
    * @param db The database to test
  - * @deffunc int apr_sdbm_rdonly(apr_sdbm_t *db)
    */
   APU_DECLARE(int) apr_sdbm_rdonly(apr_sdbm_t *db);
  -
  +/** @} */
   #endif /* APR_SDBM_H */
  
  
  
  1.8       +13 -0     apr-util/include/apu.h.in
  
  Index: apu.h.in
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apu.h.in,v
  retrieving revision 1.7
  retrieving revision 1.8
  diff -u -r1.7 -r1.8
  --- apu.h.in	2001/06/09 11:33:08	1.7
  +++ apu.h.in	2001/09/09 05:54:35	1.8
  @@ -55,6 +55,18 @@
   /*
    * apu.h is generated from apu.h.in by configure -- do not edit apu.h
    */
  +/* 
  + * Note: This is a Windows specific version of apu.h. It is renamed to
  + * apu.h at the start of a Windows build.
  + */
  +/* @file apu.h
  + * @brief APR-Utility main file
  + */
  +/**
  + * @defgroup APR_Util APR Utility Functions
  + * @{
  + */
  +
   
   #ifndef APU_H
   #define APU_H
  @@ -98,3 +110,4 @@
   #define APU_DECLARE_DATA
   
   #endif /* APU_H */
  +/** @} */
  
  
  
  1.4       +27 -0     apr-util/include/apu.hw
  
  Index: apu.hw
  ===================================================================
  RCS file: /home/cvs/apr-util/include/apu.hw,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- apu.hw	2001/02/16 04:17:10	1.3
  +++ apu.hw	2001/09/09 05:54:35	1.4
  @@ -56,11 +56,19 @@
    * Note: This is a Windows specific version of apu.h. It is renamed to
    * apu.h at the start of a Windows build.
    */
  +/* @file apu.h
  + * @brief APR-Utility main file
  + */
   
   #ifdef WIN32
   #ifndef APU_H
   #define APU_H
  +/**
  + * @defgroup APR_Util APR Utility Functions
  + * @{
  + */
   
  +
   /**
    * APU_DECLARE_EXPORT is defined when building the APR-UTIL dynamic library,
    * so that all public symbols are exported.
  @@ -108,10 +116,29 @@
   #define APU_DECLARE_NONSTD(type)     __declspec(dllexport) type
   #define APU_DECLARE_DATA             __declspec(dllexport)
   #else
  +/**
  + * The public APR-UTIL functions are declared with APU_DECLARE(), so they may
  + * use the most appropriate calling convention.  Public APR functions with 
  + * variable arguments must use APU_DECLARE_NONSTD().
  + *
  + */
   #define APU_DECLARE(type)            __declspec(dllimport) type __stdcall
  +/**
  + * The public APR-UTIL functions using variable arguments are declared with 
  + * APU_DECLARE_NONSTD(), as they must use the C language calling convention.
  + *
  + */
   #define APU_DECLARE_NONSTD(type)     __declspec(dllimport) type
  +/**
  + * The public APR-UTIL variables are declared with APU_DECLARE_DATA.
  + * This assures the appropriate indirection is invoked at compile time.
  + *
  + * @remark extern APU_DECLARE_DATA type apr_variable; syntax is required for
  + * declarations within headers to properly import the variable.
  + */
   #define APU_DECLARE_DATA             __declspec(dllimport)
   #endif
  +/** @} */
   
   #endif /* APU_H */
   #endif /* WIN32 */