Wide-character strings |
typedef wchar_t | WChar |
u_int | wslen (const WChar *) |
WChar * | wscpy (WChar *, const WChar *) |
int | wscmp (const WChar *, const WChar *) |
int | wsncmp (const WChar *, const WChar *, size_t len) |
A set of wrappers for threads |
int | thr_continue (ACE_hthread_t target_thread) |
int | thr_create (ACE_THR_FUNC func, void *args, long flags, ACE_thread_t *thr_id, ACE_hthread_t *t_handle=0, long priority=ACE_DEFAULT_THREAD_PRIORITY, void *stack=0, size_t stacksize=0, ACE_Base_Thread_Adapter *thread_adapter=0) |
int | thr_getprio (ACE_hthread_t thr_id, int &prio) |
int | thr_join (ACE_hthread_t waiter_id, ACE_THR_FUNC_RETURN *status) |
int | thr_join (ACE_thread_t waiter_id, ACE_thread_t *thr_id, ACE_THR_FUNC_RETURN *status) |
int | thr_kill (ACE_thread_t thr_id, int signum) |
ACE_thread_t | thr_self (void) |
void | thr_self (ACE_hthread_t &) |
int | thr_setprio (ACE_hthread_t thr_id, int prio) |
int | thr_setprio (const ACE_Sched_Priority prio) |
int | thr_suspend (ACE_hthread_t target_thread) |
int | thr_cancel (ACE_thread_t t_id) |
int | thr_cmp (ACE_hthread_t t1, ACE_hthread_t t2) |
int | thr_equal (ACE_thread_t t1, ACE_thread_t t2) |
void | thr_exit (ACE_THR_FUNC_RETURN status=0) |
int | thr_getconcurrency (void) |
int | lwp_getparams (ACE_Sched_Params &) |
int | thr_getspecific (ACE_thread_key_t key, void **data) |
int | thr_keyfree (ACE_thread_key_t key) |
int | thr_key_detach (void *inst) |
int | thr_keycreate (ACE_thread_key_t *key, ACE_THR_DEST, void *inst=0) |
int | thr_key_used (ACE_thread_key_t key) |
size_t | thr_min_stack (void) |
int | thr_setconcurrency (int hint) |
int | lwp_setparams (const ACE_Sched_Params &) |
int | thr_setspecific (ACE_thread_key_t key, void *data) |
int | thr_sigsetmask (int how, const sigset_t *nsm, sigset_t *osm) |
int | thr_setcancelstate (int new_state, int *old_state) |
int | thr_setcanceltype (int new_type, int *old_type) |
int | sigwait (sigset_t *set, int *sig=0) |
int | sigtimedwait (const sigset_t *set, siginfo_t *info, const ACE_Time_Value *timeout) |
void | thr_testcancel (void) |
void | thr_yield (void) |
void | unique_name (const void *object, ACE_TCHAR *name, size_t length) |
| This method uses process id and object pointer to come up with a machine wide unique name. More...
|
ACE_thread_t | NULL_thread |
| This is necessary to deal with POSIX pthreads and their use of structures for thread ids. More...
|
ACE_hthread_t | NULL_hthread |
| This is necessary to deal with POSIX pthreads and their use of structures for thread handles. More...
|
ACE_thread_key_t | NULL_key |
| This is necessary to deal with POSIX pthreads and their use of structures for TSS keys. More...
|
Public Types |
enum | ACE_HRTimer_Op { ACE_HRTIMER_START = 0x0,
ACE_HRTIMER_INCR = 0x1,
ACE_HRTIMER_STOP = 0x2,
ACE_HRTIMER_GETTIME = 0xFFFF
} |
Static Public Methods |
LPSECURITY_ATTRIBUTES | default_win32_security_attributes (LPSECURITY_ATTRIBUTES) |
const OSVERSIONINFO & | get_win32_versioninfo (void) |
| Return the win32 OSVERSIONINFO structure. More...
|
HINSTANCE | get_win32_resource_module (void) |
| Return the handle of the module containing ACE's resources. By default, for a DLL build of ACE this is a handle to the ACE DLL itself, and for a static build it is a handle to the executable. More...
|
void | set_win32_resource_module (HINSTANCE) |
| Allow an application to modify which module contains ACE's resources. This is mainly useful for a static build of ACE where the required resources reside somewhere other than the executable. More...
|
int | atoi (const char *s) |
int | atoi (const wchar_t *s) |
void * | atop (const char *s) |
void * | atop (const wchar_t *s) |
double | floor (double x) |
| This method computes the largest integral value not greater than x. More...
|
double | ceil (double x) |
| This method computes the smallest integral value not less than x. More...
|
char * | getenv (const char *symbol) |
wchar_t * | getenv (const wchar_t *symbol) |
int | putenv (const ACE_TCHAR *string) |
ACE_TCHAR * | strenvdup (const ACE_TCHAR *str) |
ACE_TCHAR * | getenvstrings (void) |
int | getopt (int argc, char *const *argv, const char *optstring) |
int | argv_to_string (ACE_TCHAR **argv, ACE_TCHAR *&buf, int substitute_env_args=1) |
int | string_to_argv (ACE_TCHAR *buf, int &argc, ACE_TCHAR **&argv, int substitute_env_args=1) |
long | sysconf (int) |
pid_t | waitpid (pid_t pid, ACE_exitcode *status=0, int wait_options=0, ACE_HANDLE handle=0) |
| Calls <waitpid> on UNIX/POSIX platforms and <await> on Chorus. More...
|
pid_t | wait (pid_t pid, ACE_exitcode *status, int wait_options=0, ACE_HANDLE handle=0) |
| Calls <WaitForSingleObject> on Win32 and <ACE::waitpid> otherwise. More...
|
pid_t | wait (int *=0) |
| Calls OS <wait> function, so it's only portable to UNIX/POSIX platforms. More...
|
void | mutex_lock_cleanup (void *mutex) |
| Handle asynchronous thread cancellation cleanup. More...
|
void | cleanup_tss (const u_int main_thread) |
| Call TSS destructors for the current thread. More...
|
int | scheduling_class (const char *class_name, ACE_id_t &) |
| Find the schedling class ID that corresponds to the class name. More...
|
int | set_scheduling_params (const ACE_Sched_Params &, ACE_id_t id=ACE_SELF) |
| Friendly interface to <priocntl>(2). More...
|
int | priority_control (ACE_idtype_t, ACE_id_t, int, void *) |
| Can't call the following priocntl, because that's a macro on Solaris. More...
|
long | num_processors (void) |
| Get the number of CPUs configured in the machine. More...
|
long | num_processors_online (void) |
| Get the number of CPUs currently online. More...
|
|
int | condattr_init (ACE_condattr_t &attributes, int type=ACE_DEFAULT_SYNCH_TYPE) |
int | condattr_destroy (ACE_condattr_t &attributes) |
int | cond_broadcast (ACE_cond_t *cv) |
int | cond_destroy (ACE_cond_t *cv) |
int | cond_init (ACE_cond_t *cv, short type=ACE_DEFAULT_SYNCH_TYPE, const char *name=0, void *arg=0) |
int | cond_init (ACE_cond_t *cv, ACE_condattr_t &attributes, const char *name=0, void *arg=0) |
int | cond_init (ACE_cond_t *cv, short type, const wchar_t *name, void *arg=0) |
int | cond_init (ACE_cond_t *cv, ACE_condattr_t &attributes, const wchar_t *name, void *arg=0) |
int | cond_signal (ACE_cond_t *cv) |
int | cond_timedwait (ACE_cond_t *cv, ACE_mutex_t *m, ACE_Time_Value *) |
int | cond_wait (ACE_cond_t *cv, ACE_mutex_t *m) |
|
char * | cuserid (char *user, size_t maxlen=ACE_MAX_USERID) |
wchar_t * | cuserid (wchar_t *user, size_t maxlen=ACE_MAX_USERID) |
|
int | uname (ACE_utsname *name) |
long | sysinfo (int cmd, char *buf, long count) |
int | hostname (char *name, size_t maxnamelen) |
int | hostname (wchar_t *name, size_t maxnamelen) |
|
int | dlclose (ACE_SHLIB_HANDLE handle) |
ACE_TCHAR * | dlerror (void) |
ACE_SHLIB_HANDLE | dlopen (const ACE_TCHAR *filename, int mode=ACE_DEFAULT_SHLIB_MODE) |
void * | dlsym (ACE_SHLIB_HANDLE handle, const ACE_TCHAR *symbol) |
|
int | last_error (void) |
void | last_error (int) |
int | set_errno_to_last_error (void) |
int | set_errno_to_wsa_last_error (void) |
int | fclose (FILE *fp) |
int | fcntl (ACE_HANDLE handle, int cmd, long arg=0) |
int | fdetach (const char *file) |
int | fsync (ACE_HANDLE handle) |
FILE * | fopen (const ACE_TCHAR *filename, const ACE_TCHAR *mode) |
FILE * | freopen (const ACE_TCHAR *filename, const ACE_TCHAR *mode, FILE *stream) |
FILE * | fdopen (ACE_HANDLE handle, const ACE_TCHAR *mode) |
ACE_TCHAR * | fgets (ACE_TCHAR *buf, int size, FILE *fp) |
int | stat (const ACE_TCHAR *file, ACE_stat *) |
int | truncate (const ACE_TCHAR *filename, off_t length) |
int | fprintf (FILE *fp, const char *format,...) |
int | sprintf (char *buf, const char *format,...) |
int | vsprintf (char *buffer, const char *format, va_list argptr) |
int | printf (const char *format,...) |
int | sprintf (wchar_t *buf, const wchar_t *format,...) |
int | fprintf (FILE *fp, const wchar_t *format,...) |
int | vsprintf (wchar_t *buffer, const wchar_t *format, va_list argptr) |
void | perror (const ACE_TCHAR *s) |
char * | gets (char *str, int n=0) |
int | puts (const ACE_TCHAR *s) |
int | fputs (const ACE_TCHAR *s, FILE *stream) |
int | fflush (FILE *fp) |
size_t | fread (void *ptr, size_t size, size_t nelems, FILE *fp) |
int | fgetc (FILE *fp) |
void | clearerr (FILE *fp) |
wint_t | fgetwc (FILE *fp) |
wint_t | ungetwc (wint_t c, FILE *fp) |
int | fseek (FILE *fp, long offset, int ptrname) |
long | ftell (FILE *fp) |
int | fgetpos (FILE *fp, fpos_t *pos) |
int | fsetpos (FILE *fp, fpos_t *pos) |
int | fstat (ACE_HANDLE, ACE_stat *) |
int | lstat (const char *, ACE_stat *) |
int | ftruncate (ACE_HANDLE, off_t) |
size_t | fwrite (const void *ptr, size_t size, size_t nitems, FILE *fp) |
void | rewind (FILE *fp) |
|
void * | bsearch (const void *key, const void *base, size_t nel, size_t size, ACE_COMPARE_FUNC) |
void | qsort (void *base, size_t nel, size_t width, ACE_COMPARE_FUNC) |
|
int | flock_init (ACE_OS::ace_flock_t *lock, int flags=0, const ACE_TCHAR *name=0, mode_t perms=0) |
int | flock_destroy (ACE_OS::ace_flock_t *lock, int unlink_file=1) |
void | adjust_flock_params (ACE_OS::ace_flock_t *lock, short whence, off_t &start, off_t &len) |
int | flock_rdlock (ACE_OS::ace_flock_t *lock, short whence=0, off_t start=0, off_t len=0) |
int | flock_tryrdlock (ACE_OS::ace_flock_t *lock, short whence=0, off_t start=0, off_t len=0) |
int | flock_trywrlock (ACE_OS::ace_flock_t *lock, short whence=0, off_t start=0, off_t len=0) |
int | flock_unlock (ACE_OS::ace_flock_t *lock, short whence=0, off_t start=0, off_t len=0) |
int | flock_wrlock (ACE_OS::ace_flock_t *lock, short whence=0, off_t start=0, off_t len=0) |
|
int | atexit (ACE_EXIT_HOOK func) |
int | execl (const char *path, const char *arg0,...) |
int | execle (const char *path, const char *arg0,...) |
int | execlp (const char *file, const char *arg0,...) |
int | execv (const char *path, char *const argv[]) |
int | execvp (const char *file, char *const argv[]) |
int | execve (const char *path, char *const argv[], char *const envp[]) |
void | _exit (int status=0) |
void | exit (int status=0) |
void | abort (void) |
pid_t | fork (void) |
int | getpagesize (void) |
int | allocation_granularity (void) |
gid_t | getgid (void) |
int | setgid (gid_t) |
pid_t | getpid (void) |
pid_t | getpgid (pid_t pid) |
pid_t | getppid (void) |
uid_t | getuid (void) |
int | setuid (uid_t) |
pid_t | setsid (void) |
int | setpgid (pid_t pid, pid_t pgid) |
int | setreuid (uid_t ruid, uid_t euid) |
int | setregid (gid_t rgid, gid_t egid) |
int | system (const ACE_TCHAR *s) |
|
pid_t | fork (const ACE_TCHAR *program_name) |
| Forks and exec's a process in a manner that works on Solaris and NT. argv[0] must be the full path name to the executable. More...
|
pid_t | fork_exec (ACE_TCHAR *argv[]) |
| Forks and exec's a process in a manner that works on Solaris and NT. argv[0] must be the full path name to the executable. More...
|
|
u_int | alarm (u_int secs) |
u_int | ualarm (u_int usecs, u_int interval=0) |
u_int | ualarm (const ACE_Time_Value &tv, const ACE_Time_Value &tv_interval=ACE_Time_Value::zero) |
ACE_hrtime_t | gethrtime (const ACE_HRTimer_Op=ACE_HRTIMER_GETTIME) |
int | clock_gettime (clockid_t, struct timespec *) |
ACE_Time_Value | gettimeofday (void) |
int | getrusage (int who, struct rusage *rusage) |
int | getrlimit (int resource, struct rlimit *rl) |
int | setrlimit (int resource, ACE_SETRLIMIT_TYPE *rl) |
int | sleep (u_int seconds) |
int | sleep (const ACE_Time_Value &tv) |
int | nanosleep (const struct timespec *requested, struct timespec *remaining=0) |
|
time_t | mktime (struct tm *timeptr) |
void | tzset (void) |
long | timezone (void) |
double | difftime (time_t t1, time_t t0) |
time_t | time (time_t *tloc=0) |
tm * | localtime (const time_t *clock) |
tm * | localtime_r (const time_t *clock, struct tm *res) |
tm * | gmtime (const time_t *clock) |
tm * | gmtime_r (const time_t *clock, struct tm *res) |
char * | asctime (const struct tm *tm) |
char * | asctime_r (const struct tm *tm, char *buf, int buflen) |
ACE_TCHAR * | ctime (const time_t *t) |
ACE_TCHAR * | ctime_r (const time_t *clock, ACE_TCHAR *buf, int buflen) |
size_t | strftime (char *s, size_t maxsize, const char *format, const struct tm *timeptr) |
|
int | msgctl (int msqid, int cmd, struct msqid_ds *) |
int | msgget (key_t key, int msgflg) |
int | msgrcv (int int_id, void *buf, size_t len, long type, int flags) |
int | msgsnd (int int_id, const void *buf, size_t len, int flags) |
|
int | madvise (caddr_t addr, size_t len, int advice) |
void * | mmap (void *addr, size_t len, int prot, int flags, ACE_HANDLE handle, off_t off=0, ACE_HANDLE *file_mapping=0, LPSECURITY_ATTRIBUTES sa=0, const ACE_TCHAR *file_mapping_name=0) |
int | mprotect (void *addr, size_t len, int prot) |
int | msync (void *addr, size_t len, int sync) |
int | munmap (void *addr, size_t len) |
|
int | recursive_mutex_init (ACE_recursive_thread_mutex_t *m, const ACE_TCHAR *name=0, ACE_mutexattr_t *arg=0, LPSECURITY_ATTRIBUTES sa=0) |
int | recursive_mutex_destroy (ACE_recursive_thread_mutex_t *m) |
int | recursive_mutex_lock (ACE_recursive_thread_mutex_t *m) |
int | recursive_mutex_trylock (ACE_recursive_thread_mutex_t *m) |
int | recursive_mutex_unlock (ACE_recursive_thread_mutex_t *m) |
int | recursive_mutex_cond_unlock (ACE_recursive_thread_mutex_t *m, ACE_recursive_mutex_state &state) |
void | recursive_mutex_cond_relock (ACE_recursive_thread_mutex_t *m, ACE_recursive_mutex_state &state) |
|
int | mutex_init (ACE_mutex_t *m, int type=ACE_DEFAULT_SYNCH_TYPE, const char *name=0, ACE_mutexattr_t *arg=0, LPSECURITY_ATTRIBUTES sa=0) |
int | mutex_init (ACE_mutex_t *m, int type, const wchar_t *name, ACE_mutexattr_t *arg=0, LPSECURITY_ATTRIBUTES sa=0) |
int | mutex_destroy (ACE_mutex_t *m) |
int | mutex_lock (ACE_mutex_t *m) |
| Win32 note: Abandoned mutexes are not treated differently. 0 is returned since the calling thread does get the ownership. More...
|
int | mutex_lock (ACE_mutex_t *m, int &abandoned) |
| This method is only implemented for Win32. For abandoned mutexes, <abandoned> is set to 1 and 0 is returned. More...
|
int | mutex_lock (ACE_mutex_t *m, const ACE_Time_Value &timeout) |
| This method attempts to acquire a lock, but gives up if the lock has not been acquired by the given time. More...
|
int | mutex_lock (ACE_mutex_t *m, const ACE_Time_Value *timeout) |
| If <timeout> == 0, calls <ACE_OS::mutex_lock(m)>. More...
|
int | mutex_trylock (ACE_mutex_t *m) |
| Win32 note: Abandoned mutexes are not treated differently. 0 is returned since the calling thread does get the ownership. More...
|
int | mutex_trylock (ACE_mutex_t *m, int &abandoned) |
| This method is only implemented for Win32. For abandoned mutexes, <abandoned> is set to 1 and 0 is returned. More...
|
int | mutex_unlock (ACE_mutex_t *m) |
|
int | thread_mutex_init (ACE_thread_mutex_t *m, int type=ACE_DEFAULT_SYNCH_TYPE, const char *name=0, ACE_mutexattr_t *arg=0) |
int | thread_mutex_init (ACE_thread_mutex_t *m, int type, const wchar_t *name, ACE_mutexattr_t *arg=0) |
int | thread_mutex_destroy (ACE_thread_mutex_t *m) |
int | thread_mutex_lock (ACE_thread_mutex_t *m) |
int | thread_mutex_lock (ACE_thread_mutex_t *m, const ACE_Time_Value &timeout) |
int | thread_mutex_lock (ACE_thread_mutex_t *m, const ACE_Time_Value *timeout) |
int | thread_mutex_trylock (ACE_thread_mutex_t *m) |
int | thread_mutex_unlock (ACE_thread_mutex_t *m) |
|
int | access (const char *path, int amode) |
int | access (const wchar_t *path, int amode) |
int | close (ACE_HANDLE handle) |
ACE_HANDLE | creat (const ACE_TCHAR *filename, mode_t mode) |
ACE_HANDLE | dup (ACE_HANDLE handle) |
int | dup2 (ACE_HANDLE oldfd, ACE_HANDLE newfd) |
int | fattach (int handle, const char *path) |
long | filesize (ACE_HANDLE handle) |
long | filesize (const ACE_TCHAR *handle) |
int | getmsg (ACE_HANDLE handle, struct strbuf *ctl, struct strbuf *data, int *flags) |
int | getpmsg (ACE_HANDLE handle, struct strbuf *ctl, struct strbuf *data, int *band, int *flags) |
int | ioctl (ACE_HANDLE handle, int cmd, void *=0) |
| UNIX-style <ioctl>. More...
|
int | ioctl (ACE_HANDLE socket, u_long io_control_code, void *in_buffer_p, u_long in_buffer, void *out_buffer_p, u_long out_buffer, u_long *bytes_returned, ACE_OVERLAPPED *overlapped, ACE_OVERLAPPED_COMPLETION_FUNC func) |
| QoS-enabled <ioctl>. More...
|
int | ioctl (ACE_HANDLE socket, u_long io_control_code, ACE_QoS &ace_qos, u_long *bytes_returned, void *buffer_p=0, u_long buffer=0, ACE_OVERLAPPED *overlapped=0, ACE_OVERLAPPED_COMPLETION_FUNC func=0) |
| QoS-enabled <ioctl> when the I/O control code is either SIO_SET_QOS or SIO_GET_QOS. More...
|
int | isastream (ACE_HANDLE handle) |
int | isatty (int handle) |
int | isatty (ACE_HANDLE handle) |
off_t | lseek (ACE_HANDLE handle, off_t offset, int whence) |
ACE_HANDLE | open (const char *filename, int mode, int perms=ACE_DEFAULT_OPEN_PERMS, LPSECURITY_ATTRIBUTES sa=0) |
| The O_APPEND flag is only partly supported on Win32. If you specify O_APPEND, then the file pointer will be positioned at the end of the file initially during open, but it is not re-positioned at the end prior to each write, as specified by POSIX. This is generally good enough for typical situations, but it is ``not quite right'' in its semantics. More...
|
ACE_HANDLE | open (const wchar_t *filename, int mode, int perms=ACE_DEFAULT_OPEN_PERMS, LPSECURITY_ATTRIBUTES sa=0) |
int | putmsg (ACE_HANDLE handle, const struct strbuf *ctl, const struct strbuf *data, int flags) |
int | putpmsg (ACE_HANDLE handle, const struct strbuf *ctl, const struct strbuf *data, int band, int flags) |
ssize_t | read (ACE_HANDLE handle, void *buf, size_t len) |
ssize_t | read (ACE_HANDLE handle, void *buf, size_t len, ACE_OVERLAPPED *) |
ssize_t | read_n (ACE_HANDLE handle, void *buf, size_t len, size_t *bytes_transferred=0) |
| Receive <len> bytes into <buf> from <handle> (uses the <ACE_OS::read> call, which uses the <read> system call on UNIX and the <ReadFile> call on Win32). More...
|
int | readlink (const char *path, char *buf, size_t bufsiz) |
ssize_t | pread (ACE_HANDLE handle, void *buf, size_t nbyte, off_t offset) |
int | recvmsg (ACE_HANDLE handle, struct msghdr *msg, int flags) |
int | sendmsg (ACE_HANDLE handle, const struct msghdr *msg, int flags) |
ssize_t | write (ACE_HANDLE handle, const void *buf, size_t nbyte) |
ssize_t | write (ACE_HANDLE handle, const void *buf, size_t nbyte, ACE_OVERLAPPED *) |
ssize_t | write_n (ACE_HANDLE handle, const void *buf, size_t len, size_t *bytes_transferred=0) |
| Send <len> bytes from <buf> to <handle> (uses the <ACE_OS::write> calls, which is uses the <write> system call on UNIX and the <WriteFile> call on Win32). More...
|
ssize_t | pwrite (ACE_HANDLE handle, const void *buf, size_t nbyte, off_t offset) |
ssize_t | readv (ACE_HANDLE handle, iovec *iov, int iovlen) |
ssize_t | writev (ACE_HANDLE handle, const iovec *iov, int iovcnt) |
ssize_t | recvv (ACE_HANDLE handle, iovec *iov, int iovlen) |
ssize_t | sendv (ACE_HANDLE handle, const iovec *iov, int iovcnt) |
|
int | select (int width, fd_set *rfds, fd_set *wfds=0, fd_set *efds=0, const ACE_Time_Value *tv=0) |
int | select (int width, fd_set *rfds, fd_set *wfds, fd_set *efds, const ACE_Time_Value &tv) |
int | poll (struct pollfd *pollfds, u_long len, const ACE_Time_Value *tv=0) |
int | poll (struct pollfd *pollfds, u_long len, const ACE_Time_Value &tv) |
int | pipe (ACE_HANDLE handles[]) |
ACE_HANDLE | shm_open (const ACE_TCHAR *filename, int mode, int perms=0, LPSECURITY_ATTRIBUTES sa=0) |
int | shm_unlink (const ACE_TCHAR *path) |
|
mode_t | umask (mode_t cmask) |
int | chdir (const char *path) |
int | chdir (const wchar_t *path) |
int | mkdir (const ACE_TCHAR *path, mode_t mode=ACE_DEFAULT_DIR_PERMS) |
int | mkfifo (const ACE_TCHAR *file, mode_t mode=ACE_DEFAULT_FILE_PERMS) |
ACE_TCHAR * | mktemp (ACE_TCHAR *t) |
ACE_HANDLE | mkstemp (ACE_TCHAR *t) |
ACE_TCHAR * | getcwd (ACE_TCHAR *, size_t) |
int | rename (const ACE_TCHAR *old_name, const ACE_TCHAR *new_name, int flags=-1) |
int | unlink (const ACE_TCHAR *path) |
ACE_TCHAR * | tempnam (const ACE_TCHAR *dir=0, const ACE_TCHAR *pfx=0) |
|
int | rand (void) |
int | rand_r (ACE_RANDR_TYPE &seed) |
void | srand (u_int seed) |
|
int | rwlock_init (ACE_rwlock_t *rw, int type=ACE_DEFAULT_SYNCH_TYPE, const ACE_TCHAR *name=0, void *arg=0) |
int | rwlock_destroy (ACE_rwlock_t *rw) |
int | rw_rdlock (ACE_rwlock_t *rw) |
int | rw_wrlock (ACE_rwlock_t *rw) |
int | rw_tryrdlock (ACE_rwlock_t *rw) |
int | rw_trywrlock (ACE_rwlock_t *rw) |
int | rw_trywrlock_upgrade (ACE_rwlock_t *rw) |
int | rw_unlock (ACE_rwlock_t *rw) |
|
int | event_init (ACE_event_t *event, int manual_reset=0, int initial_state=0, int type=ACE_DEFAULT_SYNCH_TYPE, const char *name=0, void *arg=0, LPSECURITY_ATTRIBUTES sa=0) |
int | event_init (ACE_event_t *event, int manual_reset, int initial_state, int type, const wchar_t *name, void *arg=0, LPSECURITY_ATTRIBUTES sa=0) |
int | event_destroy (ACE_event_t *event) |
int | event_wait (ACE_event_t *event) |
int | event_timedwait (ACE_event_t *event, ACE_Time_Value *timeout, int use_absolute_time=1) |
int | event_signal (ACE_event_t *event) |
int | event_pulse (ACE_event_t *event) |
int | event_reset (ACE_event_t *event) |
|
int | sema_destroy (ACE_sema_t *s) |
int | sema_init (ACE_sema_t *s, u_int count, int type=ACE_DEFAULT_SYNCH_TYPE, const char *name=0, void *arg=0, int max=0x7fffffff, LPSECURITY_ATTRIBUTES sa=0) |
int | sema_init (ACE_sema_t *s, u_int count, int type, const wchar_t *name, void *arg=0, int max=0x7fffffff, LPSECURITY_ATTRIBUTES sa=0) |
int | sema_post (ACE_sema_t *s) |
int | sema_post (ACE_sema_t *s, u_int release_count) |
int | sema_trywait (ACE_sema_t *s) |
int | sema_wait (ACE_sema_t *s) |
int | sema_wait (ACE_sema_t *s, ACE_Time_Value &tv) |
int | sema_wait (ACE_sema_t *s, ACE_Time_Value *tv) |
|
int | semctl (int int_id, int semnum, int cmd, semun) |
int | semget (key_t key, int nsems, int flags) |
int | semop (int int_id, struct sembuf *sops, size_t nsops) |
|
int | sched_params (const ACE_Sched_Params &, ACE_id_t id=ACE_SELF) |
| Set scheduling parameters. An id of ACE_SELF indicates, e.g., set the parameters on the calling thread. More...
|
|
void * | shmat (int int_id, void *shmaddr, int shmflg) |
int | shmctl (int int_id, int cmd, struct shmid_ds *buf) |
int | shmdt (void *shmaddr) |
int | shmget (key_t key, int size, int flags) |
|
int | kill (pid_t pid, int signum) |
int | sigaction (int signum, const struct sigaction *nsa, struct sigaction *osa) |
int | sigaddset (sigset_t *s, int signum) |
int | sigdelset (sigset_t *s, int signum) |
int | sigemptyset (sigset_t *s) |
int | sigfillset (sigset_t *s) |
int | sigismember (sigset_t *s, int signum) |
ACE_SignalHandler | signal (int signum, ACE_SignalHandler) |
int | sigsuspend (const sigset_t *set) |
int | sigprocmask (int how, const sigset_t *nsp, sigset_t *osp) |
int | pthread_sigmask (int how, const sigset_t *nsp, sigset_t *osp) |
|
ACE_HANDLE | accept (ACE_HANDLE handle, struct sockaddr *addr, int *addrlen) |
| BSD-style <accept> (no QoS). More...
|
ACE_HANDLE | accept (ACE_HANDLE handle, struct sockaddr *addr, int *addrlen, const ACE_Accept_QoS_Params &qos_params) |
| QoS-enabled <accept>, which passes <qos_params> to <accept>. More...
|
int | connect (ACE_HANDLE handle, struct sockaddr *addr, int addrlen) |
| BSD-style <connect> (no QoS). More...
|
int | connect (ACE_HANDLE handle, const sockaddr *addr, int addrlen, const ACE_QoS_Params &qos_params) |
| QoS-enabled <connect>, which passes <qos_params> to <connect>. More...
|
int | bind (ACE_HANDLE s, struct sockaddr *name, int namelen) |
| BSD-style <accept> (no QoS). More...
|
int | closesocket (ACE_HANDLE s) |
| BSD-style <accept> (no QoS). More...
|
hostent * | gethostbyaddr (const char *addr, int length, int type) |
| BSD-style <accept> (no QoS). More...
|
hostent * | gethostbyname (const char *name) |
| BSD-style <accept> (no QoS). More...
|
hostent * | getipnodebyname (const char *name, int family, int flags=0) |
| BSD-style <accept> (no QoS). More...
|
hostent * | getipnodebyaddr (const void *src, size_t len, int family) |
| BSD-style <accept> (no QoS). More...
|
hostent * | gethostbyaddr_r (const char *addr, int length, int type, struct hostent *result, ACE_HOSTENT_DATA buffer, int *h_errnop) |
| BSD-style <accept> (no QoS). More...
|
hostent * | gethostbyname_r (const char *name, struct hostent *result, ACE_HOSTENT_DATA buffer, int *h_errnop) |
| BSD-style <accept> (no QoS). More...
|
int | getpeername (ACE_HANDLE handle, struct sockaddr *addr, int *addrlen) |
| BSD-style <accept> (no QoS). More...
|
protoent * | getprotobyname (const char *name) |
| BSD-style <accept> (no QoS). More...
|
protoent * | getprotobyname_r (const char *name, struct protoent *result, ACE_PROTOENT_DATA buffer) |
| BSD-style <accept> (no QoS). More...
|
protoent * | getprotobynumber (int proto) |
| BSD-style <accept> (no QoS). More...
|
protoent * | getprotobynumber_r (int proto, struct protoent *result, ACE_PROTOENT_DATA buffer) |
| BSD-style <accept> (no QoS). More...
|
servent * | getservbyname (const char *svc, const char *proto) |
| BSD-style <accept> (no QoS). More...
|
servent * | getservbyname_r (const char *svc, const char *proto, struct servent *result, ACE_SERVENT_DATA buf) |
| BSD-style <accept> (no QoS). More...
|
int | getsockname (ACE_HANDLE handle, struct sockaddr *addr, int *addrlen) |
| BSD-style <accept> (no QoS). More...
|
int | getsockopt (ACE_HANDLE handle, int level, int optname, char *optval, int *optlen) |
| BSD-style <accept> (no QoS). More...
|
unsigned long | inet_addr (const char *name) |
| BSD-style <accept> (no QoS). More...
|
char * | inet_ntoa (const struct in_addr addr) |
| BSD-style <accept> (no QoS). More...
|
int | inet_aton (const char *strptr, struct in_addr *addr) |
| BSD-style <accept> (no QoS). More...
|
const char * | inet_ntop (int family, const void *addrptr, char *strptr, size_t len) |
| BSD-style <accept> (no QoS). More...
|
int | inet_pton (int family, const char *strptr, void *addrptr) |
| BSD-style <accept> (no QoS). More...
|
int | enum_protocols (int *protocols, ACE_Protocol_Info *protocol_buffer, u_long *buffer_length) |
| Retrieve information about available transport protocols installed on the local machine. More...
|
ACE_HANDLE | join_leaf (ACE_HANDLE socket, const sockaddr *name, int namelen, const ACE_QoS_Params &qos_params) |
| Joins a leaf node into a QoS-enabled multi-point session. More...
|
int | listen (ACE_HANDLE handle, int backlog) |
| BSD-style <accept> (no QoS). More...
|
int | recv (ACE_HANDLE handle, char *buf, size_t len, int flags=0) |
| BSD-style <accept> (no QoS). More...
|
int | recvfrom (ACE_HANDLE handle, char *buf, size_t len, int flags, struct sockaddr *addr, int *addrlen) |
| BSD-style <accept> (no QoS). More...
|
int | recvfrom (ACE_HANDLE handle, iovec *buffers, int buffer_count, size_t &number_of_bytes_recvd, int &flags, struct sockaddr *addr, int *addrlen, ACE_OVERLAPPED *overlapped, ACE_OVERLAPPED_COMPLETION_FUNC func) |
| BSD-style <accept> (no QoS). More...
|
int | send (ACE_HANDLE handle, const char *buf, size_t len, int flags=0) |
| BSD-style <accept> (no QoS). More...
|
int | sendto (ACE_HANDLE handle, const char *buf, size_t len, int flags, const struct sockaddr *addr, int addrlen) |
| BSD-style <accept> (no QoS). More...
|
int | sendto (ACE_HANDLE handle, const iovec *buffers, int buffer_count, size_t &number_of_bytes_sent, int flags, const struct sockaddr *addr, int addrlen, ACE_OVERLAPPED *overlapped, ACE_OVERLAPPED_COMPLETION_FUNC func) |
| BSD-style <accept> (no QoS). More...
|
int | setsockopt (ACE_HANDLE handle, int level, int optname, const char *optval, int optlen) |
| Manipulate the options associated with a socket. More...
|
int | shutdown (ACE_HANDLE handle, int how) |
| BSD-style <accept> (no QoS). More...
|
ACE_HANDLE | socket (int protocol_family, int type, int proto) |
| Create a BSD-style socket (no QoS). More...
|
ACE_HANDLE | socket (int protocol_family, int type, int proto, ACE_Protocol_Info *protocolinfo, ACE_SOCK_GROUP g, u_long flags) |
| Create a QoS-enabled socket. If the OS platform doesn't support QoS-enabled <socket> then the BSD-style <socket> is called. More...
|
int | socketpair (int domain, int type, int protocol, ACE_HANDLE sv[2]) |
| BSD-style <accept> (no QoS). More...
|
int | socket_init (int version_high=1, int version_low=1) |
| Initialize WinSock before first use (e.g., when a DLL is first loaded or the first use of a socket() call. More...
|
int | socket_fini (void) |
| Finalize WinSock after last use (e.g., when a DLL is unloaded). More...
|
|
void | setpwent (void) |
void | endpwent (void) |
passwd * | getpwent (void) |
passwd * | getpwnam (const char *user) |
passwd * | getpwnam_r (const char *name, struct passwd *pwent, char *buffer, int buflen) |
|
char * | compile (const char *instring, char *expbuf, char *endbuf) |
int | step (const char *str, char *expbuf) |
Static Public Attributes |
int | socket_initialized_ |
| Keeps track of whether we've already initialized WinSock... More...
|
Private Methods |
| ACE_CLASS_IS_NAMESPACE (ACE_OS) |
Static Private Methods |
ACE_EXIT_HOOK | set_exit_hook (ACE_EXIT_HOOK hook) |
| For use by ACE_Object_Manager only, to register its exit hook.. More...
|
void | fopen_mode_to_open_mode_converter (ACE_TCHAR x, int &hmode) |
| Translate fopen's mode char to open's mode. This helper function is here to avoid maintaining several pieces of identical code. More...
|
int | cond_timedwait_i (ACE_cond_t *cv, ACE_mutex_t *m, ACE_Time_Value *) |
u_int | alarm_i (u_int secs) |
u_int | ualarm_i (u_int usecs, u_int interval=0) |
u_int | ualarm_i (const ACE_Time_Value &tv, const ACE_Time_Value &tv_interval=ACE_Time_Value::zero) |
int | sleep_i (u_int seconds) |
int | sleep_i (const ACE_Time_Value &tv) |
int | nanosleep_i (const struct timespec *requested, struct timespec *remaining=0) |
int | select_i (int width, fd_set *rfds, fd_set *wfds, fd_set *efds, const ACE_Time_Value *tv=0) |
int | select_i (int width, fd_set *rfds, fd_set *wfds, fd_set *efds, const ACE_Time_Value &tv) |
int | poll_i (struct pollfd *pollfds, u_long len, const ACE_Time_Value *tv=0) |
int | poll_i (struct pollfd *pollfds, u_long len, const ACE_Time_Value &tv) |
int | sema_wait_i (ACE_sema_t *s) |
int | sema_wait_i (ACE_sema_t *s, ACE_Time_Value &tv) |
int | sigtimedwait_i (const sigset_t *set, siginfo_t *info, const ACE_Time_Value *timeout) |
ACE_Time_Value | gettimeofday_i (void) |
Static Private Attributes |
ACE_EXIT_HOOK | exit_hook_ = 0 |
| Function that is called by <ACE_OS::exit>, if non-null. More...
|
OSVERSIONINFO | win32_versioninfo_ |
HINSTANCE | win32_resource_module_ |
Friends |
class | ACE_Timeout_Manager |
class | ACE_OS_Object_Manager |
| Allow the ACE_OS_Object_Manager to call set_exit_hook. More...
|
This class encapsulates the differences between various OS platforms. When porting ACE to a new platform, this class is the place to focus on. Once this file is ported to a new platform, pretty much everything else comes for "free." See <www.cs.wustl.edu/~schmidt/ACE_wrappers/etc/ACE-porting.html> for instructions on porting ACE. Please see the README file in this directory for complete information on the meaning of the various macros.