You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@httpd.apache.org by rb...@hyperreal.org on 1999/05/10 16:36:37 UTC

cvs commit: apache-apr/apr/threadproc/unix Makefile proc.c threadproc.h

rbb         99/05/10 07:36:36

  Modified:    docs     apr-function.txt fileio.txt impl.txt misc.txt
                        networkio.txt threadproc.txt time.txt
               apr/file_io/beos dir.c fileacc.c filedup.c filestat.c open.c
                        readwrite.c seek.c
               apr/file_io/os2 filedup.c filestat.c open.c readwrite.c
                        seek.c
               apr/file_io/unix dir.c fileacc.c filedup.c fileio.h
                        filestat.c open.c pipe.c readwrite.c seek.c
               apr/misc/unix start.c
               apr/network_io/beos select.c sendrecv.c sockets.c sockopt.c
               apr/network_io/unix networkio.h poll.c sendrecv.c sockets.c
                        sockopt.c
               apr/test Makefile ab_apr.c client.c server.c testfile.c
                        testproc.c testsock.c
               apr/threadproc/unix Makefile proc.c threadproc.h
  Log:
  This is a huge change.  It chagnes all of the "apr_" to "ap_".  It works
  fine on my system (test program included), but I will check it out after
  the commit to make sure it still works.
  
  Revision  Changes    Path
  1.7       +54 -54    apache-apr/docs/apr-function.txt
  
  Index: apr-function.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/apr-function.txt,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- apr-function.txt	1999/02/16 13:11:00	1.6
  +++ apr-function.txt	1999/05/10 14:36:17	1.7
  @@ -31,7 +31,7 @@
   
   - APR_MACROS_AND_MAYBE_CONSTANTS will have all letters capitalized, with
     underscore word separators.
  -- apr_variables_and_functions will have all letters in lower case with
  +- ap_variables_and_functions will have all letters in lower case with
     underscore word separators.
   - APRTypedefsAndStructsAndUnions will have the first letter of each word's
     first letter capitalized. 
  @@ -107,7 +107,7 @@
   * Note: We could also follow the ANSI C model, but this seems more
     appropriate.
   
  - APRStatus apr_open(char *, APRUInt32, APRFilePerms, APRFile)
  + APRStatus ap_open(char *, APRUInt32, APRFilePerms, APRFile)
   	Open the specified file, and return a method for accessing that file.
        Arguments:
   	arg 1)  path name to the file to be opened.
  @@ -127,41 +127,41 @@
                   work, but it will support the set of Unix permissions at
                   minimum.
           arg 4) The abstracted file descriptor for the file that was opened.
  - APRStatus apr_close(APRFile);
  + APRStatus ap_close(APRFile);
   	Close the specified file descriptor
        Arguments:
   	arg 1)  file descriptor of file to be closed.
  - APRStatus apr_read(APRFile, void *, APRUInt64, APRUInt64 *)
  + APRStatus ap_read(APRFile, void *, APRUInt64, APRUInt64 *)
   	Read n bytes from file and store in buffer.
        Arguments:
   	arg 1)  File descriptor to read from
   	arg 2)  buffer to store data in
   	arg 3)  number of bytes to read
   	arg 4)  pointer to number of bytes read. (returned by APR)
  - APRStatus apr_write(APRFile, void *, APRUInt64, APRUInt64 *)
  + APRStatus ap_write(APRFile, void *, APRUInt64, APRUInt64 *)
   	Write n bytes of data from buffer to file
        Arguments:
   	arg 1)  File descriptor to write data to
   	arg 2)  buffer to read data from
   	arg 3)  number of bytes to write
   	arg 4)  pointer to number of bytes written. (returned by APR)
  - APRStatus apr_writev(APRFile, APRIOVec *, APRUInt64, APUInt64 *)
  -	Same as apr_write, except it gets the data from the APRIOVec array.
  + APRStatus ap_writev(APRFile, APRIOVec *, APRUInt64, APUInt64 *)
  +	Same as ap_write, except it gets the data from the APRIOVec array.
        Arguments:
   	arg 1)  File descriptor to write data to
   	arg 2)  Array from which to get the data to write to the file
   	arg 3)  Number of elements in the APRIOVec array.  Must be smaller
  -		than apr_MAX_IOVEC_SIZE, if not function will fail with
  -		apr_BUFFER_OVERFLOW_ERROR
  +		than ap_MAX_IOVEC_SIZE, if not function will fail with
  +		ap_BUFFER_OVERFLOW_ERROR
   	arg 4) number of bytes written.  APR_FAILURE on failure.
  -     NOTES: apr_writev will write a complete entry from APRIOVec array before
  +     NOTES: ap_writev will write a complete entry from APRIOVec array before
   	    moving on to the next one.
  - APRStatus apr_getfileinfo(char *, APRFileInfo *)  
  + APRStatus ap_getfileinfo(char *, APRFileInfo *)  
   	Get information about the file with the given path name.
        Arguments:
   	arg 1)  path to file to get information about
   	arg 2)  Structure to store file's information in. (Returned by APR)
  - APRStatus apr_seek(APRFile, APRInt64, APRSeekWhere, APRInt64 *)
  + APRStatus ap_seek(APRFile, APRInt64, APRSeekWhere, APRInt64 *)
   	Moves the read/write file offset pointer
        Arguments:
   	arg 1)  Pointer to File descriptor  
  @@ -169,35 +169,35 @@
   	arg 3)	How to move the pointer.  See APRSeekWhere def below.
   	arg 4)  Offset into file that the pointer was set to. (Returned by
                   APR)
  - APRStatus apr_access(char *, APRFilePerms)
  + APRStatus ap_access(char *, APRFilePerms)
   	Determine the Accessibility of a file
        Arguments:
   	arg 1)  path to file 
   	arg 3)  Which access permissions to check for.
  - APRStatus apr_opendir(char *, APRDir *)  
  + APRStatus ap_opendir(char *, APRDir *)  
   	Opens the specified directory stream.		
        Arguments:
   	arg 1)  path of the directory to be opened.
   	arg 2) abstracted directory descriptor structure.
  - APRStatus apr_closedir(APRDir *)  
  + APRStatus ap_closedir(APRDir *)  
   	Opens the specified directory stream.		
        Arguments:
   	arg 1) abstracted directory descriptor structure to be closed.
  - APRStatus apr_readdir(APRDir *, APRDirent *)
  + APRStatus ap_readdir(APRDir *, APRDirent *)
   	Retrieve the next directory entry from the specified directory.
        Arguments:
   	arg 1) Abstracted directory descriptor to read from.
   	arg 2) the next directory entry.
   
   ---------------------------Network I/O
  - APRStatus apr_send(APRSocket, const void *, APRUInt64, APRUInt64 *)
  + APRStatus ap_send(APRSocket, const void *, APRUInt64, APRUInt64 *)
   	Sends a message over a socket
        Arguments:
   	arg 1)  Pointer to abstracted File descriptor (socket)  
   	arg 2)  buffer containing message to send
   	arg 3)  size of buf (in bytes)	
   	arg 4)  Amount of data sent in bytes. (Returned by APR)
  - APRStatus apr_recv(APRSocket, void *, APRUInt64, APRUInt64 *);
  + APRStatus ap_recv(APRSocket, void *, APRUInt64, APRUInt64 *);
   	Receive a message from a socket
        Arguments:
   	arg 1)  Pointer to abstracted File descriptor (socket)  
  @@ -209,12 +209,12 @@
                   out
   -->
   	arg 4)  Amount of data received in bytes	
  - APRStatus apr_create_tcp_socket(APSocket *)
  + APRStatus ap_create_tcp_socket(APSocket *)
   	Create a new TCP network connection
        Arguments:
   	arg 1)  Abstracted out ptr to file descriptor, pointing to
   		 the created Socket.  NULL on failure.	
  - APRStatus apr_initializenetaddr(APRNetAddrValue, APRUInt16, APRNetAddr);
  + APRStatus ap_initializenetaddr(APRNetAddrValue, APRUInt16, APRNetAddr);
   	Initialize the fields of a APRNetAddr.  assigning well known values
   	as appropriate.  This function only sets up values in the APRNetAddr
   	structure.  It does not setup the connection.
  @@ -224,13 +224,13 @@
   		INADR_LOOPBACK equivalents.
   	arg 2)  Port number to be assigned in the struct
   	arg 3)  The address of the APRNetAddr struct to be filled out.
  - APRStatus apr_gethostbyname(char *, APRHostEnt)
  + APRStatus ap_gethostbyname(char *, APRHostEnt)
   	Lookup a host by name
        Arguments:
   	arg 1)  string defining the host name of interest
   	arg 2)  returns an APRHostEnt structure that has been filled out
   		 on success.  On failure, it returns NULL.
  - APRStatus apr_gethostbyaddr(const void *, APRInt32, APRNetAddrValue,
  + APRStatus ap_gethostbyaddr(const void *, APRInt32, APRNetAddrValue,
                                APRHostEnt)
   	Lookup a host by address
        Arguments:
  @@ -239,14 +239,14 @@
   	arg 3)  type of address
   	arg 4)  returns an APRHostEnt structure that has been filled out
   		 on success.  On failure, it returns NULL.
  - APRStatus apr_enumeratehostent(APRUInt32, const APRHostEnt *, APRUInt16,
  + APRStatus ap_enumeratehostent(APRUInt32, const APRHostEnt *, APRUInt16,
    APRNetAddr *, APRInt32);
   	Evaluate each of the possible address of a Host Entry retrived from
  -	apr_GetHostByName or apr_GetHostByAddr.
  +	ap_GetHostByName or ap_GetHostByAddr.
        Arguments:
   	arg 1)  The index of the enumeration.  To start, set to zero.  To
   		continue, set to last returned value.
  -	arg 2)  pointer to structure return by apr_GetHostBy* Functions.
  +	arg 2)  pointer to structure return by ap_GetHostBy* Functions.
   	arg 3)  Port number to be asssigned as part of the APRNetAddr
   	        structure.
   	arg 4)  Input a pointer to an APRNetAddr struct.  On output, this
  @@ -254,37 +254,37 @@
   		is filled in by the runtime if the returned result is > 0.
   	arg 5) Next value for the index parameter.  If 0, the enumeration
   		is ended.  APR_FAILURE otherwise.
  - APRStatus apr_familyinet(APRInt16)
  + APRStatus ap_familyinet(APRInt16)
   	Get the value of the address family for IP
        Arguments:
   	return)  Returns the address family
  - APRStatus apr_hton16(APRUInt16, APRUInt16 *)
  + APRStatus ap_hton16(APRUInt16, APRUInt16 *)
   	16 bit conversion from host to network byte order
        Arguments:
   	arg 1)  the integer to convert
   	arg 2)  the integer in proper  byte order. 
  - APRStatus apr_ntoh16(APRUInt16, APRUInt16 *);
  + APRStatus ap_ntoh16(APRUInt16, APRUInt16 *);
   	16 bit conversion from network to host byte order
        Arguments:
   	arg 1)  the integer to convert
   	arg 2)  the integer in proper byte order.
  - APRStatus apr_netaddrtostring(const APRNetAddr *, char *, APRUInt32)
  + APRStatus ap_netaddrtostring(const APRNetAddr *, char *, APRUInt32)
   	Convert an internet address to a String
        Arguments:
   	arg 1)  The structure to get the Internet address from
   	arg 2)  the buffer to store the converted address into
   	arg 3)  The size of the buffer
  - APRStatus apr_stringtonetaddr(const char *, APRNetAddr *)
  + APRStatus ap_stringtonetaddr(const char *, APRNetAddr *)
   	Convert a string into an internet address
        Arguments:
   	arg 1)  the buffer to get the Internet address from
   	arg 2)  The structure to store the converted address into
  - APRStatus apr_setsocketoption(APRSocket, APRSocketOptionData);
  + APRStatus ap_setsocketoption(APRSocket, APRSocketOptionData);
   	Set options on the specified socket
        Arguments:
   	arg 1)  The abstracted socket to apply the options to
   	arg 2)  The options to be applied.  Or'ed together
  - APRStatus apr_poll(APRPollDesc, APRInt32, APRInt32, APRInt32)
  + APRStatus ap_poll(APRPollDesc, APRInt32, APRInt32, APRInt32)
   	Check an array of File Descriptors for specified events 
        Arguments:
   	arg 1)  The file descriptors to look at.
  @@ -295,18 +295,18 @@
   		below under Events
   	arg 4) Number of file desriptors selected.  0 means call timed out.
   		-1 returned on failure.
  - APRStatus apr_bind(APRSocket, APRNetAddr *)
  + APRStatus ap_bind(APRSocket, APRNetAddr *)
   	Assign an address to an unnamed port
        Arguments:
   	arg 1)  The file desc of the socket to bind.
   	arg 2)  The structure pointing to address to bind to.
  - APRStatus apr_listen(APRSocket, APRUInt32)
  + APRStatus ap_listen(APRSocket, APRUInt32)
   	Mark a socket as accepting connections and limit the size of the 
   	listen queue.
        Arguments:
   	arg 1)  The file desc of the socket to mark
   	arg 2)  The size of the listen queue.
  - APRStatus apr_accept(APRSocket, APRNetAddr *, APRSocket *)
  + APRStatus ap_accept(APRSocket, APRNetAddr *, APRSocket *)
   	extract first connection from listen queue, and sets up a new 
   	connection on a new socket of the same type and family.  It allocates
   	a new socket for that connection.
  @@ -317,12 +317,12 @@
   	arg 3) file descriptor of created socket.  -1 on failure.
        NOTE:  accepted socket can not accept more connections.  Original socket
   	    remains open, and can accept more connections.
  - APRStatus apr_getsockname(APRSocket, APRNetAddr *)
  + APRStatus ap_getsockname(APRSocket, APRNetAddr *)
   	retrieves the locally bound name of the specified socket.
        Arguments:
   	arg 1)  The file desc of the socket to retrieve the name for.
   	arg 2)  structure to store socket address in.
  - APRStatus apr_shutdown(APRSocket, APRShutdownHow)
  + APRStatus ap_shutdown(APRSocket, APRShutdownHow)
   	shuts down part of a full-duplex connection on a specified socket
        Arguments:
   	arg 1)  File descriptor of socket
  @@ -335,17 +335,17 @@
   	am using seconds instead of milliseconds, because HTTP says we only
   	need second granularity, if this is not granular enough, it is easy to
   	change later.
  - APRStatus apr_current_time(APRTime *)
  + APRStatus ap_current_time(APRTime *)
   	Returns the number of seconds since the epoch.  define the epoch
   	as midnight January 1, 1970, UTC.
        Arguments:
   	arg 1) current time on local machine.
  - APRStatus apr_implode_time(const APRExplodedTime *, APRTime)
  + APRStatus ap_implode_time(const APRExplodedTime *, APRTime)
   	Convert exploded time format into an APRTime value.
        Arguments:
   	arg 1)  Time to convert in Exploded format
   	arg 2)  converted time as seconds since epoch
  - APRStatus apr_format_time(char *, APRUInt32, char *, APRExplodedTime,
  + APRStatus ap_format_time(char *, APRUInt32, char *, APRExplodedTime,
   			   APRUInt32);
   	Format time into a buffer.
        Arguments:
  @@ -355,7 +355,7 @@
   		reference above)
   	arg 4)  Time variable to convert
   	arg 5)  number of bytes of buffer used.
  - APRStatus apr_explode_time(APRTime, APRTimePARAMFN, APRExplodedTime);
  + APRStatus ap_explode_time(APRTime, APRTimePARAMFN, APRExplodedTime);
   	Convert APRTime vlaue into an expanded time format.
        Arguments:
   	arg 1)  number of seconds since the epoch to convert to Expanded time
  @@ -363,19 +363,19 @@
   	arg 3)  structure to store expanded time into
   
   ---------------------------Locking
  - APRStatus apr_create_lock(APRLock *)
  + APRStatus ap_create_lock(APRLock *)
   	Creates a new lock.
        Arguments:
   	arg 1)  pointer to the new lock object on success.
  - APRStatus apr_lock(APRLock)
  + APRStatus ap_lock(APRLock)
   	Locks the specified lock object (blocking whene necessary)
        Arguments:
   	arg 1) Lock object to be locked.
  - APRStatus apr_unlock(APRLock);
  + APRStatus ap_unlock(APRLock);
   	Unlocks the specified lock object.
        Arguments:
   	arg 1)  the lock object to be unlocked.
  - APRStatus apr_destroylock(APRLock)
  + APRStatus ap_destroylock(APRLock)
   	Destroys the lock object.
        Arguments:
   	arg 1)  the lock to destory. 
  @@ -383,18 +383,18 @@
   	    destroy it.
   
   ---------------------------Thread/Process abstraction
  - APRStatus  apr_get_thread_private(APRUInt32, APThdPriv)
  + APRStatus  ap_get_thread_private(APRUInt32, APThdPriv)
           Get the thread private data for the current thread
        Arguments:
   	arg 1)  index into thread private data table
   	arg 2)  the thread private data structure.  NULL if thread private
   		 has not been set.
  - APRStatus apr_set_thread_private(APRUInt32, APRThdPriv)
  + APRStatus ap_set_thread_private(APRUInt32, APRThdPriv)
   	Set per-thread private data.
        Arguments:
   	arg 1)  index into thread private data table
   	arg 2)  pointer to per-thread private data structure.
  - APRStatus apr_newthreadprivateIndex(APRUInt32, APRThdDestFn)
  + APRStatus ap_newthreadprivateIndex(APRUInt32, APRThdDestFn)
   	Returns a new index for the thread-private data table and can associate
   	a destructor with the data that has been assigned to the index.
        Arguments:
  @@ -402,7 +402,7 @@
   		that is valid for all threads in the current process.
   	arg 2)  a destructor function for use with the data associated with
   		the returned index.
  - APRStatus apr_create_thread(APRThreadType, void * (void *), void *,
  + APRStatus ap_create_thread(APRThreadType, void * (void *), void *,
   	      APRThreadPriority, APRUInt32, APRThread *)
   	Create a new thread
        Arguments:
  @@ -416,7 +416,7 @@
   		specific default size.
   	arg 6)  The thread created.
   
  - APRStatus apr_create_process(char *, char * *, char * *,
  + APRStatus ap_create_process(char *, char * *, char * *,
   			      const APRProcessAttr *, APRProcess)
   	create a new process
        Arguments:
  @@ -427,14 +427,14 @@
   	arg 4)  a pointer to structure that describes the attributes of the new
   		process.  If NULL, process will have the default attributes.
   	arg 5)  Process description structure.
  - APRStatus apr_procsetcurrdir(APRPROCESSATTR *, char *);
  + APRStatus ap_procsetcurrdir(APRPROCESSATTR *, char *);
   	change the current directory of the process attribute structure.
        Arguments:
   	arg 1)  Structure to change the dir in.
   	arg 2)	Path to change the directory to in the APRPROCESSATTR struct.
   
   ---------------------------Initialization and Termination
  - APRStatus apr_initialize(APRPRIMARYFN, APRINTN, char **, APRUINTN, APRINTN)
  + APRStatus ap_initialize(APRPRIMARYFN, APRINTN, char **, APRUINTN, APRINTN)
   	Do any initialization work required to setup te run-time.  Also launch
   	the main thread with Priority NORMAL.
        Arguments:
  @@ -442,9 +442,9 @@
   	arg 2)	number of arguments to program.
   	arg 3)	array of char strings of arguments.
   	arg 4)  return value of primary function
  - APRStatus apr_abort(void)
  + APRStatus ap_abort(void)
   	Stop the entire process and output a core file.
  - APRStatus apr_get_system_info(APRSYSINFO, char *, APRUInt32)
  + APRStatus ap_get_system_info(APRSYSINFO, char *, APRUInt32)
   	Return the information requested about the system
        Arguments:
   	arg 1)  Specifies system information requested.
  
  
  
  1.20      +29 -29    apache-apr/docs/fileio.txt
  
  Index: fileio.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/fileio.txt,v
  retrieving revision 1.19
  retrieving revision 1.20
  diff -u -r1.19 -r1.20
  --- fileio.txt	1999/04/30 18:38:56	1.19
  +++ fileio.txt	1999/05/10 14:36:17	1.20
  @@ -1,6 +1,6 @@
   <h2>File I/O</h2>
   
  - apr_file_t *apr_open(apr_context_t *, char *, apr_int32_t, apr_fileperms_t mode)
  + ap_file_t *ap_open(ap_context_t *, char *, ap_int32_t, ap_fileperms_t mode)
   	Open the specified file, and return a method for accessing that file.
        Arguments:
           arg 1)  The context to use.
  @@ -33,7 +33,7 @@
           is small, and a stat isn't required after opening the file. 
   
   
  -apr_status_t apr_close(apr_context_t *, apr_file_t *);
  +ap_status_t ap_close(ap_context_t *, ap_file_t *);
   	Close the specified file descriptor
        Arguments:
           arg 1)  The context to use.
  @@ -43,7 +43,7 @@
   Notes:  The fields within the APRFile structure will not be changed when a file
   	is closed.  The ONLY updated field, will be the file descriptor.
   
  - apr_size_t apr_read(apr_context_t *, apr_file_t *, void *, apr_size_t)
  + ap_size_t ap_read(ap_context_t *, ap_file_t *, void *, ap_size_t)
   	Read n bytes from file and store in buffer.
        Arguments:
           arg 1)  The context to use.
  @@ -52,7 +52,7 @@
   	arg 4)  number of bytes to read
   	return) pointer to number of bytes read.
   
  - apr_size_t apr_write(apr_context_t *, apr_file_t *, void *, apr_size_t)
  + ap_size_t ap_write(ap_context_t *, ap_file_t *, void *, ap_size_t)
   	Write n bytes of data from buffer to file
        Arguments:
           arg 1)  The context to use.
  @@ -61,21 +61,21 @@
   	arg 4)  number of bytes to write
   	return) pointer to number of bytes written. 
   
  -Notes:  apr_write tries to update the apr_file_t that is passed in, but it fails
  +Notes:  ap_write tries to update the ap_file_t that is passed in, but it fails
           silently if it is unable to do so.
   
  - apr_file_t apr_dupfile(apr_context_t *, apr_file_t *)
  -        Copy data from one apr_file_t to a new one.
  + ap_file_t ap_dupfile(ap_context_t *, ap_file_t *)
  +        Copy data from one ap_file_t to a new one.
        Arguments:
           arg 1)  The context to use.
           arg 2)  the file info to save.
           return) a new file structure.
   
   Notes:  This does not duplicate the file descriptor, it just saves the data
  -        from apr_file_t to a new apr_file_t.  This is used so user programs
  -        do not need access to the internals of apr_file_t
  +        from ap_file_t to a new ap_file_t.  This is used so user programs
  +        do not need access to the internals of ap_file_t
   
  - apr_status apr_getfileinfo(apr_context_t *, char *, apr_file_t *)  
  + ap_status ap_getfileinfo(ap_context_t *, char *, ap_file_t *)  
   	Get information about the file with the given path name.
        Arguments:
           arg 1)  The context to use.
  @@ -83,17 +83,17 @@
   	arg 3)  Structure to store file's information in. 
           return) APR_SUCCESS or APR_FAILURE.
   
  - apr_status apr_updatefileinfo(apr_context_t *, apr_file_t *)  
  + ap_status ap_updatefileinfo(ap_context_t *, ap_file_t *)  
   	Get information about the file with the given path name.
        Arguments:
           arg 1)  The context to use.
   	arg 2)  Structure to store file's information in. 
           return) APR_SUCCESS or APR_FAILURE.
   
  -Notes:  apr_updatefileinfo overwrites the old info, so if it is needed, the old
  -        info should be saved off to the side, using apr_dupfile.
  +Notes:  ap_updatefileinfo overwrites the old info, so if it is needed, the old
  +        info should be saved off to the side, using ap_dupfile.
   
  - apr_off_t apr_seek(apr_context_t *, apr_file_t, apr_off_t, apr_seek_where_t)
  + ap_off_t ap_seek(ap_context_t *, ap_file_t, ap_off_t, ap_seek_where_t)
   	Moves the read/write file offset pointer
        Arguments:
           arg 1)  The context to use.
  @@ -105,7 +105,7 @@
                       APR_END -- add the offset to the current file size.
   	return) Offset into file that the pointer was set to.
   
  - apr_status_t apr_remove_file(apr_context_t *, char *)
  + ap_status_t ap_remove_file(ap_context_t *, char *)
           Removes the file pointed to by the character string
        Arguments:
           arg 1)  The context to use.
  @@ -114,35 +114,35 @@
   Notes:  If the file is still open, it will not actually be removed until the
           all references of the file are closed.
   
  - apr_dir_t *apr_opendir(apr_context_t *, const char *)  
  + ap_dir_t *ap_opendir(ap_context_t *, const char *)  
   	Opens the specified directory stream.		
        Arguments:
           arg 1)  The context to use.
   	arg 2)  path of the directory to be opened.
   	return) abstracted directory descriptor structure.
   
  - apr_status_t apr_closedir(apr_context_t *, apr_dir_t *)  
  + ap_status_t ap_closedir(ap_context_t *, ap_dir_t *)  
   	closes the specified directory stream.		
        Arguments:
           arg 1)  The context to use.
   	arg 2)  abstracted directory descriptor structure to be closed.
           return) APR_SUCCESS or APR_FAILURE
   
  - apr_dirent_t *apr_readdir(apr_context_t *, apr_dir_t *)
  + ap_dirent_t *ap_readdir(ap_context_t *, ap_dir_t *)
   	Retrieve the next directory entry from the specified directory.
        Arguments:
           arg 1)  The context to use.
   	arg 2)  Abstracted directory descriptor to read from.
   	return) the next directory entry.
   
  - apr_status_t *apr_rewinddir(apr_context_t *, apr_dir_t *)
  + ap_status_t *ap_rewinddir(ap_context_t *, ap_dir_t *)
           Rewind directory to beginning of stream
        Arguments:
           arg 1)  The context to use.
           arg 2)  Directory structure to rewind
           return) APR_SUCCESS.  (POSIX does not allow this function to fail!)
   
  - apr_status_t apr_make_dir(apr_context_t *, const char *, apr_fileperms_t)
  + ap_status_t ap_make_dir(ap_context_t *, const char *, ap_fileperms_t)
           Create a new directory on the disk
        Arguments:
           arg 1)  The context to use.
  @@ -150,34 +150,34 @@
           arg 3)  The permissions to set for the new directory.
           return) APR_SUCCESS or APR_FAILURE
   
  - apr_status_t apr_remove_dir(apr_context_t *, const char *)
  + ap_status_t ap_remove_dir(ap_context_t *, const char *)
           Remove a direcotry from the disk
        Arguments:
           arg 1)  The context to use.
           arg 2)  The path of the directory to remove.
           return) APR_SUCCESS or APR_FAILURE
   
  - apr_ssize_t apr_writev(apr_context_t *, apr_file_t, apr_iovec_t *, apr_ssize_t)
  -	Same as apr_write, except it gets the data from the APRIOVec array.
  + ap_ssize_t ap_writev(ap_context_t *, ap_file_t, ap_iovec_t *, ap_ssize_t)
  +	Same as ap_write, except it gets the data from the APRIOVec array.
        Arguments:
           arg 1)  The context to use.
   	arg 2)  File descriptor to write data to
   	arg 3)  Array from which to get the data to write to the file
   	arg 4)  Number of elements in the APRIOVec array.  Must be smaller
  -		than apr_MAX_IOVEC_SIZE, if not function will fail with
  +		than ap_MAX_IOVEC_SIZE, if not function will fail with
   		APR_BUFFER_OVERFLOW_ERROR
   	return) number of bytes written.  APR_FAILURE on failure.
  -Notes: apr_writev will write a complete entry from APRIOVec array before
  +Notes: ap_writev will write a complete entry from APRIOVec array before
          moving on to the next one.
   
  - char * apr_get_filename(apr_context_t *, apr_file_t *)
  + char * ap_get_filename(ap_context_t *, ap_file_t *)
           Get the name of an opened file. 
        Arguments:
           arg 1)  The context to use.
   	arg 2)  File to get the name of 
   	return) filename.  NULL on failure 
   
  - apr_status_t apr_create_pipe(apr_context_t *, apr_file_t *, apr_file_t *)
  + ap_status_t ap_create_pipe(ap_context_t *, ap_file_t *, ap_file_t *)
           create an unnamed pipe
        Arguments:
           arg 1)  The context to use.
  @@ -191,7 +191,7 @@
          what isn't.  All other fields are left to the individual platform to
          set appropriately.  
   
  - char *apr_create_namedpipe(apr_context_t *, char *, apr_fileperms_t)
  + char *ap_create_namedpipe(ap_context_t *, char *, ap_fileperms_t)
           create a uniquely named pipe in the temp directory.
         Arguments:
           arg 1)  The context to use.
  @@ -204,7 +204,7 @@
   
   **************** IMPLEMENTATION DETAILS **************
   
  -struct apr_file_t {
  +struct ap_file_t {
       int filedes;
       char * fname;
       int buffered;
  
  
  
  1.3       +1 -1      apache-apr/docs/impl.txt
  
  Index: impl.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/impl.txt,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- impl.txt	1999/04/09 14:37:01	1.2
  +++ impl.txt	1999/05/10 14:36:18	1.3
  @@ -11,7 +11,7 @@
    APRFile
   	Windows:  Handle.
   	UNIX:  structure {
  -			 apr_int32_t file descriptor
  +			 ap_int32_t file descriptor
   			 char *name
   			 int mode
   			 int user id
  
  
  
  1.2       +7 -6      apache-apr/docs/misc.txt
  
  Index: misc.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/misc.txt,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- misc.txt	1999/04/29 20:20:45	1.1
  +++ misc.txt	1999/05/10 14:36:18	1.2
  @@ -1,11 +1,11 @@
   <h2>Misc Functions</h2>
   
  - apr_context_t *apr_initialize(void *)
  + ap_context_t *ap_initialize(void *)
         Initialize apr so it can be used by the program.
       Arguments:
         arg 1)  A pointer to any program specific data
         return) An apr context type.  The first field in this is ALWAYS an 
  -              apr_pool.  NULL on failure.
  +              ap_pool.  NULL on failure.
   NOTE:  This is NOT an abstract type.  This is apr specific, and the pools may
          be abstract, but the context is constant acrosee platforms, so programs
          can access the internals of this structure.  The default is that this
  @@ -13,14 +13,14 @@
          The prog_data field is basically thread-local storage, so there will be
          no OS specific TLS within APR.
   
  - apr_status_t apr_set_signal_safe(apr_context_t *, apr_int16_t)
  + ap_status_t ap_set_signal_safe(ap_context_t *, ap_int16_t)
         Should the apr functions using this context be signal-safe?
       Arguments:
         arg 1)  The context in question.
         arg 2)  Bool value.  1 means signal-safe, 0 means non-signal-safe.
         return) APR_SUCCESS
    
  - apr_status_t apr_set_cancel_safe(apr_context_t *, apr_int16_t)
  + ap_status_t ap_set_cancel_safe(ap_context_t *, ap_int16_t)
         Should the apr functions using this context be safe for asynch
         thread cancelation?
       Arguments:
  @@ -28,7 +28,7 @@
         arg 2)  Bool value.  1 means cancel-safe, 0 means non-cancel-safe.
         return) APR_SUCCESS
   
  - apr_create_sub_context(apr_context_t *, void *)
  + ap_create_sub_context(ap_context_t *, void *)
         Create a sub context.  (Includes creating a sub pool.
       Arguments:
         arg 1)  The context to be the parent.
  @@ -37,8 +37,9 @@
         return) a new context, complete with new sub_pool.  Inherits safeness
                 features from the parent.
    
  - apr_destroy_context(apr_context_t *)
  + ap_exit(ap_context_t *)
         Destroy a context and all sub_contexts.
       Arguments:
         arg 1)  The context to destroy
         return) APR_SUCCESS
  +    
  
  
  
  1.21      +46 -46    apache-apr/docs/networkio.txt
  
  Index: networkio.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/networkio.txt,v
  retrieving revision 1.20
  retrieving revision 1.21
  diff -u -r1.20 -r1.21
  --- networkio.txt	1999/04/30 18:38:56	1.20
  +++ networkio.txt	1999/05/10 14:36:18	1.21
  @@ -1,12 +1,12 @@
   <h2> Network I/O</h2>
   
  - apr_socket_t *apr_create_tcp_socket(void)
  + ap_socket_t *ap_create_tcp_socket(void)
   	Create a new TCP network connection
        Arguments:
   	return) Abstracted out ptr to file descriptor, pointing to
   		 the created Socket.  NULL on failure.
   	
  - apr_status_t apr_shutdown(apr_socket_t *, apr_shutdown_how_e)
  + ap_status_t ap_shutdown(ap_socket_t *, ap_shutdown_how_e)
   	shuts down part of a full-duplex connection on a specified socket
        Arguments:
   	arg 1)  File descriptor of socket
  @@ -16,10 +16,10 @@
   			 APR_SHUTDOWN_WRITE
   			 APR_SHUTDOWN_READWRITE
           return) APR_SUCCESS or APR_FAILURE
  -Note:  This does not free the memory consumed by apr_socket, apr_clsoe will take
  +Note:  This does not free the memory consumed by ap_socket, ap_clsoe will take
          care of that.
   
  - apr_status_t apr_close_socket(apr_socket_t *)
  + ap_status_t ap_close_socket(ap_socket_t *)
           closes the socket descriptor
        Arguments:
           arg 1)  The socket to close
  @@ -28,7 +28,7 @@
          hopes that we may be able to close it later.  If we free all the memory
          used, we can't even try to recover.
   
  - apr_ssize_t apr_send(apr_socket_t *, const char *, apr_int32_t, time_t)
  + ap_ssize_t ap_send(ap_socket_t *, const char *, ap_int32_t, time_t)
   	Sends a message over a socket
        Arguments:
   	arg 1)  Pointer to abstracted socket  
  @@ -39,7 +39,7 @@
           return) The number of bytes sent over the network.  APR_FAILURE on 
                   failure.
   
  - apr_ssize_t apr_recv(apr_socket_t, char *, apr_int32_t, time_t)
  + ap_ssize_t ap_recv(ap_socket_t, char *, ap_int32_t, time_t)
   	Receive a message from a socket
        Arguments:
   	arg 1)  Pointer to abstracted socket  
  @@ -48,7 +48,7 @@
   	arg 4)  time to wait for message from network, in seconds.
           return) Amount of data received in bytes
   
  - apr_status_t apr_setsocketopt(apr_socket_t *, apr_socketoption_t, apr_int32_t on);
  + ap_status_t ap_setsocketopt(ap_socket_t *, ap_socketoption_t, ap_int32_t on);
   	Set options on the specified socket
        Arguments:
   	arg 1)  The abstracted socket to apply the options to
  @@ -60,33 +60,33 @@
                   APR_SO_REUSEADDR
           arg 3)  1 if turning the option on, 0 if turning it off.
           return) APR_SUCCESS or APR_FAILURE.
  -Note: To unset an option, call apr_setsocketoption with the same argument. 
  +Note: To unset an option, call ap_setsocketoption with the same argument. 
   
  - void apr_sd_set(apr_socket_t *, sd_set *)
  -        set the bit in the apr_sd_set that corresponds to the socket
  + void ap_sd_set(ap_socket_t *, sd_set *)
  +        set the bit in the ap_sd_set that corresponds to the socket
        Arguments:
           arg 1)  The socket we care about.
  -        arg 2)  The apr_sd_set we are adding to.
  +        arg 2)  The ap_sd_set we are adding to.
   
  - void apr_sd_clr(apr_socket_t *, apr_sd_set *)
  -        clear the bit in the apr_sd_set that corresponds to the socket
  + void ap_sd_clr(ap_socket_t *, ap_sd_set *)
  +        clear the bit in the ap_sd_set that corresponds to the socket
        Arguments:
           arg 1)  The socket we care about.
  -        arg 2)  The apr_sd_set we are removing from.
  +        arg 2)  The ap_sd_set we are removing from.
   
  - int apr_sd_isset(apr_socket_t *, apr_sd_set *)
  -        check the bit in the apr_sd_set that corresponds to the socket
  + int ap_sd_isset(ap_socket_t *, ap_sd_set *)
  +        check the bit in the ap_sd_set that corresponds to the socket
        Arguments:
           arg 1)  The socket we care about.
  -        arg 2)  The apr_sd_set we are checking.
  +        arg 2)  The ap_sd_set we are checking.
           return) APR_SUCCESS if there, APR_FAILURE otherwise
   
  - void apr_sd_zero(apr_sd_set *)
  -        clear all bits in the apr_sd_set
  + void ap_sd_zero(ap_sd_set *)
  +        clear all bits in the ap_sd_set
        Arguments:
  -        arg 1)  The apr_sd_set we are clearing.
  +        arg 1)  The ap_sd_set we are clearing.
   
  - apr_int32_t apr_poll(apr_pollfd_t *, apr_int32_t, apr_int32_t) 
  + ap_int32_t ap_poll(ap_pollfd_t *, ap_int32_t, ap_int32_t) 
   	Monitor sockets for specifiedconditions. 
        Arguments:
   	arg 1)  an array of sockets to monitor and events to wait for.
  @@ -104,20 +104,20 @@
   	return) Number of file desriptors triggered.  0 means call timed out.
   		-1 returned on failure.
   
  - apr_status_t apr_setport(apr_socket_t *, apr_uint32_t)
  + ap_status_t ap_setport(ap_socket_t *, ap_uint32_t)
           Assign the port to the socket variable.
        Arguments:
           arg 1)  The socket variable to modify.
           arg 2)  The port to be bound to the socket.
           return) APR_SUCCESS or APR_FAILURE
   
  - apr_status_t apr_bind(apr_socket_t)
  + ap_status_t ap_bind(ap_socket_t)
   	Assign an address to an unnamed port
        Arguments:
   	arg 1)  The abstracted socket to bind.
           return) APR_SUCCESS or APR_FAILURE
   
  - apr_status_t apr_listen(apr_socket_t *, apr_int32_t)
  + ap_status_t ap_listen(ap_socket_t *, ap_int32_t)
   	Mark a socket as accepting connections and limit the size of the 
   	listen queue.
        Arguments:
  @@ -125,7 +125,7 @@
   	arg 2)  The size of the listen queue.
           return) APR_SUCCESS or APR_FAILURE
   
  - apr_socket_t *apr_accept(apr_socket_t *)
  + ap_socket_t *ap_accept(ap_socket_t *)
   	extract first connection from listen queue, and sets up a new 
   	connection on a new socket of the same type and family.  It allocates
   	a new socket for that connection.
  @@ -136,7 +136,7 @@
   NOTE:  accepted socket can not accept more connections.  Original socket
          remains open, and can accept more connections.
   
  - apr_status_t apr_connect(apr_socket_t *, char *, unisigned short)
  + ap_status_t ap_connect(ap_socket_t *, char *, unisigned short)
           Connect to a listening socket.
         Arguments:
           arg 1)  Socket to use to connect.
  @@ -144,52 +144,52 @@
           arg 3)  port to connect to.
           return) APR_SUCCESS or APR_FAILURE. 
   NOTE:  On failure, socket is closed, and memory is free'd on failure.  ALWAYS
  -       create the socket in apr_create_tcp_socket before calling this function.
  +       create the socket in ap_create_tcp_socket before calling this function.
    
  -char *apr_get_remote_hostname(apr_socket_t *)
  +char *ap_get_remote_hostname(ap_socket_t *)
           Get the host name for the remote machine
        Arguments:
           arg 1)  socket connection is on.
           return) name of remote machine. 
   
  - apr_status_t apr_gethostname(char *, int)
  + ap_status_t ap_gethostname(char *, int)
          Get the host name for the machine
        Arguments:
          arg 1)  Buffer to write name to.
          arg 2)  Size of buffer.
          return) APR_SUCCESS or APR_FAILURE
   
  - APRStatus apr_familyinet(APRInt16)
  + APRStatus ap_familyinet(APRInt16)
   	Get the value of the address family for IP
        Arguments:
   	return)  Returns the address family
  - APRStatus apr_hton16(APRUInt16, APRUInt16 *)
  + APRStatus ap_hton16(APRUInt16, APRUInt16 *)
   	16 bit conversion from host to network byte order
        Arguments:
   	arg 1)  the integer to convert
   	arg 2)  the integer in proper  byte order. 
  - APRStatus apr_ntoh16(APRUInt16, APRUInt16 *);
  + APRStatus ap_ntoh16(APRUInt16, APRUInt16 *);
   	16 bit conversion from network to host byte order
        Arguments:
   	arg 1)  the integer to convert
   	arg 2)  te integer in proper byte order.
  - APRStatus apr_netaddrtostring(const APRNetAddr *, char *, APRUInt32)
  + APRStatus ap_netaddrtostring(const APRNetAddr *, char *, APRUInt32)
   	Convert an internet address to a String
        Arguments:
   	arg 1)  The structure to get the Internet address from
   	arg 2)  the buffer to store the converted address into
   	arg 3)  The size of the buffer
  - APRStatus apr_stringtonetaddr(const char *, APRNetAddr *)
  + APRStatus ap_stringtonetaddr(const char *, APRNetAddr *)
   	Convert a string into an internet address
        Arguments:
   	arg 1)  the buffer to get the Internet address from
   	arg 2)  The structure to store the converted address into
  - APRStatus apr_getsockname(APRSocket, APRNetAddr *)
  + APRStatus ap_getsockname(APRSocket, APRNetAddr *)
   	retrieves the locally bound name of the specified socket.
        Arguments:
   	arg 1)  The file desc of the socket to retrieve the name for.
   	arg 2)  structure to store socket address in.
  - APRStatus apr_initializenetaddr(APRNetAddrValue, APRUInt16, APRNetAddr);
  + APRStatus ap_initializenetaddr(APRNetAddrValue, APRUInt16, APRNetAddr);
   	Initialize the fields of a APRNetAddr.  assigning well known values
   	as appropriate.  This function only sets up values in the APRNetAddr
   	structure.  It does not setup the connection.
  @@ -199,13 +199,13 @@
   		INADR_LOOPBACK equivalents.
   	arg 2)  Port number to be assigned in the struct
   	arg 3)  The address of the APRNetAddr struct to be filled out.
  - APRStatus apr_gethostbyname(char *, APRHostEnt)
  + APRStatus ap_gethostbyname(char *, APRHostEnt)
   	Lookup a host by name
        Arguments:
   	arg 1)  string defining the host name of interest
   	arg 2)  returns an APRHostEnt structure that has been filled out
   		 on success.  On failure, it returns NULL.
  - APRStatus apr_gethostbyaddr(const void *, APRInt32, APRNetAddrValue,
  + APRStatus ap_gethostbyaddr(const void *, APRInt32, APRNetAddrValue,
                                APRHostEnt)
   	Lookup a host by address
        Arguments:
  @@ -214,14 +214,14 @@
   	arg 3)  type of address
   	arg 4)  returns an APRHostEnt structure that has been filled out
   		 on success.  On failure, it returns NULL.
  - APRStatus apr_enumeratehostent(APRUInt32, const APRHostEnt *, APRUInt16,
  + APRStatus ap_enumeratehostent(APRUInt32, const APRHostEnt *, APRUInt16,
    APRNetAddr *, APRInt32);
   	Evaluate each of the possible address of a Host Entry retrived from
  -	apr_GetHostByName or apr_GetHostByAddr.
  +	ap_GetHostByName or ap_GetHostByAddr.
        Arguments:
   	arg 1)  The index of the enumeration.  To start, set to zero.  To
   		continue, set to last returned value.
  -	arg 2)  pointer to structure return by apr_GetHostBy* Functions.
  +	arg 2)  pointer to structure return by ap_GetHostBy* Functions.
   	arg 3)  Port number to be asssigned as part of the APRNetAddr
   	        structure.
   	arg 4)  Input a pointer to an APRNetAddr struct.  On output, this
  @@ -234,15 +234,15 @@
   
   **************** IMPLEMENTATION DETAILS *****************
   
  -struct apr_socket_t {
  +struct ap_socket_t {
       int socketdes
       char *remote_hostname
       struct sockaddr *addr
       size_t addr_len
   }
   
  -struct apr_pollfd_t {
  -    apr_socket_t *sock
  -    apr_int16_t events
  -    apr_int16_t revents
  +struct ap_pollfd_t {
  +    ap_socket_t *sock
  +    ap_int16_t events
  +    ap_int16_t revents
   }
  
  
  
  1.9       +101 -38   apache-apr/docs/threadproc.txt
  
  Index: threadproc.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/threadproc.txt,v
  retrieving revision 1.8
  retrieving revision 1.9
  diff -u -r1.8 -r1.9
  --- threadproc.txt	1999/04/29 20:20:45	1.8
  +++ threadproc.txt	1999/05/10 14:36:18	1.9
  @@ -3,7 +3,7 @@
   NOTE:  There is a one-to-one mapping between process and process_attr's.  This
          relationship does not exist with threads and thread_attr's.
   
  - apr_int32_t apr_fork(apr_proc_t *)
  + ap_int32_t ap_fork(ap_proc_t *)
           create a new process with a copy of the currently executing address space.
        Arguments:
           arg 1)  the proccess type for the newly created process.  NULL on error.
  @@ -15,12 +15,12 @@
          to produce this function should define it as NULL, so that there are
          no compile time errors. 
           
  - apr_procattr_t *apr_createprocattr_init(void);
  + ap_procattr_t *ap_createprocattr_init(void);
           create a new process attr type with OS dependant defaults
        Arguments:
           return) New process attribute type.
   
  - apr_status_t apr_setprocattr_io(apr_procattr_t *, apr_int32_t, apr_int32_t, apr_int32_t)
  + ap_status_t ap_setprocattr_io(ap_procattr_t *, ap_int32_t, ap_int32_t, ap_int32_t)
           setup stdin, stdout, and stderr attributes for the new proc
        Arguments
           arg 1)  the process attr to modify
  @@ -30,17 +30,17 @@
           return) APR_SUCCESS or APR_FAILURE
   NOTE:  the file structures are a part of the process attr variable.  They are
          created and filled out by this func.  On UNIX, this function actually
  -       creates the pipe(s), but lets apr_create_process set them up as 
  +       creates the pipe(s), but lets ap_create_process set them up as 
          std(in|out|err).
   
  - apr_status_t apr_setprocattr_dir(apr_procattr_t *, char *)
  + ap_status_t ap_setprocattr_dir(ap_procattr_t *, char *)
          define starting directory for new process.
        Arguments
          arg 1)  The process attr to modify
          arg 2)  The starting directory for the new process.
          return) APR_SUCCESS or APR_FAILURE
   
  - apr_proc_t *apr_create_process(char *, char *const [], char **, const apr_procattr_t *)
  + ap_proc_t *ap_create_process(char *, char *const [], char **, const ap_procattr_t *)
   	create a new process and run a new executable in it.
        Arguments:
   	arg 1)  Path name of the executable file 
  @@ -52,7 +52,7 @@
   		process.  If NULL, process will have the default attributes.
   	return) Process description structure.  NULL on failure
   
  - apr_file_t *apr_get_childin(apr_proc_t *)
  + ap_file_t *ap_get_childin(ap_proc_t *)
           Get the parent side of the pipe that connects to the child's stdin.
           This function is only valid after a process has successfully spawned
           a child
  @@ -61,7 +61,7 @@
           return) The file to use when writing to the child's stdin.  NULL
                   on error. 
   
  - apr_file_t *apr_get_childout(apr_proc_t *)
  + ap_file_t *ap_get_childout(ap_proc_t *)
           Get the parent side of the pipe that connects to the child's stdout.
           This function is only valid after a process has successfully spawned
           a child
  @@ -70,7 +70,7 @@
           return) The file to use when reading from the child's stdout.  NULL
                   on error. 
   
  - apr_file_t *apr_get_childerr(apr_proc_t *)
  + ap_file_t *ap_get_childerr(ap_proc_t *)
           Get the parent side of the pipe that connects to the child's stderr.
           This function is only valid after a process has successfully spawned
           a child
  @@ -79,7 +79,7 @@
           return) The file to use when reading from the child's stderr.  NULL
                   on error.   
   
  - apr_status_t apr_wait_proc(apr_proc_t *, apr_wait_how_e) 
  + ap_status_t ap_wait_proc(ap_proc_t *, ap_wait_how_e) 
           Wait for a specified process to exit
        Arguments:
           arg 1)  The process to wait for.
  @@ -88,46 +88,109 @@
                   APR_NOWAIT
           return) APR_SUCCESS or APR_fAILURE
   
  - apr_threadattr_t *apr_create_threadattr(void);
  + ap_threadattr_t *ap_create_threadattr(ap_context_t *);
           create a new thread attr type with OS dependant defaults
        Arguments:
  +        arg 1)  The context to operate on. 
           return) New thread attribute type.
  +NOTE:  All threads should be started joinable by default.
   
  - apr_thread_t *apr_create_thread(apr_threadattr_t *, void * (void *), void *)
  +ap_status_t ap_setthreadattr_detach(ap_context_t *, ap_threadattr_t *, ap_int32_t)
  +        Determine if a thread is joinable or detached when created.
  +     Arguments:
  +        arg 1)  The context to operate on.
  +        arg 2)  The attribute to modify
  +        arg 3)  1 -> start detached, 0 -> start joinable.
  +        return) APR_SUCCESS or APR_FAILURE
  +
  +ap_status_t ap_getthreadattr_detach(ap_context_t *, ap_threadattr_t *)
  +        Question thread if is joinable or detached when created.
  +     Arguments:
  +        arg 1)  The context to operate on.
  +        arg 2)  The attribute to modify
  +        return) APR_SUCCESS if detached or APR_FAILURE if joinable.
  +
  + ap_thread_t *ap_create_thread(ap_context_t *, ap_threadattr_t *, void * (void *), void *)
   	Create a new thread
        Arguments:
  -        arg 1)  The attributes to use when creating the thread.
  -	arg 2)	pointer to the root function of the new thread.  This function
  +        arg 1)  The context to operate on
  +        arg 2)  The attributes to use when creating the thread.
  +	arg 3)	pointer to the root function of the new thread.  This function
   		is called when the thread is created.  Returning from this
   		function is the only way to terminate the thread.
  -	arg 3)	parameter to pass to thread's root func.
  +	arg 4)	parameter to pass to thread's root func.
   	return) The thread created.
   
  - APRStatus  apr_get_thread_private(APRUInt32, APThdPriv)
  -        Get the thread private data for the current thread
  + ap_status_t ap_cancel_thread(ap_context_t *, ap_thread_t *)
  +        Cancel the specified thread
        Arguments:
  -	arg 1)  index into thread private data table
  -	arg 2)  the thread private data structure.  NULL if thread private
  -		 has not been set.
  - APRStatus apr_set_thread_private(APRUInt32, APRThdPriv)
  -	Set per-thread private data.
  -     Arguments:
  -	arg 1)  index into thread private data table
  -	arg 2)  pointer to per-thread private data structure.
  - APRStatus apr_newthreadprivateIndex(APRUInt32, APRThdDestFn)
  -	Returns a new index for the thread-private data table and can associate
  -	a destructor with the data that has been assigned to the index.
  -     Arguments:
  -	arg 1)  On output this is an index into the thread-private data table
  -		that is valid for all threads in the current process.
  -	arg 2)  a destructor function for use with the data associated with
  -		the returned index.
  +        arg 1)  The context to operate on.
  +        arg 2)  The thread to be canceled.
  +        return) APR_SUCCESS or APR_FAILURE. 
  +NOTE:  The return doesn't determine if the thread has been canceled or not.  The
  +       thread itself can determine if it should ignore, honor, or defer the
  +       request to die.  The return code only determines if the request was
  +       sent properly.
  +
  + ap_status_t ap_set_canceltype(ap_context_t *, ap_int32_t)
  +        How do I cancel this thread?
  +     Arguments:
  +        arg 1)  The context to operate on.
  +        arg 2)  How to cancel a thread.  One of:
  +                   APR_CANCEL_ASYNCH
  +                   APR_CANCEL_DEFER
  +        return) APR_SUCCESS or APR_FAILURE
  +NOTE:  This function works on the current thread only.
  +
  + ap_status_t ap_set_cancelstate(ap_context_t *, ap_int32_t)
  +        Can I cancel this thread?
  +     Arguments:
  +        arg 1)  The context to operate on.
  +        arg 2)  Can I cancel this thread.  One of:
  +                   APR_CANCEL_ENABLE
  +                   APR_CANCEL_DISABLE
  +        return) APR_SUCCESS or APR_FAILURE
  +NOTE:  This function works on the current thread only.
  +
  + void ap_thread_exit(ap_context_t *, ap_status_t *)
  +        Exit this therad immediately.
  +     Arguments:
  +        arg 1)  The context to operate on.
  +        arg 2)  The value to return when the thread exits.  Either APR_SUCCESS
  +                of APR_FAILURE.  NULL is also valid here.
  +        return) This function NEVER returns.
  +
  + ap_status_t ap_thread_join(ap_context_t *, ap_thread_t *, ap_status_t *)
  +        Wait for specified thread to exit.
  +     Arguments:
  +        arg 1)  The context to operate on.
  +        arg 2)  The thread to wait for.
  +        arg 3)  The return value of the thread we are waiting for.
  +        return) APR_SUCCESS or APR_FAILURE.
  +
  + ap_status_t ap_thread_detach(ap_context_t *, ap_thread_t *)
  +        Mark a thread as being detached.  No longer a need to join on it.
  +     Arguments:
  +        arg 1)  Context to operate on.
  +        arg 2)  Thread to mark as detached.
  +        return) APR_SUCCESS or APR_FAILURE
  +
  + ap_key_t ap_create_thread_private(ap_context_t *, void (*dest)(void *))
  +	create per-thread private data.
  +     Arguments:
  +	arg 1)  context to operate on.
  +	arg 2)  function used to destroy private data. 
  +        return) Platform dependant key to retrieve private data.
  +
  + ap_status_t ap_set_thread_private(ap_context_t *, ap_key_t, void *)
  +        Set the thread private data for the current thread
  +     Arguments:
  +	arg 1)  Context to operate on. 
  +	arg 2)  Key to thread's private data.
  +        arg 3)  Data to set as thread private.
  +        return) a pointer to the private data.
  +
   
   
   **************** IMPLEMENTATION DETAILS **************   
   
  -struct apr_thread_t {
  -    pthread_t td;
  -    apr_procattr_t attr;
  -} 
  -  
  
  
  
  1.2       +4 -4      apache-apr/docs/time.txt
  
  Index: time.txt
  ===================================================================
  RCS file: /home/cvs/apache-apr/docs/time.txt,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- time.txt	1999/04/20 15:08:48	1.1
  +++ time.txt	1999/05/10 14:36:18	1.2
  @@ -5,17 +5,17 @@
   	am using seconds instead of milliseconds, because HTTP says we only
   	need second granularity, if this is not granular enough, it is easy to
   	change later.
  - APRStatus apr_current_time(APRTime *)
  + APRStatus ap_current_time(APRTime *)
   	Returns the number of seconds since the epoch.  define the epoch
   	as midnight January 1, 1970, UTC.
        Arguments:
   	arg 1) current time on local machine.
  - APRStatus apr_implode_time(const APRExplodedTime *, APRTime)
  + APRStatus ap_implode_time(const APRExplodedTime *, APRTime)
   	Convert exploded time format into an APRTime value.
        Arguments:
   	arg 1)  Time to convert in Exploded format
   	arg 2)  converted time as seconds since epoch
  - APRStatus apr_format_time(char *, APRUInt32, char *, APRExplodedTime,
  + APRStatus ap_format_time(char *, APRUInt32, char *, APRExplodedTime,
   			   APRUInt32);
   	Format time into a buffer.
        Arguments:
  @@ -25,7 +25,7 @@
   		reference above)
   	arg 4)  Time variable to convert
   	arg 5)  number of bytes of buffer used.
  - APRStatus apr_explode_time(APRTime, APRTimePARAMFN, APRExplodedTime);
  + APRStatus ap_explode_time(APRTime, APRTimePARAMFN, APRExplodedTime);
   	Convert APRTime vlaue into an expanded time format.
        Arguments:
   	arg 1)  number of seconds since the epoch to convert to Expanded time
  
  
  
  1.2       +7 -7      apache-apr/apr/file_io/beos/dir.c
  
  Index: dir.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/dir.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- dir.c	1999/04/23 14:50:33	1.1
  +++ dir.c	1999/05/10 14:36:20	1.2
  @@ -60,9 +60,9 @@
   #include <stdio.h>
   /*#include <sys/stat.h> */
   
  -apr_dir_t *apr_opendir(const char *dirname)
  +ap_dir_t *ap_opendir(const char *dirname)
   {
  -    apr_dir_t *thedir = (apr_dir_t *)malloc(sizeof(apr_dir_t));
  +    ap_dir_t *thedir = (ap_dir_t *)malloc(sizeof(ap_dir_t));
       thedir->dirname = strdup(dirname);
       thedir->dirstruct = opendir(dirname);
   
  @@ -75,7 +75,7 @@
       }
   }
   
  -apr_status_t apr_closedir(apr_dir_t *thedir)
  +ap_status_t ap_closedir(ap_dir_t *thedir)
   {
       if (closedir(thedir->dirstruct) == 0) {
           free(thedir->dirname);
  @@ -88,18 +88,18 @@
       }
   } 
   
  -apr_dirent_t *apr_readdir(apr_dir_t *thedir)
  +ap_dirent_t *ap_readdir(ap_dir_t *thedir)
   {
       return readdir(thedir->dirstruct);
   }
   
  -apr_status_t apr_rewinddir(apr_dir_t *thedir)
  +ap_status_t ap_rewinddir(ap_dir_t *thedir)
   {
       rewinddir(thedir->dirstruct);
       return APR_SUCCESS;
   }
   
  -apr_status_t apr_make_dir(const char *path, apr_fileperms_t mode)
  +ap_status_t ap_make_dir(const char *path, ap_fileperms_t mode)
   {
       if (mkdir(path, mode) == 0) {
           return APR_SUCCESS;
  @@ -109,7 +109,7 @@
       }
   }
   
  -apr_status_t apr_remove_dir(const char *path)
  +ap_status_t ap_remove_dir(const char *path)
   {
       if (rmdir(path) == 0) {
           return APR_SUCCESS;
  
  
  
  1.2       +3 -3      apache-apr/apr/file_io/beos/fileacc.c
  
  Index: fileacc.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/fileacc.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- fileacc.c	1999/04/23 14:50:33	1.1
  +++ fileacc.c	1999/05/10 14:36:20	1.2
  @@ -58,9 +58,9 @@
   #include <errno.h>
   #include <string.h>
   
  -/* A file to put ALL of the accessor functions for apr_file_t types. */
  +/* A file to put ALL of the accessor functions for ap_file_t types. */
   
  -apr_status_t apr_valid_file(apr_file_t *thefile) 
  +ap_status_t ap_valid_file(ap_file_t *thefile) 
   {
       if (thefile != NULL && thefile->filedes > 0) {
           return APR_SUCCESS;
  @@ -70,7 +70,7 @@
       }
   }
   
  -char * apr_get_filename(apr_file_t *thefile)
  +char * ap_get_filename(ap_file_t *thefile)
   {
       if (thefile != NULL) {
           return thefile->fname;
  
  
  
  1.2       +2 -2      apache-apr/apr/file_io/beos/filedup.c
  
  Index: filedup.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/filedup.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- filedup.c	1999/02/26 17:06:44	1.1
  +++ filedup.c	1999/05/10 14:36:20	1.2
  @@ -56,9 +56,9 @@
   #include "apr_file_io.h"
   #include "apr_general.h"
   
  -apr_file_t *apr_dupfile(apr_file_t *old_file)
  +ap_file_t *ap_dupfile(ap_file_t *old_file)
   {
  -    apr_file_t * new_file = (apr_file_t *)malloc(sizeof(apr_file_t));
  +    ap_file_t * new_file = (ap_file_t *)malloc(sizeof(ap_file_t));
       
       if (new_file == NULL) {
           errno = ENOMEM;
  
  
  
  1.2       +2 -2      apache-apr/apr/file_io/beos/filestat.c
  
  Index: filestat.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/filestat.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- filestat.c	1999/02/26 17:06:44	1.1
  +++ filestat.c	1999/05/10 14:36:20	1.2
  @@ -57,7 +57,7 @@
   #include "apr_general.h"
   #include "apr_errno.h"
   
  -apr_status_t apr_getfileinfo(char * fname, apr_file_t *thefile)
  +ap_status_t ap_getfileinfo(char * fname, ap_file_t *thefile)
   {
       struct stat info;
       int rv = stat(fname, &info);
  @@ -78,7 +78,7 @@
       }
   }
   
  -apr_status_t apr_updatefileinfo(apr_file_t *thefile)
  +ap_status_t ap_updatefileinfo(ap_file_t *thefile)
   {
       struct stat info;
       int rv = fstat(thefile->filedes, &info);
  
  
  
  1.3       +5 -5      apache-apr/apr/file_io/beos/open.c
  
  Index: open.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/open.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- open.c	1999/04/23 14:50:33	1.2
  +++ open.c	1999/05/10 14:36:20	1.3
  @@ -65,10 +65,10 @@
   #include <unistd.h>
   #include <stdio.h>
   
  -apr_file_t *apr_open(char *fname, apr_int32_t flag,  apr_fileperms_t mode)
  +ap_file_t *ap_open(char *fname, ap_int32_t flag,  ap_fileperms_t mode)
   {
       int oflags = 0;
  -    apr_file_t *dafile = (apr_file_t *)malloc(sizeof(apr_file_t));
  +    ap_file_t *dafile = (ap_file_t *)malloc(sizeof(ap_file_t));
       struct stat info;
   
       if ((flag & APR_READ) && (flag & APR_WRITE)) {
  @@ -114,7 +114,7 @@
           return NULL;
       }
   
  -    if (apr_updatefileinfo(dafile) == APR_SUCCESS) {
  +    if (ap_updatefileinfo(dafile) == APR_SUCCESS) {
   		return dafile;
       }
       else {
  @@ -125,7 +125,7 @@
       }
   }
   
  -apr_status_t apr_close(apr_file_t * file)
  +ap_status_t ap_close(ap_file_t * file)
   {
       if (close(file->filedes) == 0) {
           file->filedes = -1;
  @@ -139,7 +139,7 @@
       }
   }
   
  -apr_status_t apr_remove_file(char *path) 
  +ap_status_t ap_remove_file(char *path) 
   { 
       if (unlink(path) == 0) { 
           return APR_SUCCESS; 
  
  
  
  1.3       +6 -6      apache-apr/apr/file_io/beos/readwrite.c
  
  Index: readwrite.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/readwrite.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- readwrite.c	1999/04/23 14:50:33	1.2
  +++ readwrite.c	1999/05/10 14:36:21	1.3
  @@ -59,9 +59,9 @@
   #include <errno.h>
   #include <unistd.h>
   
  -apr_ssize_t apr_read(apr_file_t *thefile, void *buf, apr_ssize_t nbytes)
  +ap_ssize_t ap_read(ap_file_t *thefile, void *buf, ap_ssize_t nbytes)
   {
  -    apr_size_t rv;
  +    ap_size_t rv;
   
       if (thefile->filedes < 0) {
           errno = EBADF;
  @@ -73,9 +73,9 @@
       return rv;
   }
   
  -apr_ssize_t apr_write(apr_file_t *thefile, void * buf, apr_ssize_t nbytes)
  +ap_ssize_t ap_write(ap_file_t *thefile, void * buf, ap_ssize_t nbytes)
   {
  -    apr_size_t rv;
  +    ap_size_t rv;
       struct stat info;
   
       if (thefile->filedes < 0) {
  @@ -94,9 +94,9 @@
       return rv;
   }	
   
  -apr_ssize_t apr_writev(apr_file_t *thefile,const apr_iovec_t *vec, apr_ssize_t iocnt)
  +ap_ssize_t ap_writev(ap_file_t *thefile,const ap_iovec_t *vec, ap_ssize_t iocnt)
   {
  -	apr_ssize_t bytes;
  +	ap_ssize_t bytes;
   	if ((bytes = writev(thefile->filedes, vec, iocnt)) < 0){
   		return APR_FAILURE;
   	}
  
  
  
  1.2       +1 -1      apache-apr/apr/file_io/beos/seek.c
  
  Index: seek.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/beos/seek.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- seek.c	1999/04/23 14:50:33	1.1
  +++ seek.c	1999/05/10 14:36:21	1.2
  @@ -57,7 +57,7 @@
   #include <errno.h>
   #include <string.h>
   
  -apr_off_t apr_seek(apr_file_t *thefile, apr_off_t offset, apr_seek_where_t where)
  +ap_off_t ap_seek(ap_file_t *thefile, ap_off_t offset, ap_seek_where_t where)
   {
       return lseek(thefile->filedes, offset, where);
   }
  
  
  
  1.2       +2 -2      apache-apr/apr/file_io/os2/filedup.c
  
  Index: filedup.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/os2/filedup.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- filedup.c	1999/04/09 18:39:14	1.1
  +++ filedup.c	1999/05/10 14:36:22	1.2
  @@ -60,10 +60,10 @@
   #define INCL_DOS
   #include <os2.h>
   
  -apr_file_t *apr_dupfile(apr_file_t *old_file)
  +ap_file_t *ap_dupfile(ap_file_t *old_file)
   {
       int rv;
  -    apr_file_t * new_file = (apr_file_t *)malloc(sizeof(apr_file_t));
  +    ap_file_t * new_file = (ap_file_t *)malloc(sizeof(ap_file_t));
       
       if (new_file == NULL) {
           errno = ENOMEM;
  
  
  
  1.2       +2 -2      apache-apr/apr/file_io/os2/filestat.c
  
  Index: filestat.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/os2/filestat.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- filestat.c	1999/04/09 18:39:15	1.1
  +++ filestat.c	1999/05/10 14:36:22	1.2
  @@ -90,7 +90,7 @@
     return mktime( &tmpdate );
   }
   
  -apr_status_t apr_getfileinfo(char * fname, apr_file_t *thefile)
  +ap_status_t ap_getfileinfo(char * fname, ap_file_t *thefile)
   {
       FILESTATUS3 info;
       int rv = DosQueryPathInfo(fname, FIL_STANDARD, &info, sizeof(info));
  @@ -111,7 +111,7 @@
       }
   }
   
  -apr_status_t apr_updatefileinfo(apr_file_t *thefile)
  +ap_status_t ap_updatefileinfo(ap_file_t *thefile)
   {
       FILESTATUS3 info;
       int rv = DosQueryFileInfo(thefile->filedes, FIL_STANDARD, &info, sizeof(info));
  
  
  
  1.2       +5 -5      apache-apr/apr/file_io/os2/open.c
  
  Index: open.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/os2/open.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- open.c	1999/04/09 18:39:15	1.1
  +++ open.c	1999/05/10 14:36:22	1.2
  @@ -60,12 +60,12 @@
   #define INCL_DOS
   #include <os2.h>
   
  -apr_file_t *apr_open(char *fname, apr_int32_t flag,  apr_fileperms_t mode)
  +ap_file_t *ap_open(char *fname, ap_int32_t flag,  ap_fileperms_t mode)
   {
       int oflags = 0;
       int mflags = OPEN_FLAGS_FAIL_ON_ERROR|OPEN_SHARE_DENYNONE;
       int rv;
  -    apr_file_t *dafile = (apr_file_t *)malloc(sizeof(apr_file_t));
  +    ap_file_t *dafile = (ap_file_t *)malloc(sizeof(ap_file_t));
       struct stat info;
       ULONG action;
   
  @@ -117,7 +117,7 @@
           return NULL;
       }
   
  -    if (apr_updatefileinfo(dafile) == APR_SUCCESS) {
  +    if (ap_updatefileinfo(dafile) == APR_SUCCESS) {
           dafile->fname = strdup(fname);
           return dafile;
       } else {
  @@ -127,7 +127,7 @@
       }
   }
   
  -apr_status_t apr_close(apr_file_t *file)
  +ap_status_t ap_close(ap_file_t *file)
   {
       if (DosClose(file->filedes) == 0) {
           free(file->fname);
  @@ -139,7 +139,7 @@
       }
   }
   
  -apr_status_t apr_remove_file(char *path)
  +ap_status_t ap_remove_file(char *path)
   {
       if (DosDelete(path) == 0) {
           return APR_SUCCESS;
  
  
  
  1.2       +4 -4      apache-apr/apr/file_io/os2/readwrite.c
  
  Index: readwrite.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/os2/readwrite.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- readwrite.c	1999/04/09 18:39:15	1.1
  +++ readwrite.c	1999/05/10 14:36:23	1.2
  @@ -59,9 +59,9 @@
   #include <errno.h>
   #include <unistd.h>
   
  -apr_ssize_t apr_read(apr_file_t *thefile, void *buf, apr_ssize_t nbytes)
  +ap_ssize_t ap_read(ap_file_t *thefile, void *buf, ap_ssize_t nbytes)
   {
  -    apr_size_t rv;
  +    ap_size_t rv;
   
       if (thefile->filedes < 0) {
           errno = EBADF;
  @@ -73,9 +73,9 @@
       return rv;
   }
   
  -apr_ssize_t apr_write(apr_file_t *thefile, void * buf, apr_ssize_t nbytes)
  +ap_ssize_t ap_write(ap_file_t *thefile, void * buf, ap_ssize_t nbytes)
   {
  -    apr_size_t rv;
  +    ap_size_t rv;
       struct stat info;
   
       if (thefile->filedes < 0) {
  
  
  
  1.2       +1 -1      apache-apr/apr/file_io/os2/seek.c
  
  Index: seek.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/os2/seek.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- seek.c	1999/04/09 18:39:15	1.1
  +++ seek.c	1999/05/10 14:36:23	1.2
  @@ -63,7 +63,7 @@
   
   int os2errno( ULONG oserror );
   
  -apr_off_t apr_seek(apr_file_t *file, apr_off_t offset, apr_seek_where_t origin)
  +ap_off_t ap_seek(ap_file_t *file, ap_off_t offset, ap_seek_where_t origin)
   {
       int rv;
       ULONG newpos;
  
  
  
  1.3       +10 -10    apache-apr/apr/file_io/unix/dir.c
  
  Index: dir.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/dir.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- dir.c	1999/04/30 15:19:50	1.2
  +++ dir.c	1999/05/10 14:36:24	1.3
  @@ -58,7 +58,7 @@
   #include <string.h>
   #include <dirent.h>
   
  -apr_status_t dir_cleanup(apr_dir_t *thedir)
  +ap_status_t dir_cleanup(ap_dir_t *thedir)
   {
       if (closedir(thedir->dirstruct) == 0) {
           return APR_SUCCESS;
  @@ -68,9 +68,9 @@
       }
   } 
   
  -apr_dir_t *apr_opendir(apr_context_t *cont, const char *dirname)
  +ap_dir_t *ap_opendir(ap_context_t *cont, const char *dirname)
   {
  -    apr_dir_t *thedir = (apr_dir_t *)apr_palloc(cont->pool, sizeof(apr_dir_t));
  +    ap_dir_t *thedir = (ap_dir_t *)ap_palloc(cont->pool, sizeof(ap_dir_t));
   
       thedir->dirname = strdup(dirname);
       thedir->dirstruct = opendir(dirname);
  @@ -80,32 +80,32 @@
           return NULL;
       }    
       else {
  -        apr_register_cleanup(cont->pool, (void *)thedir, dir_cleanup, NULL);
  +        ap_register_cleanup(cont->pool, (void *)thedir, dir_cleanup, NULL);
           return thedir;
       }
   }
   
  -apr_status_t apr_closedir(apr_context_t *cont, apr_dir_t *thedir)
  +ap_status_t ap_closedir(ap_context_t *cont, ap_dir_t *thedir)
   {
       if (dir_cleanup(thedir) == APR_SUCCESS) {
  -        apr_kill_cleanup(cont->pool, thedir, dir_cleanup);
  +        ap_kill_cleanup(cont->pool, thedir, dir_cleanup);
           return APR_SUCCESS;
       }
       return APR_FAILURE;
   }
   
  -apr_dirent_t *apr_readdir(apr_context_t *cont, apr_dir_t *thedir)
  +ap_dirent_t *ap_readdir(ap_context_t *cont, ap_dir_t *thedir)
   {
       return readdir(thedir->dirstruct);
   }
   
  -apr_status_t apr_rewinddir(apr_context_t *cont, apr_dir_t *thedir)
  +ap_status_t ap_rewinddir(ap_context_t *cont, ap_dir_t *thedir)
   {
       rewinddir(thedir->dirstruct);
       return APR_SUCCESS;
   }
   
  -apr_status_t apr_make_dir(apr_context_t *cont, const char *path, apr_fileperms_t mode)
  +ap_status_t ap_make_dir(ap_context_t *cont, const char *path, ap_fileperms_t mode)
   {
       if (mkdir(path, mode) == 0) {
           return APR_SUCCESS;
  @@ -115,7 +115,7 @@
       }
   }
   
  -apr_status_t apr_remove_dir(apr_context_t *cont, const char *path)
  +ap_status_t ap_remove_dir(ap_context_t *cont, const char *path)
   {
       if (rmdir(path) == 0) {
           return APR_SUCCESS;
  
  
  
  1.4       +2 -2      apache-apr/apr/file_io/unix/fileacc.c
  
  Index: fileacc.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/fileacc.c,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- fileacc.c	1999/04/30 15:19:51	1.3
  +++ fileacc.c	1999/05/10 14:36:24	1.4
  @@ -58,9 +58,9 @@
   #include <errno.h>
   #include <string.h>
   
  -/* A file to put ALL of the accessor functions for apr_file_t types. */
  +/* A file to put ALL of the accessor functions for ap_file_t types. */
   
  -char * apr_get_filename(apr_context_t *cont, apr_file_t *thefile)
  +char * ap_get_filename(ap_context_t *cont, ap_file_t *thefile)
   {
       if (thefile != NULL) {
           return thefile->fname;
  
  
  
  1.7       +3 -3      apache-apr/apr/file_io/unix/filedup.c
  
  Index: filedup.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/filedup.c,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- filedup.c	1999/04/30 15:19:51	1.6
  +++ filedup.c	1999/05/10 14:36:24	1.7
  @@ -57,9 +57,9 @@
   #include "apr_general.h"
   #include "fileio.h"
   
  -apr_file_t *apr_dupfile(apr_context_t *cont, apr_file_t *old_file)
  +ap_file_t *ap_dupfile(ap_context_t *cont, ap_file_t *old_file)
   {
  -    apr_file_t *new_file = (apr_file_t *)apr_palloc(cont->pool, sizeof(apr_file_t));
  +    ap_file_t *new_file = (ap_file_t *)ap_palloc(cont->pool, sizeof(ap_file_t));
       
       if (new_file == NULL) {
           errno = ENOMEM;
  @@ -75,6 +75,6 @@
       old_file->atime = new_file->atime;    
       old_file->mtime = new_file->mtime;
       old_file->ctime = new_file->ctime;
  -    apr_register_cleanup(cont->pool, (void *)new_file, file_cleanup, NULL);
  +    ap_register_cleanup(cont->pool, (void *)new_file, file_cleanup, NULL);
   }
   
  
  
  
  1.4       +1 -1      apache-apr/apr/file_io/unix/fileio.h
  
  Index: fileio.h
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/fileio.h,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- fileio.h	1999/04/30 18:38:50	1.3
  +++ fileio.h	1999/05/10 14:36:24	1.4
  @@ -99,7 +99,7 @@
   typedef struct dirent     dirent_t;
   typedef struct iovec      iovec_t;
   
  -apr_status_t file_cleanup(void *);
  +ap_status_t file_cleanup(void *);
   
   #endif  /* ! FILE_IO_H */
   
  
  
  
  1.3       +2 -2      apache-apr/apr/file_io/unix/filestat.c
  
  Index: filestat.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/filestat.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- filestat.c	1999/04/30 15:19:51	1.2
  +++ filestat.c	1999/05/10 14:36:25	1.3
  @@ -57,7 +57,7 @@
   #include "apr_general.h"
   #include "apr_errno.h"
   
  -apr_status_t apr_getfileinfo(apr_context_t *cont, char * fname, apr_file_t *thefile)
  +ap_status_t ap_getfileinfo(ap_context_t *cont, char * fname, ap_file_t *thefile)
   {
       struct stat info;
       int rv = stat(fname, &info);
  @@ -78,7 +78,7 @@
       }
   }
   
  -apr_status_t apr_updatefileinfo(apr_context_t *cont, apr_file_t *thefile)
  +ap_status_t ap_updatefileinfo(ap_context_t *cont, ap_file_t *thefile)
   {
       struct stat info;
       int rv = fstat(thefile->filedes, &info);
  
  
  
  1.17      +10 -10    apache-apr/apr/file_io/unix/open.c
  
  Index: open.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/open.c,v
  retrieving revision 1.16
  retrieving revision 1.17
  diff -u -r1.16 -r1.17
  --- open.c	1999/05/07 18:19:20	1.16
  +++ open.c	1999/05/10 14:36:25	1.17
  @@ -59,9 +59,9 @@
   #include <errno.h>
   #include <string.h>
   
  -apr_status_t file_cleanup(void *thefile)
  +ap_status_t file_cleanup(void *thefile)
   {
  -    apr_file_t *file = thefile;
  +    ap_file_t *file = thefile;
       if (close(file->filedes) == 0) {
           file->filedes = -1;
           return APR_SUCCESS;
  @@ -72,13 +72,13 @@
       }
   }
   
  -apr_file_t *apr_open(apr_context_t *cont, char *fname, apr_int32_t flag,  apr_fileperms_t mode)
  +ap_file_t *ap_open(ap_context_t *cont, char *fname, ap_int32_t flag,  ap_fileperms_t mode)
   {
       int oflags = 0;
  -    apr_file_t *dafilel;
  +    ap_file_t *dafile;
       struct stat info;
       
  -    dafile = (apr_file_t *)apr_palloc(cont->pool, sizeof(apr_file_t));
  +    dafile = (ap_file_t *)ap_palloc(cont->pool, sizeof(ap_file_t));
   
       if ((flag & APR_READ) && (flag & APR_WRITE)) {
           oflags = O_RDWR;
  @@ -127,8 +127,8 @@
           return NULL;
       }
   
  -    if (apr_updatefileinfo(cont, dafile) == APR_SUCCESS) {
  -	apr_register_cleanup(cont->pool, (void *)dafile, file_cleanup, NULL);
  +    if (ap_updatefileinfo(cont, dafile) == APR_SUCCESS) {
  +	ap_register_cleanup(cont->pool, (void *)dafile, file_cleanup, NULL);
           return dafile;
       }
       else {
  @@ -138,16 +138,16 @@
       }
   }
   
  -apr_status_t apr_close(apr_context_t *cont, apr_file_t *file)
  +ap_status_t ap_close(ap_context_t *cont, ap_file_t *file)
   {
       if (file_cleanup(file) == APR_SUCCESS) {
  -        apr_kill_cleanup(cont->pool, file, file_cleanup);
  +        ap_kill_cleanup(cont->pool, file, file_cleanup);
           return APR_SUCCESS;
       }
       return APR_FAILURE;
   }
   
  -apr_status_t apr_remove_file(apr_context_t *cont, char *path)
  +ap_status_t ap_remove_file(ap_context_t *cont, char *path)
   {
       if (unlink(path) == 0) {
           return APR_SUCCESS;
  
  
  
  1.3       +2 -2      apache-apr/apr/file_io/unix/pipe.c
  
  Index: pipe.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/pipe.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- pipe.c	1999/04/30 15:19:52	1.2
  +++ pipe.c	1999/05/10 14:36:25	1.3
  @@ -61,7 +61,7 @@
   #include <sys/types.h>
   #include <sys/stat.h>
   
  -apr_status_t apr_create_pipe(apr_context_t *cont, apr_file_t *in, apr_file_t *out)
  +ap_status_t ap_create_pipe(ap_context_t *cont, ap_file_t *in, ap_file_t *out)
   {
       int filedes[2];
   
  @@ -78,7 +78,7 @@
       return APR_SUCCESS;
   }
   
  -char *apr_create_namedpipe(apr_context_t *cont, char *dirpath, apr_fileperms_t mode)
  +char *ap_create_namedpipe(ap_context_t *cont, char *dirpath, ap_fileperms_t mode)
   {
       char *tmp;
   
  
  
  
  1.6       +5 -5      apache-apr/apr/file_io/unix/readwrite.c
  
  Index: readwrite.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/readwrite.c,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- readwrite.c	1999/04/30 15:19:52	1.5
  +++ readwrite.c	1999/05/10 14:36:25	1.6
  @@ -59,9 +59,9 @@
   #include <errno.h>
   #include <unistd.h>
   #include <sys/uio.h>
  -apr_ssize_t apr_read(apr_context_t *cont, apr_file_t *thefile, void *buf, apr_ssize_t nbytes)
  +ap_ssize_t ap_read(ap_context_t *cont, ap_file_t *thefile, void *buf, ap_ssize_t nbytes)
   {
  -    apr_size_t rv;
  +    ap_size_t rv;
   
       if (thefile->filedes < 0) {
           errno = EBADF;
  @@ -73,9 +73,9 @@
       return rv;
   }
   
  -apr_ssize_t apr_write(apr_context_t *cont, apr_file_t *thefile, void *buf, apr_ssize_t nbytes)
  +ap_ssize_t ap_write(ap_context_t *cont, ap_file_t *thefile, void *buf, ap_ssize_t nbytes)
   {
  -    apr_size_t rv;
  +    ap_size_t rv;
       struct stat info;
   
       if (thefile->filedes < 0) {
  @@ -94,7 +94,7 @@
       return rv;
   }
   
  -apr_ssize_t apr_writev(apr_context_t *cont, apr_file_t *thefile, const apr_iovec_t * vec, apr_ssize_t iocnt)
  +ap_ssize_t ap_writev(ap_context_t *cont, ap_file_t *thefile, const ap_iovec_t * vec, ap_ssize_t iocnt)
   {
       int bytes;
       if ((bytes = writev(thefile->filedes, vec, iocnt)) < 0) {
  
  
  
  1.3       +1 -1      apache-apr/apr/file_io/unix/seek.c
  
  Index: seek.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/file_io/unix/seek.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- seek.c	1999/04/30 15:19:52	1.2
  +++ seek.c	1999/05/10 14:36:25	1.3
  @@ -57,7 +57,7 @@
   #include <errno.h>
   #include <string.h>
   
  -apr_off_t apr_seek(apr_context_t *cont, apr_file_t *thefile, apr_off_t offset, apr_seek_where_t where)
  +ap_off_t ap_seek(ap_context_t *cont, ap_file_t *thefile, ap_off_t offset, ap_seek_where_t where)
   {
       return lseek(thefile->filedes, offset, where);
   }
  
  
  
  1.2       +14 -14    apache-apr/apr/misc/unix/start.c
  
  Index: start.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/misc/unix/start.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- start.c	1999/04/29 20:20:33	1.1
  +++ start.c	1999/05/10 14:36:27	1.2
  @@ -59,18 +59,18 @@
   #include <errno.h>
   #include <string.h>
   
  -apr_context_t *apr_initialize(void *data)
  +ap_context_t *ap_initialize(void *data)
   {
  -    apr_context_t *new;
  -    apr_pool_t *pool;
  +    ap_context_t *new;
  +    ap_pool_t *pool;
   
  -    pool = apr_init_alloc();
  +    pool = ap_init_alloc();
   
       if (pool == NULL) {
           errno = ENOPOOL;
           return NULL;
       }    
  -    new = (apr_context_t *)apr_palloc(pool, sizeof(apr_context_t));
  +    new = (ap_context_t *)ap_palloc(pool, sizeof(ap_context_t));
       new->pool = pool;
       new->prog_data = data;
       new->signal_safe = 0;
  @@ -79,29 +79,29 @@
       return new;
   }
   
  -apr_status_t apr_set_signal_safe(apr_context_t *cont, apr_int16_t safe)
  +ap_status_t ap_set_signal_safe(ap_context_t *cont, ap_int16_t safe)
   {
       cont->signal_safe = safe;
       return APR_SUCCESS;
   }
   
  -apr_status_t apr_set_cancel_safe(apr_context_t *cont, apr_int16_t safe)
  +ap_status_t ap_set_cancel_safe(ap_context_t *cont, ap_int16_t safe)
   {
       cont->cancel_safe = safe;
       return APR_SUCCESS;
   }
   
  -apr_context_t *apr_create_sub_context(apr_context_t *cont, void *data)
  +ap_context_t *ap_create_sub_context(ap_context_t *cont, void *data)
   {
  -    apr_context_t *new;
  -    apr_pool_t *pool;
  +    ap_context_t *new;
  +    ap_pool_t *pool;
   
  -    pool = apr_make_sub_pool(cont->pool);
  +    pool = ap_make_sub_pool(cont->pool);
       if (pool == NULL) {
           errno = ENOPOOL;
           return NULL;
       }    
  -    new = (apr_context_t *)apr_palloc(pool, sizeof(apr_context_t));
  +    new = (ap_context_t *)ap_palloc(pool, sizeof(ap_context_t));
       new->pool = pool;
       if (data == NULL) {
           cont->prog_data = cont->prog_data;
  @@ -115,9 +115,9 @@
       return new;
   }
   
  -apr_status_t apr_destroy_context(apr_context_t *cont)
  +ap_status_t ap_destroy_context(ap_context_t *cont)
   {
  -    apr_destroy_pool(cont->pool);
  +    ap_destroy_pool(cont->pool);
       return APR_SUCCESS;
   }
   
  
  
  
  1.2       +5 -5      apache-apr/apr/network_io/beos/select.c
  
  Index: select.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/beos/select.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- select.c	1999/04/23 15:19:34	1.1
  +++ select.c	1999/05/10 14:36:28	1.2
  @@ -60,29 +60,29 @@
   #include "apr_network_io.h"
   #include "apr_general.h"
   
  -void apr_sd_set(apr_socket_t *sock, apr_sd_set_t *sd_set)
  +void ap_sd_set(ap_socket_t *sock, ap_sd_set_t *sd_set)
   {
       FD_SET(sock->socketdes, sd_set);
   }
   
  -void apr_sd_clr(apr_socket_t *sock, apr_sd_set_t *sd_set)
  +void ap_sd_clr(ap_socket_t *sock, ap_sd_set_t *sd_set)
   {
       FD_CLR(sock->socketdes, sd_set);
   }
   
  -apr_status_t apr_sd_isset(apr_socket_t *sock, apr_sd_set_t *sd_set)
  +ap_status_t ap_sd_isset(ap_socket_t *sock, ap_sd_set_t *sd_set)
   {
       if (FD_ISSET(sock->socketdes, sd_set))
           return APR_SUCCESS;
       return APR_FAILURE;
   }
   
  -void apr_sd_zero(apr_sd_set_t *sd_set)
  +void ap_sd_zero(ap_sd_set_t *sd_set)
   {
       FD_ZERO(sd_set);
   }
   
  -apr_int32_t apr_select(apr_int32_t nsd, apr_sd_set_t *readset, apr_sd_set_t *writeset, apr_sd_set_t *exceptset, struct timeval *timeout)
  +ap_int32_t ap_select(ap_int32_t nsd, ap_sd_set_t *readset, ap_sd_set_t *writeset, ap_sd_set_t *exceptset, struct timeval *timeout)
   {
       return select(nsd, readset, NULL, NULL, timeout);
   } 
  
  
  
  1.2       +8 -8      apache-apr/apr/network_io/beos/sendrecv.c
  
  Index: sendrecv.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/beos/sendrecv.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- sendrecv.c	1999/04/23 15:19:35	1.1
  +++ sendrecv.c	1999/05/10 14:36:28	1.2
  @@ -62,9 +62,9 @@
   #include "apr_general.h"
   #include "apr_network_io.h"
   
  -apr_ssize_t apr_send(apr_socket_t *sock, const char *buf, int len, time_t sec)
  +ap_ssize_t ap_send(ap_socket_t *sock, const char *buf, int len, time_t sec)
   {
  -    apr_ssize_t rv;
  +    ap_ssize_t rv;
   
       do {
           rv = send(sock->socketdes, buf, len,0);
  @@ -85,7 +85,7 @@
           } while (srv == -1 && errno == EINTR);
   
           if (srv < 1) {
  -            return (apr_ssize_t) -1;
  +            return (ap_ssize_t) -1;
           }
           else {
               do {
  @@ -93,12 +93,12 @@
               } while (rv == -1 && errno == EINTR);
           }
       }
  -    return (apr_ssize_t) rv;
  +    return (ap_ssize_t) rv;
   }
   
  -apr_ssize_t apr_recv(apr_socket_t *sock, char *buf, int len, time_t sec)
  +ap_ssize_t ap_recv(ap_socket_t *sock, char *buf, int len, time_t sec)
   {
  -    apr_ssize_t rv;
  +    ap_ssize_t rv;
       do {
           rv = recv(sock->socketdes, buf, len,0);
       } while (rv == -1 && errno == EINTR);
  @@ -118,7 +118,7 @@
           } while (srv == -1 && errno == EINTR);
   
           if (srv < 1) {
  -            return (apr_ssize_t) -1;
  +            return (ap_ssize_t) -1;
           }
           else {
               do {
  @@ -126,6 +126,6 @@
               } while (rv == -1 && errno == EINTR);
           }
       }
  -    return (apr_ssize_t) rv;
  +    return (ap_ssize_t) rv;
   }
   
  
  
  
  1.2       +10 -10    apache-apr/apr/network_io/beos/sockets.c
  
  Index: sockets.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/beos/sockets.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- sockets.c	1999/04/23 15:19:35	1.1
  +++ sockets.c	1999/05/10 14:36:28	1.2
  @@ -61,9 +61,9 @@
   #include "apr_general.h"
   #include <stdio.h>
   
  -apr_socket_t *apr_create_tcp_socket(void)
  +ap_socket_t *ap_create_tcp_socket(void)
   {
  -    apr_socket_t *thesocket = (apr_socket_t *)malloc(sizeof(apr_socket_t));
  +    ap_socket_t *thesocket = (ap_socket_t *)malloc(sizeof(ap_socket_t));
       
       thesocket->socketdes = socket(AF_INET ,SOCK_STREAM, 0);
   	thesocket->remote_hostname=NULL;
  @@ -82,7 +82,7 @@
       }
   } 
   
  -apr_status_t apr_shutdown(apr_socket_t *thesocket, apr_shutdown_how_e how)
  +ap_status_t ap_shutdown(ap_socket_t *thesocket, ap_shutdown_how_e how)
   {
       if (shutdown(thesocket->socketdes, how) == 0) {
           return APR_SUCCESS;
  @@ -92,7 +92,7 @@
       }
   }
   
  -apr_status_t apr_close_socket(apr_socket_t *thesocket)
  +ap_status_t ap_close_socket(ap_socket_t *thesocket)
   {
       if (closesocket(thesocket->socketdes) == 0) {
           free(thesocket->addr);
  @@ -105,13 +105,13 @@
       }
   }
   
  -apr_status_t apr_setport(apr_socket_t *sock, apr_uint32_t port) 
  +ap_status_t ap_setport(ap_socket_t *sock, ap_uint32_t port) 
   { 
       sock->addr->sin_port = htons((short)port); 
       return APR_SUCCESS; 
   } 
   
  -apr_status_t apr_bind(apr_socket_t *sock) 
  +ap_status_t ap_bind(ap_socket_t *sock) 
   { 
       sock->addr->sin_addr.s_addr = INADDR_ANY;
       if (bind(sock->socketdes, (struct sockaddr *)sock->addr, sock->addr_len) == -1) 
  @@ -120,7 +120,7 @@
           return APR_SUCCESS; 
   } 
    
  -apr_status_t apr_listen(apr_socket_t *sock, apr_int32_t backlog) 
  +ap_status_t ap_listen(ap_socket_t *sock, ap_int32_t backlog) 
   { 
       if (listen(sock->socketdes, backlog) == -1) 
           return APR_FAILURE; 
  @@ -128,9 +128,9 @@
           return APR_SUCCESS; 
   } 
   
  -apr_socket_t *apr_accept(const apr_socket_t *sock) 
  +ap_socket_t *ap_accept(const ap_socket_t *sock) 
   { 
  -    apr_socket_t *new = (apr_socket_t *)malloc(sizeof(apr_socket_t)); 
  +    ap_socket_t *new = (ap_socket_t *)malloc(sizeof(ap_socket_t)); 
   	struct hostent *hptr;
   	
   	 
  @@ -147,7 +147,7 @@
       return NULL; 
   } 
    
  -apr_status_t apr_connect(apr_socket_t *sock, char *hostname, unsigned short port) 
  +ap_status_t ap_connect(ap_socket_t *sock, char *hostname, unsigned short port) 
   { 
       struct hostent *hp; 
   
  
  
  
  1.2       +3 -3      apache-apr/apr/network_io/beos/sockopt.c
  
  Index: sockopt.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/beos/sockopt.c,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- sockopt.c	1999/04/23 15:19:35	1.1
  +++ sockopt.c	1999/05/10 14:36:28	1.2
  @@ -101,7 +101,7 @@
   }
   
   
  -apr_status_t apr_setsocketopt(apr_socket_t *sock, apr_int32_t opt, apr_int32_t on)
  +ap_status_t ap_setsocketopt(ap_socket_t *sock, ap_int32_t opt, ap_int32_t on)
   {
       int one;
   	char *set;
  @@ -134,7 +134,7 @@
       return APR_SUCCESS;
   }         
   
  -apr_status_t apr_gethostname(char * buf, int len)
  +ap_status_t ap_gethostname(char * buf, int len)
   {
   	if (gethostname(buf, len) == -1){
   		return APR_FAILURE;
  @@ -143,7 +143,7 @@
   	}
   }
   
  -char *apr_get_remote_hostname(apr_socket_t *sock)
  +char *ap_get_remote_hostname(ap_socket_t *sock)
   {
   	return sock->remote_hostname;
   }
  
  
  
  1.7       +2 -2      apache-apr/apr/network_io/unix/networkio.h
  
  Index: networkio.h
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/unix/networkio.h,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- networkio.h	1999/04/28 16:00:06	1.6
  +++ networkio.h	1999/05/10 14:36:30	1.7
  @@ -76,8 +76,8 @@
   
   struct pollfd_t {
       struct socket_t *sock;
  -    apr_int16_t events;
  -    apr_int16_t revents;
  +    ap_int16_t events;
  +    ap_int16_t revents;
   };
   
   #endif  /* ! NETWORK_IO_H */
  
  
  
  1.3       +2 -2      apache-apr/apr/network_io/unix/poll.c
  
  Index: poll.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/unix/poll.c,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- poll.c	1999/04/30 18:38:52	1.2
  +++ poll.c	1999/05/10 14:36:30	1.3
  @@ -59,13 +59,13 @@
   #include <errno.h>
   #include <sys/poll.h>
   
  -apr_int32_t apr_poll(apr_context_t *cont, apr_pollfd_t *aprset, apr_int32_t nsds, apr_int32_t timeout)
  +ap_int32_t ap_poll(ap_context_t *cont, ap_pollfd_t *aprset, ap_int32_t nsds, ap_int32_t timeout)
   {
       int i;
       struct pollfd *pollset;
       int rv;
   
  -    pollset = (struct pollfd *)apr_palloc(cont->pool, sizeof(struct pollfd) * nsds);
  +    pollset = (struct pollfd *)ap_palloc(cont->pool, sizeof(struct pollfd) * nsds);
   
       for (i = 0; i < nsds; i++) {
           pollset[i].fd = aprset[i].sock->socketdes;
  
  
  
  1.6       +6 -6      apache-apr/apr/network_io/unix/sendrecv.c
  
  Index: sendrecv.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/unix/sendrecv.c,v
  retrieving revision 1.5
  retrieving revision 1.6
  diff -u -r1.5 -r1.6
  --- sendrecv.c	1999/04/30 18:38:52	1.5
  +++ sendrecv.c	1999/05/10 14:36:30	1.6
  @@ -60,7 +60,7 @@
   #include "apr_network_io.h"
   #include <sys/time.h>
   
  -apr_ssize_t apr_send(apr_context_t *cont, apr_socket_t *sock, const char *buf, int len, time_t sec)
  +ap_ssize_t ap_send(ap_context_t *cont, ap_socket_t *sock, const char *buf, int len, time_t sec)
   {
       ssize_t rv;
       
  @@ -83,7 +83,7 @@
           } while (srv == -1 && errno == EINTR);
   
           if (srv < 1) {
  -            return (apr_ssize_t) -1;
  +            return (ap_ssize_t) -1;
           }
           else {
               do {
  @@ -91,10 +91,10 @@
               } while (rv == -1 && errno == EINTR);
           }
       }
  -    return (apr_ssize_t) rv;
  +    return (ap_ssize_t) rv;
   }
   
  -apr_ssize_t apr_recv(apr_context_t *cont, apr_socket_t *sock, char *buf, int len, time_t sec)
  +ap_ssize_t ap_recv(ap_context_t *cont, ap_socket_t *sock, char *buf, int len, time_t sec)
   {
       ssize_t rv;
       
  @@ -117,7 +117,7 @@
           } while (srv == -1 && errno == EINTR);
   
           if (srv < 1) {
  -            return (apr_ssize_t) -1;
  +            return (ap_ssize_t) -1;
           }
           else {
               do {
  @@ -125,6 +125,6 @@
               } while (rv == -1 && errno == EINTR);
           }
       }
  -    return (apr_ssize_t) rv;
  +    return (ap_ssize_t) rv;
   }
   
  
  
  
  1.13      +17 -17    apache-apr/apr/network_io/unix/sockets.c
  
  Index: sockets.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/unix/sockets.c,v
  retrieving revision 1.12
  retrieving revision 1.13
  diff -u -r1.12 -r1.13
  --- sockets.c	1999/04/30 18:38:52	1.12
  +++ sockets.c	1999/05/10 14:36:30	1.13
  @@ -63,9 +63,9 @@
   #include <netinet/in.h>
   #include <netdb.h>
   
  -apr_status_t socket_cleanup(void *sock)
  +ap_status_t socket_cleanup(void *sock)
   {
  -    apr_socket_t *thesocket = sock;
  +    ap_socket_t *thesocket = sock;
       if (close(thesocket->socketdes) == 0) {
           thesocket->socketdes = -1;
           return APR_SUCCESS;
  @@ -75,14 +75,14 @@
       }
   }
   
  -apr_socket_t *apr_create_tcp_socket(apr_context_t *cont)
  +ap_socket_t *ap_create_tcp_socket(ap_context_t *cont)
   {
  -    apr_socket_t *thesocket = (apr_socket_t *)apr_palloc(cont->pool, sizeof(apr_socket_t));
  +    ap_socket_t *thesocket = (ap_socket_t *)ap_palloc(cont->pool, sizeof(ap_socket_t));
       
       thesocket->socketdes = socket(AF_INET ,SOCK_STREAM, IPPROTO_TCP);
       thesocket->remote_hostname = NULL;
   
  -    thesocket->addr = (struct sockaddr_in *)apr_palloc(cont->pool, sizeof(struct sockaddr_in));
  +    thesocket->addr = (struct sockaddr_in *)ap_palloc(cont->pool, sizeof(struct sockaddr_in));
       thesocket->addr->sin_family = AF_INET;
   
       thesocket->addr_len = sizeof(*thesocket->addr);
  @@ -91,12 +91,12 @@
           return NULL;
       }
       else {
  -        apr_register_cleanup(cont->pool, (void *)thesocket, socket_cleanup, NULL);
  +        ap_register_cleanup(cont->pool, (void *)thesocket, socket_cleanup, NULL);
           return thesocket;
       }
   } 
   
  -apr_status_t apr_shutdown(apr_context_t *cont, apr_socket_t *thesocket, apr_shutdown_how_e how)
  +ap_status_t ap_shutdown(ap_context_t *cont, ap_socket_t *thesocket, ap_shutdown_how_e how)
   {
       if (shutdown(thesocket->socketdes, how) == 0) {
           return APR_SUCCESS;
  @@ -106,19 +106,19 @@
       }
   }
   
  -apr_status_t apr_close_socket(apr_context_t *cont, apr_socket_t *thesocket)
  +ap_status_t ap_close_socket(ap_context_t *cont, ap_socket_t *thesocket)
   {
       socket_cleanup(thesocket);
  -    apr_kill_cleanup(cont->pool, thesocket, socket_cleanup);
  +    ap_kill_cleanup(cont->pool, thesocket, socket_cleanup);
   }
   
  -apr_status_t apr_setport(apr_context_t *cont, apr_socket_t *sock, apr_uint32_t port)
  +ap_status_t ap_setport(ap_context_t *cont, ap_socket_t *sock, ap_uint32_t port)
   {
       sock->addr->sin_port = htons((short)port);
       return APR_SUCCESS;
   }
   
  -apr_status_t apr_bind(apr_context_t *cont, apr_socket_t *sock)
  +ap_status_t ap_bind(ap_context_t *cont, ap_socket_t *sock)
   {
       sock->addr->sin_addr.s_addr = INADDR_ANY;
       if (bind(sock->socketdes, (struct sockaddr *)sock->addr, sock->addr_len) == -1)
  @@ -127,7 +127,7 @@
           return APR_SUCCESS;
   }
   
  -apr_status_t apr_listen(apr_context_t *cont, apr_socket_t *sock, apr_int32_t backlog)
  +ap_status_t ap_listen(ap_context_t *cont, ap_socket_t *sock, ap_int32_t backlog)
   {
       if (listen(sock->socketdes, backlog) == -1)
           return APR_FAILURE;
  @@ -135,12 +135,12 @@
           return APR_SUCCESS;
   }
   
  -apr_socket_t *apr_accept(apr_context_t *cont, const apr_socket_t *sock)
  +ap_socket_t *ap_accept(ap_context_t *cont, const ap_socket_t *sock)
   {
  -    apr_socket_t *new = (apr_socket_t *)apr_palloc(cont->pool, sizeof(apr_socket_t));
  +    ap_socket_t *new = (ap_socket_t *)ap_palloc(cont->pool, sizeof(ap_socket_t));
       struct hostent *hptr;
   
  -    new->addr = (struct sockaddr_in *)apr_palloc(cont->pool, sizeof(struct sockaddr_in));
  +    new->addr = (struct sockaddr_in *)ap_palloc(cont->pool, sizeof(struct sockaddr_in));
       new->addr_len = sizeof(struct sockaddr_in);
   
       new->socketdes = accept(sock->socketdes, (struct sockaddr *)new->addr, &new->addr_len);
  @@ -154,11 +154,11 @@
           new->remote_hostname = strdup(hptr->h_name);
       }
       
  -    apr_register_cleanup(cont->pool, (void *)new, socket_cleanup, NULL);
  +    ap_register_cleanup(cont->pool, (void *)new, socket_cleanup, NULL);
       return new;
   }
   
  -apr_status_t apr_connect(apr_context_t *cont, apr_socket_t *sock, char *hostname)
  +ap_status_t ap_connect(ap_context_t *cont, ap_socket_t *sock, char *hostname)
   {
       struct hostent *hp;
   
  
  
  
  1.4       +3 -3      apache-apr/apr/network_io/unix/sockopt.c
  
  Index: sockopt.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/network_io/unix/sockopt.c,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- sockopt.c	1999/04/30 18:38:52	1.3
  +++ sockopt.c	1999/05/10 14:36:31	1.4
  @@ -100,7 +100,7 @@
   }
   
   
  -apr_status_t apr_setsocketopt(apr_context_t *cont, apr_socket_t *sock, apr_int32_t opt, apr_int32_t on)
  +ap_status_t ap_setsocketopt(ap_context_t *cont, ap_socket_t *sock, ap_int32_t opt, ap_int32_t on)
   {
       int one;
       struct linger li;
  @@ -145,7 +145,7 @@
       return APR_SUCCESS;
   }         
   
  -apr_status_t apr_gethostname(apr_context_t *cont, char *buf, int len)
  +ap_status_t ap_gethostname(ap_context_t *cont, char *buf, int len)
   {
       if (gethostname(buf, len) == -1)
           return APR_FAILURE;
  @@ -153,7 +153,7 @@
           return APR_SUCCESS;
   }
   
  -char *apr_get_remote_hostname(apr_context_t *cont, apr_socket_t *sock)
  +char *ap_get_remote_hostname(ap_context_t *cont, ap_socket_t *sock)
   {
       return sock->remote_hostname;
   }
  
  
  
  1.10      +1 -1      apache-apr/apr/test/Makefile
  
  Index: Makefile
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/Makefile,v
  retrieving revision 1.9
  retrieving revision 1.10
  diff -u -r1.9 -r1.10
  --- Makefile	1999/04/30 18:38:53	1.9
  +++ Makefile	1999/05/10 14:36:32	1.10
  @@ -12,7 +12,7 @@
   SRCDIR=..
   EXTRA_CFLAGS=-g 
   EXTRA_LDFLAGS=
  -EXTRA_LIBS=-L../misc -laprmisc -L../lib -lapr -L../threadproc -lthreadproc -L../file_io -lfile -L../network_io -lnetwork 
  +EXTRA_LIBS=-L../threadproc -lthreadproc -L../network_io -lnetwork -L../file_io -lfile -L../misc -laprmisc -L../lib -lapr 
   EXTRA_INCLUDES=
   EXTRA_DEPS=
   OSDIR=
  
  
  
  1.5       +30 -30    apache-apr/apr/test/ab_apr.c
  
  Index: ab_apr.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/ab_apr.c,v
  retrieving revision 1.4
  retrieving revision 1.5
  diff -u -r1.4 -r1.5
  --- ab_apr.c	1999/04/26 13:07:49	1.4
  +++ ab_apr.c	1999/05/10 14:36:32	1.5
  @@ -120,7 +120,7 @@
   
   /*#define ap_select       select*/
   /*#else  (!)NO_APACHE_INCLUDES */
  -/*#include "ap_config.h"*/
  +/*#include "apr_config.h"*/
   /*#include <fcntl.h>*/
   /*#include <sys/time.h>*/
   /*#endif  NO_APACHE_INCLUDES */
  @@ -137,7 +137,7 @@
   #define CBUFFSIZE       512
   
   struct connection {
  -	apr_socket_t * aprsock;
  +	ap_socket_t * aprsock;
       int state;
       int read;			/* amount of bytes read */
       int bread;			/* amount of body read */
  @@ -197,7 +197,7 @@
   
   /* global request (and its length) */
   char request[512];
  -apr_ssize_t reqlen;
  +ap_ssize_t reqlen;
   
   /* one global throw-away buffer to read stuff into */
   char buffer[8192];
  @@ -205,7 +205,7 @@
   struct connection *con;		/* connection array */
   struct data *stats;		/* date for each request */
   
  -apr_sd_set_t readbits, writebits;
  +ap_sd_set_t readbits, writebits;
   
   /* --------------------------------------------------------- */
   
  @@ -230,27 +230,27 @@
   static void write_request(struct connection *c)
   {
       gettimeofday(&c->connect, 0);
  -	if (apr_send(c->aprsock, request, reqlen, 30) != reqlen){
  +	if (ap_send(c->aprsock, request, reqlen, 30) != reqlen){
   		printf ("Send request failed!\n");
   	}
       if (posting) {
  -	apr_send(c->aprsock, postdata, postlen, 30);
  +	ap_send(c->aprsock, postdata, postlen, 30);
   	totalposted += (reqlen + postlen);
       }
   
       c->state = STATE_READ;
  -    apr_sd_set(c->aprsock, &readbits);
  -    apr_sd_clr(c->aprsock, &writebits);
  +    ap_sd_set(c->aprsock, &readbits);
  +    ap_sd_clr(c->aprsock, &writebits);
   }
   
   /* --------------------------------------------------------- */
   
   /* make an fd non blocking */
   
  -static void nonblock(apr_socket_t * sock)
  +static void nonblock(ap_socket_t * sock)
   {
       int i = 1;
  -    /*apr_setsocketopt(sock, APR_SO_NONBLOCK, i);*/
  +    /*ap_setsocketopt(sock, APR_SO_NONBLOCK, i);*/
   }
   
   /* --------------------------------------------------------- */
  @@ -477,21 +477,21 @@
       c->cbx = 0;
       c->gotheader = 0;
   
  -    if ((c->aprsock = apr_create_tcp_socket()) ==NULL)
  +    if ((c->aprsock = ap_create_tcp_socket()) ==NULL)
           err("Socket:");
       nonblock(c->aprsock);
       gettimeofday(&c->start, 0);
  -	if (apr_connect(c->aprsock, hostname, port) == APR_FAILURE){
  +	if (ap_connect(c->aprsock, hostname, port) == APR_FAILURE){
   	printf ("Connect failed.\n");
   	if (errno == EINPROGRESS) {
   		printf ("Error - EINPROGRESS\n");
   	    c->state = STATE_CONNECTING;
  -	    apr_sd_set(c->aprsock, &writebits);
  +	    ap_sd_set(c->aprsock, &writebits);
   	    return;
   	}
   	else {
   	    /*we don't have to close the socket.  If we have an error this bad,
  -            apr_connect will destroy it for us.  */
  +            ap_connect will destroy it for us.  */
               err_conn++;
   	    if (bad++ > 10) {
   		err("\nTest aborted after 10 failures\n\n");
  @@ -536,9 +536,9 @@
   	}
       }
   
  -    apr_sd_clr(c->aprsock, &readbits);
  -    apr_sd_clr(c->aprsock, &writebits);
  -    apr_close_socket(c->aprsock);
  +    ap_sd_clr(c->aprsock, &readbits);
  +    ap_sd_clr(c->aprsock, &writebits);
  +    ap_close_socket(c->aprsock);
   
       /* connect again */
       start_connect(c);
  @@ -551,11 +551,11 @@
   
   static void read_connection(struct connection *c)
   {
  -    apr_ssize_t r;
  +    ap_ssize_t r;
       char *part;
       char respcode[4];		/* 3 digits and null */
   
  -	r = apr_recv(c->aprsock, buffer, sizeof(buffer),aprtimeout);
  +	r = ap_recv(c->aprsock, buffer, sizeof(buffer),aprtimeout);
       if (r == 0 || (r < 0 && errno != EAGAIN)) {
   	good++;
   	close_connection(c);
  @@ -598,11 +598,11 @@
   		return;
   	    else {
   		/* header is in invalid or too big - close connection */
  -		apr_close_socket(c->aprsock);
  +		ap_close_socket(c->aprsock);
   		if (bad++ > 10) {
   		    err("\nTest aborted after 10 failures\n\n");
   		}
  -		apr_sd_clr(c->aprsock, &writebits);
  +		ap_sd_clr(c->aprsock, &writebits);
   		start_connect(c);
   	    }
   	}
  @@ -702,7 +702,7 @@
   static void test(void)
   {
       struct timeval timeout, now;
  -	apr_sd_set_t sel_read, sel_except, sel_write;
  +	ap_sd_set_t sel_read, sel_except, sel_write;
   	
       int i;
   
  @@ -715,8 +715,8 @@
       memset(con, 0, concurrency * sizeof(struct connection));
   
       stats = malloc(requests * sizeof(struct data));
  -    apr_sd_zero(&readbits);
  -    apr_sd_zero(&writebits);
  +    ap_sd_zero(&readbits);
  +    ap_sd_zero(&writebits);
   
       /* setup request */
       if (!posting) {
  @@ -764,7 +764,7 @@
   	start_connect(&con[i]);
   
       while (done < requests) {
  -	apr_int32_t n;
  +	ap_int32_t n;
   	/* setup bit arrays */
   	memcpy(&sel_except, &readbits, sizeof(readbits));
   	memcpy(&sel_read, &readbits, sizeof(readbits));
  @@ -779,7 +779,7 @@
   	timeout.tv_sec = 30;
   	timeout.tv_usec = 0;
   
  -	n = apr_select(FD_SETSIZE, &sel_read, &sel_write, &sel_except, &timeout);
  +	n = ap_select(FD_SETSIZE, &sel_read, &sel_write, &sel_except, &timeout);
   
   	if (!n) {
   	    err("\nServer timed out\n\n");
  @@ -788,16 +788,16 @@
   	    err("select");
   
   	for (i = 0; i < concurrency; i++) {
  -	    apr_socket_t *s = con[i].aprsock;
  -	    if (apr_sd_isset(s,&sel_except) == APR_SUCCESS){
  +	    ap_socket_t *s = con[i].aprsock;
  +	    if (ap_sd_isset(s,&sel_except) == APR_SUCCESS){
   		bad++;
   		err_except++;
   		start_connect(&con[i]);
   		continue;
   	    }
  -	    if (apr_sd_isset(s,&sel_read) == APR_SUCCESS)
  +	    if (ap_sd_isset(s,&sel_read) == APR_SUCCESS)
   		read_connection(&con[i]);
  -	    if (apr_sd_isset(s, &sel_write) == APR_SUCCESS)
  +	    if (ap_sd_isset(s, &sel_write) == APR_SUCCESS)
   		write_request(&con[i]);
   	}
       }
  
  
  
  1.4       +19 -19    apache-apr/apr/test/client.c
  
  Index: client.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/client.c,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- client.c	1999/04/30 18:38:54	1.3
  +++ client.c	1999/05/10 14:36:33	1.4
  @@ -66,77 +66,77 @@
   
   int main(int argc, char *argv[])
   {
  -    apr_context_t *context;
  -    apr_socket_t *sock;
  -    apr_int32_t rv;
  +    ap_context_t *context;
  +    ap_socket_t *sock;
  +    ap_int32_t rv;
       struct timeval timeout;
       char datasend[STRLEN] = "Send data test";
       char datarecv[STRLEN];
   
  -    context = apr_initialize(NULL);
  +    context = ap_initialize(NULL);
   
       fprintf(stdout, "\tClient:  Creating new socket.......");
  -    if ((sock = apr_create_tcp_socket(context)) == NULL) {
  +    if ((sock = ap_create_tcp_socket(context)) == NULL) {
           fprintf(stderr, "Couldn't create socket\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tClient:  Setting socket option NONBLOCK.......");
  -    if (apr_setsocketopt(context, sock, APR_SO_NONBLOCK, 1) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_setsocketopt(context, sock, APR_SO_NONBLOCK, 1) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Couldn't set socket option\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tClient:  Setting port for socket.......");
  -    if (apr_setport(context, sock, 8021) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_setport(context, sock, 8021) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Couldn't set the port correctly\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");           
   
       fprintf(stdout, "\tClient:  Connecting to socket.......");
  -    if (apr_connect(context, sock, "localhost") == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_connect(context, sock, "localhost") == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Could not connect\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tClient:  Trying to send data over socket.......");
  -    if (apr_send(context, sock, datasend, STRLEN, 5) != STRLEN) {
  -        apr_close_socket(context, sock);
  +    if (ap_send(context, sock, datasend, STRLEN, 5) != STRLEN) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Problem sending data\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
       
       fprintf(stdout, "\tClient:  Trying to receive data over socket.......");
  -    if (apr_recv(context, sock, datarecv, STRLEN, 5) != STRLEN) {
  -        apr_close_socket(context, sock);
  +    if (ap_recv(context, sock, datarecv, STRLEN, 5) != STRLEN) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Problem receiving data\n");
           exit(-1);
       }
       if (strcmp(datarecv, "Recv data test")) {
  -        apr_close_socket(context, sock);
  +        ap_close_socket(context, sock);
           fprintf(stderr, "I did not receive the correct data %s\n", datarecv);
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tClient:  Shutting down socket.......");
  -    if (apr_shutdown(context, sock, APR_SHUTDOWN_WRITE) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_shutdown(context, sock, APR_SHUTDOWN_WRITE) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Could not shutdown socket\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tClient:  Closing down socket.......");
  -    if (apr_close_socket(context, sock) == APR_FAILURE) {
  +    if (ap_close_socket(context, sock) == APR_FAILURE) {
           fprintf(stderr, "Could not shutdown socket\n");
           exit(-1);
       }
  
  
  
  1.4       +34 -34    apache-apr/apr/test/server.c
  
  Index: server.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/server.c,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- server.c	1999/04/30 18:38:54	1.3
  +++ server.c	1999/05/10 14:36:33	1.4
  @@ -66,50 +66,50 @@
   
   int main(int argc, char *argv[])
   {
  -    apr_context_t *context;
  -    apr_socket_t *sock;
  -    apr_socket_t *sock2;
  -    apr_int32_t rv;
  -    apr_pollfd_t sdset;
  +    ap_context_t *context;
  +    ap_socket_t *sock;
  +    ap_socket_t *sock2;
  +    ap_int32_t rv;
  +    ap_pollfd_t sdset;
       char datasend[STRLEN];
       char datarecv[STRLEN] = "Recv data test";
   
  -    context = apr_initialize(NULL);
  +    context = ap_initialize(NULL);
   
       fprintf(stdout, "\tServer:  Creating new socket.......");
  -    if ((sock = apr_create_tcp_socket(context)) == NULL) {
  +    if ((sock = ap_create_tcp_socket(context)) == NULL) {
           fprintf(stderr, "Couldn't create socket\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  Setting socket option NONBLOCK.......");
  -    if (apr_setsocketopt(context, sock, APR_SO_NONBLOCK, 1) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_setsocketopt(context, sock, APR_SO_NONBLOCK, 1) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Couldn't set socket option\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  Setting port for socket.......");
  -    if (apr_setport(context, sock, 8021) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_setport(context, sock, 8021) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Couldn't set the port correctly\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  Binding socket to port.......");
  -    if (apr_bind(context, sock) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_bind(context, sock) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Could not bind  %d\n", errno);
           exit(-1);
       }
       fprintf(stdout, "OK\n");
       
       fprintf(stdout, "\tServer:  Listening to socket.......");
  -    if (apr_listen(context, sock, 8021) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_listen(context, sock, 8021) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Could not listen\n");
           exit(-1);
       }
  @@ -121,70 +121,70 @@
       fprintf(stdout, "OK\n");
       
       fprintf(stdout, "\tServer:  Beginning to poll for socket.......");
  -    rv = apr_poll(context, &sdset, 1, -1); 
  +    rv = ap_poll(context, &sdset, 1, -1); 
       if (rv == -1) {
  -        apr_close_socket(context, sock);
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Select caused an error\n");
           exit(-1);
       }
       else if (rv == 0) {
  -        apr_close_socket(context, sock);
  +        ap_close_socket(context, sock);
           fprintf(stderr, "I should not return until rv == 1\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  Accepting a connection.......");
  -    if ((sock2 = apr_accept(context, sock)) == NULL) {
  -        apr_close_socket(context, sock);
  +    if ((sock2 = ap_accept(context, sock)) == NULL) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Could not accept connection.\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  Trying to recv data from socket.......");
  -    if (apr_recv(context, sock2, datasend, STRLEN, 5) != STRLEN) {
  -        apr_close_socket(context, sock);
  -        apr_close_socket(context, sock2);
  +    if (ap_recv(context, sock2, datasend, STRLEN, 5) != STRLEN) {
  +        ap_close_socket(context, sock);
  +        ap_close_socket(context, sock2);
           fprintf(stderr, "Problem recving data\n");
           exit(-1);
       }
       if (strcmp(datasend, "Send data test")) {
  -        apr_close_socket(context, sock);
  -        apr_close_socket(context, sock2);
  +        ap_close_socket(context, sock);
  +        ap_close_socket(context, sock2);
           fprintf(stderr, "I did not receive the correct data %s\n", datarecv);
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  Sending data over socket.......");
  -    if (apr_send(context, sock2, datarecv, STRLEN, 5) != STRLEN) {
  -        apr_close_socket(context, sock);
  -        apr_close_socket(context, sock2);
  +    if (ap_send(context, sock2, datarecv, STRLEN, 5) != STRLEN) {
  +        ap_close_socket(context, sock);
  +        ap_close_socket(context, sock2);
           fprintf(stderr, "Problem sending data\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
       
       fprintf(stdout, "\tServer:  Shutting down accepte socket.......");
  -    if (apr_shutdown(context, sock2, APR_SHUTDOWN_READ) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  -        apr_close_socket(context, sock2);
  +    if (ap_shutdown(context, sock2, APR_SHUTDOWN_READ) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
  +        ap_close_socket(context, sock2);
           fprintf(stderr, "Problem shutting down\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
   
       fprintf(stdout, "\tServer:  closing duplicate socket.......");
  -    if (apr_close_socket(context, sock2) == APR_FAILURE) {
  -        apr_close_socket(context, sock);
  +    if (ap_close_socket(context, sock2) == APR_FAILURE) {
  +        ap_close_socket(context, sock);
           fprintf(stderr, "Problem closing down\n");
           exit(-1);
       }
       fprintf(stdout, "OK\n");
       
       fprintf(stdout, "\tServer:  closing original socket.......");
  -    if (apr_close_socket(context, sock) == APR_FAILURE) {
  +    if (ap_close_socket(context, sock) == APR_FAILURE) {
           fprintf(stderr, "Problem closing down\n");
           exit(-1);
       }
  
  
  
  1.14      +39 -39    apache-apr/apr/test/testfile.c
  
  Index: testfile.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/testfile.c,v
  retrieving revision 1.13
  retrieving revision 1.14
  diff -u -r1.13 -r1.14
  --- testfile.c	1999/04/30 18:38:54	1.13
  +++ testfile.c	1999/05/10 14:36:33	1.14
  @@ -62,26 +62,26 @@
   #include <unistd.h>
   #endif
   
  -int test_filedel(apr_context_t *);
  -int testdirs(apr_context_t *);
  +int test_filedel(ap_context_t *);
  +int testdirs(ap_context_t *);
   
   int main()
   {
  -    apr_context_t *context;
  -    apr_file_t *thefile = NULL;
  -    apr_status_t status = 0;
  -    apr_int32_t flag = APR_READ | APR_WRITE | APR_CREATE;
  -    apr_uint64_t rv = 0;
  -    apr_uint64_t nbytes = 0;
  +    ap_context_t *context;
  +    ap_file_t *thefile = NULL;
  +    ap_status_t status = 0;
  +    ap_int32_t flag = APR_READ | APR_WRITE | APR_CREATE;
  +    ap_uint64_t rv = 0;
  +    ap_uint64_t nbytes = 0;
       char buf;
       char *filename = "test.fil";
   
  -    context = apr_initialize(NULL);
  +    context = ap_initialize(NULL);
   
       fprintf(stdout, "Testing file functions.\n");
   
       fprintf(stdout, "\tOpening file.......");
  -    thefile = apr_open(context, filename, flag, APR_UREAD | APR_UWRITE | APR_GREAD);
  +    thefile = ap_open(context, filename, flag, APR_UREAD | APR_UWRITE | APR_GREAD);
       if (thefile == NULL) {
           perror("Didn't open file");
           exit(-1);
  @@ -95,7 +95,7 @@
           fprintf(stderr, "Bad file des\n");
           exit(-1);
       }
  -    if (strcmp(apr_get_filename(context, thefile), filename) != 0) {
  +    if (strcmp(ap_get_filename(context, thefile), filename) != 0) {
           fprintf(stderr, "wrong filename\n");
           exit(-1);
       }
  @@ -105,8 +105,8 @@
   
       fprintf(stdout, "\tWriting to file.......");
       
  -    nbytes = (apr_uint64_t)strlen("this is a test");
  -    rv = apr_write(context, thefile, "this is a test", nbytes);
  +    nbytes = (ap_uint64_t)strlen("this is a test");
  +    rv = ap_write(context, thefile, "this is a test", nbytes);
       if (rv == -1) {
           perror("something's wrong");
           exit(-1);
  @@ -120,7 +120,7 @@
       }
   
       fprintf(stdout, "\tMoving to start of file.......");
  -    if (apr_seek(context, thefile, 0, SEEK_SET) != 0) {
  +    if (ap_seek(context, thefile, 0, SEEK_SET) != 0) {
           perror("couldn't seek to beginning of file.");
           exit(-1);
       }
  @@ -129,13 +129,13 @@
       }
   
       fprintf(stdout, "\tReading from the file.......");
  -    nbytes = (apr_uint64_t)strlen("this is a test");
  -    rv = apr_read(context, thefile, &buf, nbytes);
  +    nbytes = (ap_uint64_t)strlen("this is a test");
  +    rv = ap_read(context, thefile, &buf, nbytes);
       if (rv == -1) {
           perror("something's wrong");
           exit(-1);
       }
  -    nbytes = (apr_uint64_t)strlen("this is a test");
  +    nbytes = (ap_uint64_t)strlen("this is a test");
       if (rv != nbytes) {
           fprintf(stderr, "didn't read properly.\n");
           exit(-1);
  @@ -145,7 +145,7 @@
       }
   
       fprintf(stdout, "\tClosing File.......");
  -    status = apr_close(context, thefile);
  +    status = ap_close(context, thefile);
       if (status == APR_FAILURE) {
           fprintf(stderr, "Couldn't close the file\n");
           exit(-1); 
  @@ -155,7 +155,7 @@
       }
       
       fprintf(stdout, "\tDeleting file.......");
  -    status = apr_remove_file(context, filename);
  +    status = ap_remove_file(context, filename);
       if (status == APR_FAILURE) {
           fprintf(stderr, "Couldn't delete the file\n");
           exit(-1); 
  @@ -165,7 +165,7 @@
       }
       
       fprintf(stdout, "\tMaking sure it's gone.......");
  -    thefile = apr_open(context, filename, APR_READ, APR_UREAD | APR_UWRITE | APR_GREAD);
  +    thefile = ap_open(context, filename, APR_READ, APR_UREAD | APR_UWRITE | APR_GREAD);
       if (thefile != NULL) {
           fprintf(stderr, "I could open the file for some reason?\n");
           exit(-1);
  @@ -180,25 +180,25 @@
       return 1;
   }
   
  -int test_filedel(apr_context_t *context)
  +int test_filedel(ap_context_t *context)
   {
  -    apr_file_t *thefile;
  -    apr_int32_t flag = APR_READ | APR_WRITE | APR_CREATE;
  +    ap_file_t *thefile;
  +    ap_int32_t flag = APR_READ | APR_WRITE | APR_CREATE;
       
  -    thefile = apr_open(context, "testdel", flag, APR_UREAD | APR_UWRITE | APR_GREAD);
  +    thefile = ap_open(context, "testdel", flag, APR_UREAD | APR_UWRITE | APR_GREAD);
       if (thefile == NULL) {
            return APR_FAILURE;
       }
   
  -    if (apr_remove_file(context, thefile->fname) == APR_FAILURE) {
  +    if (ap_remove_file(context, thefile->fname) == APR_FAILURE) {
           return APR_FAILURE;
       }
   
  -    if (apr_close(context, thefile) == APR_FAILURE) {
  +    if (ap_close(context, thefile) == APR_FAILURE) {
           return APR_FAILURE;
       }
   
  -    thefile = apr_open(context, "testdel", APR_READ, APR_UREAD | APR_UWRITE | APR_GREAD);
  +    thefile = ap_open(context, "testdel", APR_READ, APR_UREAD | APR_UWRITE | APR_GREAD);
       if (thefile == NULL) {
           return APR_FAILURE;
       }
  @@ -206,15 +206,15 @@
       return APR_SUCCESS;
   }
   
  -int testdirs(apr_context_t *context)
  +int testdirs(ap_context_t *context)
   {
  -    apr_dir_t *temp;  
  -    apr_dirent_t *entry, *entry1;
  +    ap_dir_t *temp;  
  +    ap_dirent_t *entry, *entry1;
   
       fprintf(stdout, "Testing Directory functions.\n");
   
       fprintf(stdout, "\tMakeing Directory.......");
  -    if (apr_make_dir(context, "testdir", APR_UREAD | APR_UWRITE | APR_UEXECUTE | APR_GREAD | APR_GWRITE | APR_GEXECUTE | APR_WREAD | APR_WWRITE | APR_WEXECUTE) == APR_FAILURE) {
  +    if (ap_make_dir(context, "testdir", APR_UREAD | APR_UWRITE | APR_UEXECUTE | APR_GREAD | APR_GWRITE | APR_GEXECUTE | APR_WREAD | APR_WWRITE | APR_WEXECUTE) == APR_FAILURE) {
           fprintf(stderr, "Could not create directory\n");
           return -1;
       }
  @@ -222,12 +222,12 @@
           fprintf(stdout, "OK\n");
       }
   
  -    if (apr_open(context, "testdir/testfile", APR_READ | APR_WRITE | APR_CREATE, APR_UREAD | APR_UWRITE | APR_UEXECUTE) == NULL) {;
  +    if (ap_open(context, "testdir/testfile", APR_READ | APR_WRITE | APR_CREATE, APR_UREAD | APR_UWRITE | APR_UEXECUTE) == NULL) {;
           return -1;
       }
   
       fprintf(stdout, "\tOpening Directory.......");
  -    if ((temp = apr_opendir(context, "testdir")) == NULL) {
  +    if ((temp = ap_opendir(context, "testdir")) == NULL) {
           fprintf(stderr, "Could not open directory\n");
           return -1;
       }
  @@ -236,7 +236,7 @@
       }
   
       fprintf(stdout, "\tReading Directory.......");
  -    if ((entry = apr_readdir(context, temp)) == NULL) {
  +    if ((entry = ap_readdir(context, temp)) == NULL) {
           fprintf(stderr, "Could not read directory\n");
           return -1;
       }
  @@ -246,9 +246,9 @@
       
   
       fprintf(stdout, "\tRewinding directory.......");
  -    apr_rewinddir(context, temp); 
  +    ap_rewinddir(context, temp); 
      
  -    if ((entry1 = apr_readdir(context, temp)) != NULL) {
  +    if ((entry1 = ap_readdir(context, temp)) != NULL) {
           if (entry1->d_ino != entry->d_ino) {
               fprintf(stderr, "Couldn't rewind directory\n");
               return -1;
  @@ -259,7 +259,7 @@
       }
       
       fprintf(stdout, "\tClosing Directory.......");
  -    if (apr_closedir(context, temp) == APR_FAILURE) {
  +    if (ap_closedir(context, temp) == APR_FAILURE) {
           fprintf(stderr, "Could not close directory\n");
           return -1;
       }
  @@ -268,7 +268,7 @@
       }
   
       fprintf(stdout, "\tRemoving file from directory.......");
  -    if (apr_remove_file(context, "testdir/testfile") == APR_FAILURE) {
  +    if (ap_remove_file(context, "testdir/testfile") == APR_FAILURE) {
           fprintf(stderr, "Could not remove file\n");
           return -1;
       }
  @@ -277,7 +277,7 @@
       }
   
       fprintf(stdout, "\tRemoving Directory.......");
  -    if (apr_remove_dir(context, "testdir") == APR_FAILURE) {
  +    if (ap_remove_dir(context, "testdir") == APR_FAILURE) {
           fprintf(stderr, "Could not create directory\n");
           return -1;
       }
  
  
  
  1.4       +15 -10    apache-apr/apr/test/testproc.c
  
  Index: testproc.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/testproc.c,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- testproc.c	1999/04/26 15:35:18	1.3
  +++ testproc.c	1999/05/10 14:36:34	1.4
  @@ -67,19 +67,23 @@
   
   int main(int argc, char *argv[])
   {
  -    apr_proc_t *newproc;
  -    apr_procattr_t *attr;
  -    apr_file_t *testfile;
  +    ap_context_t *context;
  +    ap_proc_t *newproc;
  +    ap_procattr_t *attr;
  +    ap_file_t *testfile;
  +    ap_ssize_t rv;
       char buf[256];
       char *args[3];
       char *teststr = "Whooo Hoooo\n";
   
  +    context = ap_initialize(NULL);
  +
       if (argc > 1) {
           fprintf(stdout, "%s", teststr);
           exit(1);
       }
       fprintf(stdout, "Creating procattr.......");
  -    attr = apr_createprocattr_init();
  +    attr = ap_createprocattr_init(context);
       if (attr == NULL) {
           fprintf(stderr, "Could not create attr\n");
           exit(-1);;
  @@ -87,21 +91,21 @@
       fprintf(stdout, "OK.\n");
   
       fprintf(stdout, "Setting attr pipes, all three.......");
  -    if (apr_setprocattr_io(attr, 1, 1, 1) == APR_FAILURE) {
  +    if (ap_setprocattr_io(context, attr, 1, 1, 1) == APR_FAILURE) {
           fprintf(stderr, "Could not set pipes attr\n");
           exit(-1);
       }
       fprintf(stdout, "OK.\n");
       
       fprintf(stdout, "Setting attr dir.......");
  -    if (apr_setprocattr_dir(attr, "proctest") == APR_FAILURE) {
  +    if (ap_setprocattr_dir(context, attr, "proctest") == APR_FAILURE) {
           fprintf(stderr, "Could not set directory attr\n");
           exit(-1);
       }
       fprintf(stdout, "OK.\n");
   
       fprintf(stdout, "Setting attr cmd type.......");
  -    if (apr_setprocattr_cmdtype(attr, APR_PROGRAM) == APR_FAILURE) {
  +    if (ap_setprocattr_cmdtype(context, attr, APR_PROGRAM) == APR_FAILURE) {
           fprintf(stderr, "Could not set cmd type attr\n");
           exit(-1);
       }
  @@ -112,21 +116,22 @@
       args[2] = NULL;
    
       fprintf(stdout, "Createing a new process.......");
  -    if ((newproc = apr_create_process("../testproc", args, NULL, attr)) == NULL) {
  +    if ((newproc = ap_create_process(context, "../testproc", args, NULL, attr)) == NULL) {
           fprintf(stderr, "Could not create the new process\n");
           exit(-1);
       }
       fprintf(stdout, "OK.\n");
   
       fprintf(stdout, "Grabbing child's stdout.......");
  -    if ((testfile = apr_get_childout(newproc)) == NULL) {
  +    if ((testfile = ap_get_childout(context, newproc)) == NULL) {
           fprintf(stderr, "Could not get child's stdout\n");
           exit(-1);
       }
       fprintf(stdout, "OK.\n");
       
       fprintf(stdout, "Checking the data read from pipe to child.......");
  -    apr_read(testfile, buf, 256);
  +    rv = ap_read(context, testfile, buf, 256);
  +    buf[rv] = '\0';
       if (!strcmp(buf, teststr))
           fprintf(stdout,"OK\n");
       else fprintf(stderr, "Uh-Oh\n");
  
  
  
  1.4       +16 -16    apache-apr/apr/test/testsock.c
  
  Index: testsock.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/test/testsock.c,v
  retrieving revision 1.3
  retrieving revision 1.4
  diff -u -r1.3 -r1.4
  --- testsock.c	1999/04/30 18:38:54	1.3
  +++ testsock.c	1999/05/10 14:36:34	1.4
  @@ -64,16 +64,16 @@
   
   int main(int argc, char *argv[])
   {
  -    apr_context_t *context;
  +    ap_context_t *context;
   
  -    apr_procattr_t *attr1;
  -    apr_procattr_t *attr2;
  -    apr_proc_t *proc1;
  -    apr_proc_t *proc2;
  -    apr_status_t s1;
  -    apr_status_t s2;
  +    ap_procattr_t *attr1;
  +    ap_procattr_t *attr2;
  +    ap_proc_t *proc1;
  +    ap_proc_t *proc2;
  +    ap_status_t s1;
  +    ap_status_t s2;
   
  -    context = apr_initialize(NULL);
  +    context = ap_initialize(NULL);
   
       fprintf(stdout, "This test relies on the process test working.  Please\n");
       fprintf(stdout, "run that test first, and only run this test when it\n");
  @@ -81,8 +81,8 @@
       fprintf(stdout, "server and client by yourself.\n");
   
       fprintf(stdout, "Creating children to run network tests.......\n");
  -    attr1 = apr_createprocattr_init(context);
  -    attr2 = apr_createprocattr_init(context);
  +    attr1 = ap_createprocattr_init(context);
  +    attr2 = ap_createprocattr_init(context);
   
   
       if (attr1 == NULL || attr2 == NULL) {
  @@ -90,25 +90,25 @@
           exit(-1);
       }
      
  -    proc1 = apr_create_process(context, "server", NULL, NULL, attr1);
  -    proc2 = apr_create_process(context, "client", NULL, NULL, attr2);
  +    proc1 = ap_create_process(context, "server", NULL, NULL, attr1);
  +    proc2 = ap_create_process(context, "client", NULL, NULL, attr2);
   
       if (proc1 == NULL || proc2 == NULL) {
           fprintf(stderr, "Problem spawning new process\n");
           exit(-1);
       }
   
  -    while ((s1 = apr_wait_proc(context, proc1, APR_NOWAIT)) == APR_FAILURE &&
  -           (s2 = apr_wait_proc(context, proc2, APR_NOWAIT)) == APR_FAILURE)
  +    while ((s1 = ap_wait_proc(context, proc1, APR_NOWAIT)) == APR_FAILURE &&
  +           (s2 = ap_wait_proc(context, proc2, APR_NOWAIT)) == APR_FAILURE)
           continue;
   
       if (s1 == APR_SUCCESS) {
           kill(proc2->pid, SIGTERM);
  -        apr_wait_proc(context, proc2, APR_WAIT);
  +        ap_wait_proc(context, proc2, APR_WAIT);
       }
       else {
           kill(proc1->pid, SIGTERM);
  -        apr_wait_proc(context, proc1, APR_WAIT);
  +        ap_wait_proc(context, proc1, APR_WAIT);
       }
       fprintf(stdout, "Network test completed.\n");   
   }
  
  
  
  1.2       +6 -3      apache-apr/apr/threadproc/unix/Makefile
  
  Index: Makefile
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/threadproc/unix/Makefile,v
  retrieving revision 1.1
  retrieving revision 1.2
  diff -u -r1.1 -r1.2
  --- Makefile	1999/04/23 17:59:53	1.1
  +++ Makefile	1999/05/10 14:36:35	1.2
  @@ -12,7 +12,7 @@
   SRCDIR=..
   EXTRA_CFLAGS=-g 
   EXTRA_LDFLAGS=
  -EXTRA_LIBS=-L ../../fileio -lfile
  +EXTRA_LIBS=
   EXTRA_INCLUDES=
   EXTRA_DEPS=
   OSDIR=
  @@ -47,7 +47,7 @@
   
   LIB=  libthreadproc.a
   
  -OBJS= proc.o 
  +OBJS= proc.o thread.o threadcancel.o threadpriv.o 
         
   .c.o:
   	$(CC) -c $(INCLUDES) $(CFLAGS) $<
  @@ -82,4 +82,7 @@
   $(OBJS): Makefile
   
   # DO NOT REMOVE
  -open.o: proc.c
  +proc.o: proc.c
  +thread.o: thread.c
  +threadcancel.o: threadcancel.c
  +threadpriv.o: threadpriv.c
  
  
  
  1.7       +42 -42    apache-apr/apr/threadproc/unix/proc.c
  
  Index: proc.c
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/threadproc/unix/proc.c,v
  retrieving revision 1.6
  retrieving revision 1.7
  diff -u -r1.6 -r1.7
  --- proc.c	1999/05/07 18:17:49	1.6
  +++ proc.c	1999/05/10 14:36:36	1.7
  @@ -62,9 +62,9 @@
   #include <string.h>
   #include <sys/wait.h>
   
  -apr_procattr_t *apr_createprocattr_init(apr_context_t *cont)
  +ap_procattr_t *ap_createprocattr_init(ap_context_t *cont)
   {
  -    apr_procattr_t *new = (apr_procattr_t *)apr_palloc(cont->pool, sizeof(apr_procattr_t));
  +    ap_procattr_t *new = (ap_procattr_t *)ap_palloc(cont->pool, sizeof(ap_procattr_t));
   
       new->parent_in = NULL;
       new->child_in = NULL;
  @@ -77,54 +77,54 @@
       return new;
   }
   
  -apr_status_t apr_setprocattr_io(apr_context_t *cont, apr_procattr_t *attr, apr_int32_t in, 
  -                                 apr_int32_t out, apr_int32_t err)
  +ap_status_t ap_setprocattr_io(ap_context_t *cont, ap_procattr_t *attr, ap_int32_t in, 
  +                                 ap_int32_t out, ap_int32_t err)
   {
       if (in) {
  -        attr->parent_in = (apr_file_t *)apr_palloc(cont->pool, 
  -                                                   sizeof(apr_file_t));
  -        attr->child_in = (apr_file_t *)apr_palloc(cont->pool, 
  -                                                  sizeof(apr_file_t));
  -        if (apr_create_pipe(cont, attr->child_in, 
  +        attr->parent_in = (ap_file_t *)ap_palloc(cont->pool, 
  +                                                   sizeof(ap_file_t));
  +        attr->child_in = (ap_file_t *)ap_palloc(cont->pool, 
  +                                                  sizeof(ap_file_t));
  +        if (ap_create_pipe(cont, attr->child_in, 
                               attr->parent_in) == APR_FAILURE) {
               return APR_FAILURE;
           }
       } 
       if (out) {
  -        attr->parent_out = (apr_file_t *)apr_palloc(cont->pool, 
  -                                                    sizeof(apr_file_t));
  -        attr->child_out = (apr_file_t *)apr_palloc(cont->pool, 
  -                                                   sizeof(apr_file_t));
  -        if (apr_create_pipe(cont, attr->parent_out, 
  +        attr->parent_out = (ap_file_t *)ap_palloc(cont->pool, 
  +                                                    sizeof(ap_file_t));
  +        attr->child_out = (ap_file_t *)ap_palloc(cont->pool, 
  +                                                   sizeof(ap_file_t));
  +        if (ap_create_pipe(cont, attr->parent_out, 
                               attr->child_out) == APR_FAILURE) {
               return APR_FAILURE;
           }
       } 
       if (err) {
  -        attr->parent_err = (apr_file_t *)apr_palloc(cont->pool, 
  -                                                    sizeof(apr_file_t));
  -        attr->child_err = (apr_file_t *)apr_palloc(cont->pool, 
  -                                                   sizeof(apr_file_t));
  -        if (apr_create_pipe(cont, attr->parent_err, 
  +        attr->parent_err = (ap_file_t *)ap_palloc(cont->pool, 
  +                                                    sizeof(ap_file_t));
  +        attr->child_err = (ap_file_t *)ap_palloc(cont->pool, 
  +                                                   sizeof(ap_file_t));
  +        if (ap_create_pipe(cont, attr->parent_err, 
                               attr->child_err) == APR_FAILURE) {
               return APR_FAILURE;
           }
       } 
   }
   
  -apr_status_t apr_setprocattr_dir(apr_context_t *cont, apr_procattr_t *attr, 
  +ap_status_t ap_setprocattr_dir(ap_context_t *cont, ap_procattr_t *attr, 
                                    char *dir) 
   {
       attr->currdir = strdup(dir);
   }
   
  -apr_status_t apr_setprocattr_cmdtype(apr_context_t *cont, apr_procattr_t *attr,
  -                                     apr_cmdtype_e cmd) 
  +ap_status_t ap_setprocattr_cmdtype(ap_context_t *cont, ap_procattr_t *attr,
  +                                     ap_cmdtype_e cmd) 
   {
       attr->cmdtype = cmd;
   }
   
  -apr_int32_t apr_fork(apr_context_t *cont, apr_proc_t *proc)
  +ap_int32_t ap_fork(ap_context_t *cont, ap_proc_t *proc)
   {
       int pid;
   
  @@ -141,11 +141,11 @@
       return 1;
   }
   
  -apr_proc_t *apr_create_process(apr_context_t *cont, char *progname, 
  +ap_proc_t *ap_create_process(ap_context_t *cont, char *progname, 
                                  char *const args[], char **env, 
  -                               apr_procattr_t *attr)
  +                               ap_procattr_t *attr)
   {
  -    apr_proc_t *new = (apr_proc_t *)apr_palloc(cont->pool, sizeof(apr_proc_t));
  +    ap_proc_t *new = (ap_proc_t *)ap_palloc(cont->pool, sizeof(ap_proc_t));
       int i;
       char **newargs;
   
  @@ -155,19 +155,19 @@
       else if (new->pid == 0) { 
           /* child process */
           if (attr->child_in) {
  -            apr_close(cont, attr->parent_in);
  +            ap_close(cont, attr->parent_in);
               dup2(attr->child_in->filedes, STDIN_FILENO);
  -            apr_close(cont, attr->child_in);
  +            ap_close(cont, attr->child_in);
           }
           if (attr->child_out) {
  -            apr_close(cont, attr->parent_out);
  +            ap_close(cont, attr->parent_out);
               dup2(attr->child_out->filedes, STDOUT_FILENO);
  -            apr_close(cont, attr->child_out);
  +            ap_close(cont, attr->child_out);
           }
           if (attr->child_err) {
  -            apr_close(cont, attr->parent_err);
  +            ap_close(cont, attr->parent_err);
               dup2(attr->child_err->filedes, STDERR_FILENO);
  -            apr_close(cont, attr->child_err);
  +            ap_close(cont, attr->child_err);
           }
           
           signal(SIGCHLD, SIG_DFL); /*not sure if this is needed or not */
  @@ -202,36 +202,36 @@
       }
       /* Parent process */
       if (attr->child_in) {
  -        apr_close(cont, attr->child_in);
  +        ap_close(cont, attr->child_in);
       }
       if (attr->child_out) {
  -        apr_close(cont, attr->child_out);
  +        ap_close(cont, attr->child_out);
       }
       if (attr->child_err) {
  -        apr_close(cont, attr->child_err);
  +        ap_close(cont, attr->child_err);
       }
       
       new->attr = attr;
       return new;
   }
   
  -apr_file_t *apr_get_childin(apr_context_t *cont, apr_proc_t *proc)
  +ap_file_t *ap_get_childin(ap_context_t *cont, ap_proc_t *proc)
   {
       return proc->attr->parent_in; 
   }
   
  -apr_file_t *apr_get_childout(apr_context_t *cont, apr_proc_t *proc)
  +ap_file_t *ap_get_childout(ap_context_t *cont, ap_proc_t *proc)
   {
       return proc->attr->parent_out; 
   }
   
  -apr_file_t *apr_get_childerr(apr_context_t *cont, apr_proc_t *proc)
  +ap_file_t *ap_get_childerr(ap_context_t *cont, ap_proc_t *proc)
   {
       return proc->attr->parent_err; 
   }    
   
  -apr_status_t apr_wait_proc(apr_context_t *cont, apr_proc_t *proc, 
  -                           apr_wait_how_e wait)
  +ap_status_t ap_wait_proc(ap_context_t *cont, ap_proc_t *proc, 
  +                           ap_wait_how_e wait)
   {
       if (!proc)
           return APR_FAILURE;
  @@ -245,9 +245,9 @@
       return APR_FAILURE;
   } 
   
  -void apr_exit_proc(apr_context_t *cont)
  +void ap_exit_proc(ap_context_t *cont)
   {
  -    apr_destroy_pool(cont->pool);
  +    ap_destroy_pool(cont->pool);
   }
   
   
  
  
  
  1.3       +15 -7     apache-apr/apr/threadproc/unix/threadproc.h
  
  Index: threadproc.h
  ===================================================================
  RCS file: /home/cvs/apache-apr/apr/threadproc/unix/threadproc.h,v
  retrieving revision 1.2
  retrieving revision 1.3
  diff -u -r1.2 -r1.3
  --- threadproc.h	1999/04/29 20:20:36	1.2
  +++ threadproc.h	1999/05/10 14:36:36	1.3
  @@ -62,6 +62,14 @@
   
   #define SHELL_PATH "/bin/sh"
   
  +#define PTHREAD_CANCEL_AYNCHRONOUS  CANCEL_ASYNCH; 
  +#define PTHREAD_CANCEL_DEFERRED     CANCEL_DEFER;
  +                                   
  +#define PTHREAD_CANCEL_ENABLE       CANCEL_ENABLE; 
  +#define PTHREAD_CANCEL_DISABLE      CANCEL_DISABLE;
  +
  +typedef pthread_key_t     threadkey_t;
  +
   struct thread_t {
       pthread_t *td;
   };
  @@ -71,14 +79,14 @@
   };
   
   struct procattr_t {
  -    apr_file_t *parent_in;
  -    apr_file_t *child_in;
  -    apr_file_t *parent_out;
  -    apr_file_t *child_out;
  -    apr_file_t *parent_err;
  -    apr_file_t *child_err;
  +    ap_file_t *parent_in;
  +    ap_file_t *child_in;
  +    ap_file_t *parent_out;
  +    ap_file_t *child_out;
  +    ap_file_t *parent_err;
  +    ap_file_t *child_err;
       char *currdir;
  -    apr_int32_t cmdtype;
  +    ap_int32_t cmdtype;
   };
   
   struct proc_t {