This page summarizes the 307 functions, 38 structures, and 2 unions included in Advanced UNIX Programming, 2nd Edition.
Note that signal and sigset are listed as variables due to a parsing problem with Doxygen, which was used to generate this page.
Definition in file SUS_Summary.
Go to the source code of this file.
Compounds | |
struct | addrinfo |
struct | aiocb |
struct | dirent |
struct | flock |
struct | group |
struct | hostent |
struct | if_nameindex |
struct | iovec |
struct | ipc_perm |
struct | itimerspec |
struct | itimerval |
struct | mq_attr |
struct | msg |
struct | msghdr |
struct | msqid_ds |
struct | netent |
struct | passwd |
struct | pollfd |
struct | protoent |
struct | rlimit |
struct | rusage |
struct | sembuf |
struct | semid_ds |
union | semun |
struct | servent |
struct | sigaction |
struct | sigevent |
struct | siginfo_t |
union | sigval |
struct | SimpleSem |
struct | sockaddr_in |
struct | sockaddr_in6 |
struct | sockaddr_un |
struct | stat |
struct | statvfs |
struct | termios |
struct | timespec |
struct | timeval |
struct | tm |
struct | tms |
struct | utimbuf |
Functions | |
void | FD_CLR (int fd, fd_set *fdset) |
int | FD_ISSET (int fd, fd_set *fdset) |
void | FD_SET (int fd, fd_set *fdset) |
void | FD_ZERO (fd_set *fdset) |
void | _Exit (int status) |
void | _exit (int status) |
void | _longjmp (jmp_buf loc_info, int val) |
int | _setjmp (jmp_buf loc_info) |
void | abort (void) |
int | accept (int socket_fd, struct sockaddr *sa, socklen_t *sa_len) |
int | access (const char *path, int what) |
int | aio_cancel (int fd, struct aiocb *aiocbp) |
int | aio_error (const struct aiocb *aiocbp) |
int | aio_fsync (int op, struct aiocb *aiocbp) |
int | aio_read (struct aiocb *aiocbp) |
ssize_t | aio_return (struct aiocb *aiocbp) |
int | aio_suspend (const struct aiocb *const list[], int cbcnt, const struct timespec *timeout) |
int | aio_write (struct aiocb *aiocbp) |
unsigned | alarm (unsigned secs) |
char * | asctime (const struct tm *tmbuf) |
int | atexit (void(*fcn)(void)) |
int | bind (int socket_fd, const struct sockaddr *sa, socklen_t sa_len) |
speed_t | cfgetispeed (const struct termios *tp) |
speed_t | cfgetospeed (const struct termios *tp) |
int | cfsetispeed (struct termios *tp, speed_t speed) |
int | cfsetospeed (struct termios *tp, speed_t speed) |
int | chdir (const char *path) |
int | chmod (const char *path, mode_t mode) |
int | chown (const char *path, uid_t uid, gid_t gid) |
int | chroot (const char *path) |
clock_t | clock (void) |
int | clock_getcpuclockid (pid_t pid, clockid_t *clock_id) |
int | clock_getres (clockid_t clock_id, struct timespec *res) |
int | clock_gettime (clockid_t clock_id, struct timespec *tp) |
int | clock_nanosleep (clockid_t clock_id, int flags, const struct timespec *nsecs, struct timespec *remain) |
int | clock_settime (clockid_t clock_id, const struct timespec *tp) |
int | close (int fd) |
int | closedir (DIR *dirp) |
size_t | confstr (int name, char *buf, size_t len) |
int | connect (int socket_fd, const struct sockaddr *sa, socklen_t sa_len) |
int | creat (const char *path, mode_t perms) |
char * | ctermid (char *buf) |
char * | ctime (const time_t *t) |
double | difftime (time_t time1, time_t time0) |
int | dup (int fd) |
int | dup2 (int fd, int fd2) |
void | endhostent (void) |
void | endnetent (void) |
void | endprotoent (void) |
void | endservent (void) |
int | execl (const char *path, const char *arg0, const char *arg1,..., (char *)NULL) |
int | execle (const char *path, const char *arg0, const char *arg1,..., (char *)NULL, char *const envv[]) |
int | execlp (const char *file, const char *arg0, const char *arg1,..., (char *)NULL) |
int | execv (const char *path, char *const argv[]) |
int | execve (const char *path, char *const argv[], char *const envv[]) |
int | execvp (const char *file, char *const argv[]) |
void | exit (int status) |
int | fchdir (int fd) |
int | fchmod (int fd, mode_t mode) |
int | fchown (int fd, uid_t uid, gid_t gid) |
int | fcntl (int fd, int op,...) |
int | fdatasync (int fd) |
pid_t | fork (void) |
long | fpathconf (int fd, int name) |
void | freeaddrinfo (struct addrinfo *infop) |
int | fstat (int fd, struct stat *buf) |
int | fstatvfs (int fd, struct statvfs *buf) |
int | fsync (int fd) |
key_t | ftok (const char *path, int id) |
int | ftruncate (int fd, off_t length) |
const char * | gai_strerror (int code) |
int | getaddrinfo (const char *nodename, const char *servname, const struct addrinfo *hint, struct addrinfo **infop) |
char * | getcwd (char *buf, size_t bufsize) |
tm * | getdate (const char *s) |
gid_t | getegid (void) |
char * | getenv (const char *var) |
uid_t | geteuid (void) |
gid_t | getgid (void) |
group * | getgrgid (gid_t gid) |
hostent * | gethostbyaddr (const void *addr, socklen_t len, int family) |
hostent * | gethostbyname (const char *nodename,) |
hostent * | gethostent (void) |
long | gethostid (void) |
int | gethostname (char *name, size_t namelen) |
int | getitimer (int which, struct itimerval *val) |
char * | getlogin (void) |
int | getnameinfo (const struct sockaddr *sa, socklen_t sa_len, char *nodename, socklen_t nodelen, char *servname, socklen_t servlen, unsigned flags) |
netent * | getnetbyaddr (uint32_t net, int type) |
netent * | getnetbyname (const char *name) |
netent * | getnetent (void) |
int | getpeername (int socket_fd, struct sockaddr *sa, socklen_t *sa_len) |
pid_t | getpgid (pid_t pid) |
pid_t | getpid (void) |
pid_t | getppid (void) |
protoent * | getprotobyname (const char *name) |
protoent * | getprotobynumber (int proto) |
protoent * | getprotoent (void) |
passwd * | getpwuid (uid_t uid) |
int | getrlimit (int resource, struct rlimit *rlp) |
int | getrusage (int who, struct rusage *r_usage) |
servent * | getservbyname (const char *name, const char *proto) |
servent * | getservbyport (int port, const char *proto) |
servent * | getservent (void) |
pid_t | getsid (pid_t pid) |
int | getsockname (int socket_fd, struct sockaddr *sa, socklen_t *sa_len) |
int | getsockopt (int socket, int level, int option, const void *value, socklen_t *value_len) |
int | gettimeofday (struct timeval *tvalbuf, void *dummy) |
uid_t | getuid (void) |
tm * | gmtime (const time_t *t) |
int | grantpt (int fd) |
uint32_t | htonl (uint32_t hostnum) |
uint16_t | htons (uint16_t hostnum) |
void | if_freenameindex (struct if_nameindex *ptr) |
char * | if_indextoname (unsigned ifindex, char *ifname) |
if_nameindex * | if_nameindex (void) |
unsigned | if_nametoindex (const char *ifname) |
in_addr_t | inet_addr (const char *cp) |
char * | inet_ntoa (struct in_addr in) |
const char * | inet_ntop (int domain, const void *src, char *dst, socklen_t dst_len) |
int | inet_pton (int domain, const char *src, void *dst) |
int | ioctl (int fd, int req,...) |
int | isatty (int fd) |
int | kill (pid_t pid, int signum) |
int | killpg (pid_t pgrp, int signum) |
int | lchown (const char *path, uid_t uid, gid_t gid) |
int | link (const char *oldpath, const char *newpath) |
int | lio_listio (int mode, struct aiocb *const list[], int cbcnt, struct sigevent *sig) |
int | listen (int socket_fd, int backlog) |
tm * | localtime (const time_t *t) |
int | lockf (int fd, int op, off_t len) |
void | longjmp (jmp_buf loc_info, int val) |
off_t | lseek (int fd, off_t pos, int whence) |
int | lstat (const char *path, struct stat *buf) |
int | mkdir (const char *path, mode_t perms) |
int | mkfifo (const char *path, mode_t perms) |
int | mknod (const char *path, mode_t perms, dev_t dev) |
int | mkstemp (char *template) |
time_t | mktime (struct tm *tmbuf) |
void * | mmap (void *addr, size_t len, int prot, int flags, int fd, off_t off) |
int | mount (const char *source, const char *target, const char *type, unsigned long flags, const void *data) |
int | mq_close (mqd_t mqd) |
int | mq_getattr (mqd_t mqd, struct mq_attr *attr) |
int | mq_notify (mqd_t mqd, const struct sigevent *ep) |
mqd_t | mq_open (const char *name, int flags) |
ssize_t | mq_receive (mqd_t mqd, char *msg, size_t msgsize, unsigned *priorityp) |
int | mq_send (mqd_t mqd, const char *msg, size_t msgsize, unsigned priority) |
int | mq_setattr (mqd_t mqd, const struct mq_attr *attr, struct mq_attr *oldattr) |
ssize_t | mq_timedreceive (mqd_t mqd, char *msg, size_t msgsize, unsigned *priorityp const struct timespec *tmout) |
int | mq_timedsend (mqd_t mqd, const char *msg, size_t msgsize, unsigned priority const struct timespec *tmout) |
int | mq_unlink (const char *name) |
int | msgctl (int msqid, int cmd, struct msqid_ds *data) |
int | msgget (key_t key, int flags) |
ssize_t | msgrcv (int msqid, const void *msgp, size_t mtextsize, long msgtype, int flags) |
int | msgsnd (int msqid, const void *msgp, size_t msgsize, int flags) |
int | munmap (void *addr, size_t len) |
int | nanosleep (const struct timespec *nsecs, struct timespec *remain) |
int | nice (int incr) |
uint32_t | ntohl (uint32_t netnum) |
uint16_t | ntohs (uint16_t netnum) |
int | open (const char *path, int flags, mode_t perms) |
DIR * | opendir (const char *path) |
long | pathconf (const char *path, int name) |
int | pause (void) |
int | pipe (int pfd[2]) |
int | poll (struct pollfd fdinfo[], nfds_t nfds, int timeout) |
int | posix_openpt (int oflag) |
ssize_t | pread (int fd, void *buf, size_t nbytes off_t offset) |
int | pselect (int nfds, fd_set *readset, fd_set *writeset, fd_set *errorset, const struct timespec *timeout, const sigset_t *sigmask) |
int | pthread_cancel (pthread_t thread_id) |
void | pthread_cleanup_pop (int execute) |
void | pthread_cleanup_push (void(*handler)(void *), void *arg) |
int | pthread_cond_signal (pthread_cond_t *cond) |
int | pthread_cond_wait (pthread_cond_t *cond, pthread_mutex_t *mutex) |
int | pthread_create (pthread_t *thread_id, const pthread_attr_t *attr, void *(*start_fcn)(void *), void *arg) |
int | pthread_join (pthread_t thread_id, void **status_ptr) |
int | pthread_kill (pthread_t thread_id, int signum) |
int | pthread_mutex_lock (pthread_mutex_t *mutex) |
int | pthread_mutex_unlock (pthread_mutex_t *mutex) |
int | pthread_sigmask (int how, const sigset_t *set, sigset_t *oset) |
void | pthread_testcancel (void) |
char * | ptsname (int fd) |
int | putenv (char *string) |
ssize_t | pwrite (int fd, const void *buf, size_t nbytes off_t offset) |
int | raise (int signum) |
ssize_t | read (int fd, void *buf, size_t nbytes) |
dirent * | readdir (DIR *dirp) |
int | readdir_r (DIR *restrict dirp, struct dirent *entry, struct dirent **result) |
ssize_t | readlink (const char *path, char *buf, size_t bufsize) |
ssize_t | readv (int fd, const struct iovec *iov, int iovcnt) |
ssize_t | recv (int socket_fd, void *buffer, size_t length, int flags) |
ssize_t | recvfrom (int socket_fd, void *buffer, size_t length, int flags, struct sockaddr *sa, socklen_t *sa_len) |
ssize_t | recvmsg (int socket_fd, struct msghdr *message, int flags) |
int | rename (const char *oldpath, const char *newpath) |
void | rewinddir (DIR *dirp) |
int | rmdir (const char *path) |
void | seekdir (DIR *dirp, long loc) |
int | select (int nfds, fd_set *readset, fd_set *writeset, fd_set *errorset, struct timeval *timeout) |
int | sem_close (sem_t *sem) |
int | sem_destroy (sem_t *sem) |
int | sem_getvalue (sem_t *restrict sem, int *valuep) |
int | sem_init (sem_t *sem, int pshared, unsigned value) |
sem_t * | sem_open (const char *name, int flags) |
int | sem_post (sem_t *sem) |
int | sem_timedwait (sem_t *restrict sem, const struct timespec *time) |
int | sem_trywait (sem_t *sem) |
int | sem_unlink (const char *name) |
int | sem_wait (sem_t *sem) |
int | semctl (int semid, int semnum, int cmd, union semun arg) |
int | semget (key_t key, int nsems, int flags) |
int | semop (int semid, struct sembuf *sops, size_t nsops) |
ssize_t | send (int socket_fd, const void *data, size_t length, int flags) |
ssize_t | sendmsg (int socket_fd, const struct msghdr *message, int flags) |
ssize_t | sendto (int socket_fd, const void *message, size_t length, int flags, const struct sockaddr *sa, socklen_t sa_len) |
int | setegid (gid_t gid) |
int | setenv (const char *var, const char *val, int overwrite) |
int | seteuid (uid_t uid) |
int | setgid (gid_t gid) |
void | sethostent (int stayopen) |
int | setitimer (int which, const struct itimerval *val, struct itimerval *oval) |
int | setjmp (jmp_buf loc_info) |
void | setnetent (int stayopen) |
int | setpgid (pid_t pid, pid_t pgid) |
void | setprotoent (int stayopen) |
int | setrlimit (int resource, const struct rlimit *rlp) |
void | setservent (int stayopen) |
pid_t | setsid (void) |
int | setsockopt (int socket_fd, int level, int option, const void *value, socklen_t value_len) |
int | setuid (uid_t uid) |
int | shm_open (const char *name, int flags, mode_t perms) |
int | shm_unlink (const char *name) |
void * | shmat (int shmid, const void *shmaddr, int flags) |
int | shmctl (int shmid, int cmd, struct shmid_ds *data) |
int | shmdt (const void *shmaddr) |
int | shmget (key_t key, size_t size, int flags) |
int | shutdown (int socket_fd, int how) |
int | sigaction (int signum, const struct sigaction *act, struct sigaction *oact) |
int | sigaddset (sigset_t *set, int signum) |
int | sigaltstack (const stack_t *stack, stack_t *ostack) |
int | sigdelset (sigset_t *set, int signum) |
int | sigemptyset (sigset_t *set) |
int | sigfillset (sigset_t *set) |
int | sighold (int signum,) |
int | sigignore (int signum,) |
int | siginterrupt (int signum, int flag) |
int | sigismember (const sigset_t *set, int signum) |
void | siglongjmp (sigjmp_buf loc_info, int val) |
int | sigpause (int signum,) |
int | sigpending (sigset_t *set) |
int | sigprocmask (int how, const sigset_t *set, sigset_t *oset) |
int | sigqueue (pid_t pid, int signum, const union sigval value) |
int | sigrelse (int signum,) |
int | sigsetjmp (sigjmp_buf loc_info, int savemask) |
int | sigsuspend (const sigset_t *sigmask) |
int | sigtimedwait (const sigset_t *set, siginfo_t *info, const struct timespec *ts) |
int | sigwait (const sigset_t *set, int *signum) |
int | sigwaitinfo (const sigset_t *set, siginfo_t *info) |
unsigned | sleep (unsigned secs) |
int | sockatmark (int socket_fd,) |
int | socket (int domain, int type, int protocol) |
int | socketpair (int domain, int type, int protocol int socket_vector[2]) |
int | stat (const char *path, struct stat *buf) |
int | statvfs (const char *path struct statvfs *buf) |
size_t | strftime (char *buf, size_t bufsize, const char *format, const struct tm *tmbuf) |
char * | strptime (const char *s, const char *format, struct tm *tmbuf) |
int | symlink (const char *oldpath, const char *newpath) |
void | sync (void) |
long | sysconf (int name) |
int | system (const char *command) |
int | tcdrain (int fd) |
int | tcflow (int fd, int action) |
int | tcflush (int fd, int queue) |
int | tcgetattr (int fd, struct termios *tp) |
pid_t | tcgetpgrp (int fd) |
pid_t | tcgetsid (int fd) |
int | tcsendbreak (int fd, int duration) |
int | tcsetattr (int fd, int actions, const struct termios *tp) |
int | tcsetpgrp (int fd, pid_t pgid) |
long | telldir (DIR *dirp) |
time_t | time (time_t *t) |
int | timer_create (clockid_t clockid, struct sigevent *sig, timer_t *timer_id) |
int | timer_delete (timer_t timer_id) |
int | timer_getoverrun (timer_t timer_id) |
int | timer_gettime (timer_t timer_id, struct itimerspec *val) |
int | timer_settime (timer_t timer_id, int flags, const struct itimerspec *val, struct itimerspec *oval) |
clock_t | times (struct tms *buffer) |
int | truncate (const char *path, off_t length) |
char * | ttyname (int fd) |
int | ttyname_r (int fd, char *buf, size_t bufsize) |
void | tzset (void) |
long | ulimit (int cmd,...) |
mode_t | umask (mode_t cmask) |
int | umount (const char *target) |
int | uname (struct utsname *name) |
int | unlink (const char *path) |
int | unlockpt (int fd) |
int | unsetenv (const char *var) |
int | usleep (useconds_t usecs) |
int | utime (const char *path, const struct utimbuf *timbuf) |
pid_t | vfork (void) |
pid_t | wait (int *statusp,) |
int | waitid (idtype_t idtype, id_t id, siginfo_t *infop, int options) |
pid_t | waitpid (pid_t pid, int *statusp, int options) |
size_t | wcsftime (wchar_t *buf, size_t bufsize, const wchar_t *format, const struct tm *tmbuf) |
ssize_t | write (int fd, const void *buf, size_t nbytes) |
ssize_t | writev (int fd, const struct iovec *iov, int iovcnt) |
Variables | |
void(*)(int) | signal (int signum, void(*act)(int)) |
void(*)(int) | sigset (int signum, void(*act)(int)) |
int | daylight |
long | timezone |
char * | tzname [2] |
|
Referenced by edinvoke(), execute3(), fcn(), fd_check(), handler(), invoke(), main(), redirect(), and sig_thread(). |
|
|
|
|
|
|
|
|
|
Referenced by main(), run_server(), and ssi_wait_server(). |
|
W_OK write permission X_OK execute (search) permission F_OK test for existence
Referenced by access_test(), find_and_open_master(), and main(). |
|
|
|
Referenced by asynchronous(), and Ux::Aio::error(). |
|
|
|
Referenced by asynchronous(). |
|
|
|
Referenced by asynchronous(). |
|
|
|
Referenced by Ux::Timer::alarm(), aup_sleep(), main(), posixsem_test(), and sysvsem_test(). |
|
|
|
Referenced by ec_push(), and process_test(). |
|
Referenced by main(), run_client(), run_server(), and ssi_open(). |
|
Referenced by Ux::Termios::cfgetispeed(). |
|
Referenced by Ux::Termios::cfgetospeed(). |
|
|
|
|
|
Referenced by builtin(), do_dir(), getcwdx(), main(), and process_test(). |
|
|
|
|
|
Referenced by process_test(). |
|
Referenced by Ux::RealtimeTimer::create(), getaddr(), Ux::Clock::getcpuclockid(), and main(). |
|
|
|
|
|
|
|
|
|
|
|
Referenced by backward(), backward0(), backward2(), Bclose(), clients_close_all(), copy(), copy2(), copy2a(), do_dir(), edinvoke(), ev_close(), exec_redirected(), fcn(), fcntl_example(), file_ctime_test(), find_and_open_master(), fsort(), fsort0(), ftruncate_test(), getaddr(), getcwdx(), invoke(), junk(), lock(), main(), main1(), pcsync_end(), pipewrite(), pipewrite2(), pipewrite2bug(), process1(), process2(), pt_close_master(), pt_close_slave(), pt_open_master(), pt_open_slave(), pwrite_test(), readany_test(), readany_test2(), readany_test3(), redirect(), rmdir_test(), run_client(), run_server(), scatter(), setup_fdset(), showpginfo(), SimpleSemOpen(), smi_close_fifo(), smi_close_pshm(), smi_open_pshm(), smi_open_shm(), ssi_close(), ssi_close_fd(), synctest(), try6(), who_wc(), and who_wc2(). |
|
Referenced by do_dir(), getcwdx(), readdir_r_test(), and readdir_test(). |
|
Referenced by main(). |
|
Referenced by main(), main1(), run_client(), and ssi_open(). |
|
|
|
|
|
Referenced by file_ctime_test(), and send_header_OK(). |
|
Referenced by Ux::TimeSec::diff(), Ux::Timet::difftime(), print_date(), and test_setblock(). |
|
|
|
Referenced by edinvoke(), exec_redirected(), fsort(), fsort0(), pipewrite2(), pipewrite2bug(), redirect(), who_wc(), and who_wc2(). |
|
Referenced by hostdb(). |
|
Referenced by netdb(). |
|
|
|
Referenced by servdb(). |
|
Referenced by exectest(), and junk(). |
|
|
|
Referenced by edinvoke(), fsort(), fsort0(), pipewrite(), pipewrite2(), pipewrite2bug(), process_test(), who_wc(), and who_wc2(). |
|
Referenced by exec_path(). |
|
|
|
Referenced by exec_redirected(), execute3(), Ux::Process::execvpe(), invoke(), and main(). |
|
Referenced by a1(), a3(), command(), display(), ec_mutex(), forkbuf(), get_and_incr_x(), init(), main(), main1(), process(), process1(), process2(), run_client(), run_server(), setup_fdset(), setup_posix_msg(), setup_posix_sem(), setup_process(), setup_signal(), setup_systemv_msg(), setup_systemv_sem(), socket_test_inet(), socket_test_unix(), sorter(), syserr(), tc_keystroke(), try1(), try2(), try3(), try4(), try5(), and try6(). |
|
|
|
Referenced by pt_open_slave(). |
|
|
|
Referenced by fcntl_example(), fd_check(), init(), junk(), pipe_access_mode(), and setblock(). |
|
Referenced by run_server(), and ssi_close_fd(). |
|
Referenced by main(), readany2(), readbuf(), run_server(), ssi_close(), ssi_wait_server(), and thread_fdset(). |
|
Referenced by main(), pcsync_wait_for_parent(), pt_wait_master(), readany2(), readbuf(), run_server(), setup_fdset(), ssi_open(), and ssi_wait_server(). |
|
Referenced by main(), pcsync_wait_for_parent(), pt_wait_master(), readany2(), readbuf(), run_server(), setup_fdset(), and ssi_open(). |
|
Referenced by main(). |
|
Referenced by edinvoke(), execute3(), forkbuf(), forktest(), fsort(), fsort0(), invoke(), main(), pipewrite(), pipewrite2(), pipewrite2bug(), process_test(), run_client(), setup_fdset(), setup_posix_msg(), setup_posix_sem(), setup_process(), setup_signal(), setup_systemv_msg(), setup_systemv_sem(), socket_test_inet(), socket_test_unix(), try1(), try2(), try3(), try4(), try5(), try6(), who_wc(), and who_wc2(). |
|
Referenced by fpathconf_test(), and tc_setraw(). |
|
Referenced by make_sockaddr(). |
|
Referenced by check_parent(), and file_ctime_test(). |
|
|
|
Referenced by main(). |
|
Referenced by getaddr(), main(), setup_systemv_msg(), setup_systemv_sem(), SimpleSemOpen(), SimpleSemRemove(), smi_open_shm(), sysvmsg_test(), sysvsem_test(), and sysvshm_test(). |
|
Referenced by ftruncate_test(), main(), and smi_open_pshm(). |
|
Referenced by a3(), syserrmsgline(), syserrmsgtype(), and Ux::Error::what(). |
|
Referenced by a1(), a3(), main(), and make_sockaddr(). |
|
Referenced by get_cwd(), main(), and process_test(). |
|
|
|
Referenced by Ux::Process::getegid(), and main(). |
|
Referenced by builtin(), execvp2(), Ux::Process::getenv(), and process_env_test(). |
|
Referenced by Ux::Process::geteuid(), and main(). |
|
Referenced by Ux::Process::getgid(), and main(). |
|
Referenced by Ux::System::getgrgid(), main(), and print_group(). |
|
Referenced by gethostbyaddr_ex(). |
|
Referenced by gethostbyname_ex(). |
|
Referenced by Ux::Netdb::gethostent(), and hostdb(). |
|
Referenced by Ux::System::gethostid(), and main(). |
|
Referenced by main(). |
|
|
|
|
|
Referenced by getnameinfo_ex(). |
|
Referenced by Ux::Netdb::getnetbyaddr(). |
|
Referenced by Ux::Netdb::getnetbyname(). |
|
Referenced by Ux::Netdb::getnetent(), and netdb(). |
|
|
|
Referenced by showpginfo(). |
|
Referenced by Ux::Process::getpid(), gp(), logfmt(), main(), msg_check(), run_client(), setup_fdset(), setup_posix_msg(), setup_posix_sem(), setup_signal(), setup_systemv_msg(), setup_systemv_sem(), showpginfo(), smi_close_fifo(), smi_open_fifo(), smi_open_mq(), smi_open_pshm(), smi_send_getaddr_pshm(), smi_send_release_fifo(), and testlock(). |
|
Referenced by Ux::Process::getppid(), setup_signal(), and showpginfo(). |
|
Referenced by Ux::Netdb::getprotobyname(). |
|
Referenced by Ux::Netdb::getprotobynumber(). |
|
Referenced by Ux::Netdb::getprotoent(), main(), and protodb(). |
|
Referenced by Ux::System::getpwuid(), main(), and print_owner(). |
|
Referenced by main(), process_test(), and showlimit(). |
|
Referenced by process_test(). |
|
Referenced by Ux::Netdb::getservbyname(). |
|
Referenced by Ux::Netdb::getservbyport(). |
|
Referenced by Ux::Netdb::getservent(), and servdb(). |
|
Referenced by showpginfo(). |
|
|
|
Referenced by show(). |
|
Referenced by get_rel_time(), and main(). |
|
Referenced by Ux::Process::getuid(), and main(). |
|
|
|
Referenced by pt_open_master(). |
|
Referenced by Ux::Netdb::htonl(), main1(), and msg_check(). |
|
Referenced by getnameinfo_ex(), Ux::Netdb::htons(), main(), and main1(). |
|
Referenced by ifdb(). |
|
|
|
Referenced by ifdb(). |
|
|
|
Referenced by gethostbyaddr_ex(), getnameinfo_ex(), and main(). |
|
Referenced by display_hostent(), and main(). |
|
Referenced by cvt(). |
|
Referenced by cvt(). |
|
Referenced by pt_open_slave(). |
|
Referenced by Ux::Terminal::isatty(). |
|
Referenced by main(), pcsync_unblock_children(), setup_signal(), try2(), try3(), try4(), and try5(). |
|
|
|
|
|
Referenced by add_link(), display(), and main(). |
|
|
|
Referenced by main(), run_server(), and ssi_open(). |
|
Referenced by logfmt(), and print_date(). |
|
Referenced by main(), process2(), and store(). |
|
Referenced by fcn2(). |
|
Referenced by backward(), backward0(), backward2(), file_ctime_test(), junk(), main(), process2(), pwrite_test(), scatter(), and store(). |
|
Referenced by check_parent(), do_entry(), getcwdx(), ls_one(), main(), and runtest(). |
|
Referenced by main(), and rmdir_test(). |
|
Referenced by main(), and smi_open_fifo(). |
|
|
|
Referenced by junk(). |
|
|
|
Referenced by get_client(), and smi_open_pshm(). |
|
|
|
|
|
|
|
|
|
const char *name, POSIX IPC name int flags, flags (including O_CREAT) mode_t perms, permissions struct mq_attr *attr attributes (or NULL) );
|
|
|
|
|
|
|
|
|
|
|
|
|
|
Referenced by main(), and setup_systemv_msg(). |
|
Referenced by main(), and setup_systemv_msg(). |
|
Referenced by thread_svmsg(). |
|
Referenced by main(), and setup_systemv_msg(). |
|
Referenced by smi_close_pshm(). |
|
Referenced by thread_heartbeat(). |
|
Referenced by main(), and process_test(). |
|
Referenced by msg_check(), and Ux::Netdb::ntohl(). |
|
Referenced by main(), and Ux::Netdb::ntohs(). |
|
Referenced by asynchronous(), backward(), backward0(), backward2(), Bopen_internal(), buildfile(), copy(), copy2(), copy2a(), dir_read_test(), do_dir(), ev_creat(), ev_open(), fcn(), fcntl_example(), file_ctime_test(), find_and_open_master(), fsort(), fsort0(), ftruncate_test(), getaddr(), getcwdx(), gp(), junk(), lock(), main(), process1(), process2(), pt_open_slave(), pwrite_test(), readany_test(), readany_test2(), readany_test3(), redirect(), rmdir_test(), scatter(), showpginfo(), SimpleSemOpen(), smi_open_fifo(), smi_open_shm(), smi_receive_getaddr_fifo(), synchronous(), synctest(), and temp_open(). |
|
Referenced by do_dir(), getcwdx(), readdir_r_test(), and readdir_test(). |
|
Referenced by get_max_pathname(), main(), option_async_io(), option_sync_io(), and readdir_r_test(). |
|
Referenced by aup_sleep(), main(), process_test(), try2(), and try3(). |
|
Referenced by command(), edinvoke(), fpathconf_test(), fsort(), fsort0(), pcsync_init(), pipe_access_mode(), pipe_test(), pipetest(), pipewrite(), pipewrite2(), pipewrite2bug(), setup_fdset(), socket_test_inet(), socket_test_unix(), try6(), who_wc(), and who_wc2(). |
|
Calls poll.
Definition at line 276 of file uxfile.cpp. References errno. Referenced by readany3(). |
|
Referenced by find_and_open_master(). |
|
Referenced by backward2(), and readrec(). |
|
Calls pselect.
Definition at line 288 of file uxfile.cpp. References errno. |
|
Referenced by main(), and uem_unregister(). |
|
Referenced by thread_fdset(), thread_func(), thread_heartbeat(), thread_process(), thread_signal(), thread_svmsg(), and thread_svsem(). |
|
Referenced by thread_fdset(), thread_func(), thread_heartbeat(), thread_process(), thread_signal(), thread_svmsg(), and thread_svsem(). |
|
Referenced by main(), and queue_event(). |
|
Referenced by thread_func(), and uem_wait(). |
|
Referenced by handle_signals(), main(), uem_register_fdset(), uem_register_heartbeat(), uem_register_process(), uem_register_signal(), uem_register_svmsg(), and uem_register_svsem(). |
|
Referenced by main(). |
|
|
|
Definition at line 24 of file pthreadstub.c. Referenced by dequeue_event(), ec_mutex(), get_and_incr_x(), main(), queue_event(), sorter(), thread_fdset(), thread_func(), and uem_wait(). |
|
Definition at line 34 of file pthreadstub.c. Referenced by cleanup_handler(), dequeue_event(), ec_mutex(), get_and_incr_x(), main(), queue_event(), sorter(), thread_fdset(), thread_func(), and uem_wait(). |
|
Referenced by handle_signals(), uem_bgn(), and uem_register_signal(). |
|
|
|
Referenced by pt_open_master(). |
|
Referenced by process_env_test(). |
|
Referenced by pwrite_test(), and writerec(). |
|
|
|
Referenced by asynchronous(), backward(), backward0(), cget(), copy(), copy2(), copy2a(), cready(), dir_read_test(), ev_read(), fsort(), fsort0(), getch(), getln(), getln2(), junk(), main(), main1(), pcsync_unblock_children(), pipetest(), readall(), readany(), readany2(), readany3(), readbuf(), run_client(), run_server(), scatter(), setup_fdset(), smi_receive_getaddr_fifo(), synchronous(), tc_keystroke(), test_setblock(), and try6(). |
|
Referenced by do_dir(), getcwdx(), and readdir_test(). |
|
Referenced by readdir_r_test(). |
|
Referenced by print_name(). |
|
Referenced by main(). |
|
|
|
Referenced by run_server(). |
|
Referenced by run_server(). |
|
|
|
Referenced by do_dir(). |
|
Referenced by rmdir_test(). |
|
|
|
Calls select.
Definition at line 361 of file uxfile.cpp. References errno. Referenced by main(), pcsync_wait_for_parent(), pt_wait_master(), readany2(), readbuf(), run_server(), ssi_wait_server(), and thread_fdset(). |
|
Referenced by SimpleSemClose(). |
|
Referenced by op_semi(). |
|
Referenced by main(). |
|
Referenced by smi_open_pshm(). |
|
const char *name, POSIX IPC name int flags, flags (including O_CREAT) mode_t perms, permissions unsigned value initial value );
Referenced by main(), setup_posix_sem(), and SimpleSemOpen(). |
|
Referenced by main(), op_semi(), setup_posix_sem(), and SimpleSemPost(). |
|
|
|
|
|
Referenced by main(). |
|
Referenced by main(), op_semi(), and SimpleSemWait(). |
|
Referenced by init_semi(), setup_systemv_sem(), SimpleSemOpen(), SimpleSemRemove(), smi_close_shm(), and smi_open_shm(). |
|
Referenced by main(), setup_systemv_sem(), SimpleSemOpen(), SimpleSemRemove(), and smi_open_shm(). |
|
Referenced by op_semi(), setup_systemv_sem(), SimpleSemOpen(), SimpleSemPost(), SimpleSemWait(), and thread_svsem(). |
|
|
|
Referenced by run_server(). |
|
Referenced by main(), run_client(), and run_server(). |
|
|
|
|
|
|
|
|
|
Referenced by hostdb(). |
|
|
|
Referenced by main(). |
|
Referenced by netdb(). |
|
|
|
|
|
Referenced by main(), and process_test(). |
|
Referenced by servdb(). |
|
Referenced by pt_open_slave(). |
|
Referenced by ssi_open(). |
|
|
|
Referenced by get_client(), and smi_open_pshm(). |
|
Referenced by smi_close_pshm(), and smi_open_pshm(). |
|
Referenced by getaddr(), and smi_open_shm(). |
|
Referenced by smi_close_shm(), and smi_open_shm(). |
|
Referenced by getaddr(), and smi_close_shm(). |
|
Referenced by getaddr(), and smi_open_shm(). |
|
|
|
Referenced by aup_sleep(), entry_sig(), handle_signals(), ignore_sig(), main(), pcsync_wait_for_parent(), posixsem_test(), sysvsem_test(), try2(), try3(), and try4(). |
|
Referenced by aup_sleep(), handle_signals(), pcsync_init(), thread_signal(), try3(), try4(), try5(), and uem_register_signal(). |
|
|
|
Referenced by aup_sleep(), pcsync_wait_for_parent(), try3(), try4(), and uem_bgn(). |
|
Referenced by aup_sleep(), handle_signals(), pcsync_init(), thread_signal(), try3(), try4(), try5(), uem_bgn(), and uem_register_signal(). |
|
Referenced by handle_signals(), main(), pcsync_wait_for_parent(), try3(), try4(), and uem_bgn(). |
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
Referenced by aup_sleep(), handle_signals(), main(), pcsync_init(), pcsync_unblock_children(), pcsync_wait_for_parent(), try3(), try4(), and try5(). |
|
Referenced by main(). |
|
|
|
|
|
Referenced by aup_sleep(), pcsync_wait_for_parent(), and try4(). |
|
|
|
Referenced by sig_thread(), thread_signal(), and try5(). |
|
|
|
Referenced by ev_sleep(), file_ctime_test(), lock(), main(), playback(), process(), process_test(), readany(), run_client(), setup_fdset(), setup_posix_msg(), setup_posix_sem(), setup_process(), setup_signal(), setup_systemv_msg(), setup_systemv_sem(), SimpleSemOpen(), Ux::Clock::sleep(), smi_open_shm(), sorter(), test_setblock(), testlock(), thread1_func(), and thread_func(). |
|
|
|
Referenced by main(), main1(), run_client(), run_server(), and ssi_open(). |
|
|
|
Referenced by handle_request(), and main(). |
|
|
|
Referenced by logfmt(), and print_date(). |
|
|
|
Referenced by main(). |
|
Referenced by main(). |
|
Referenced by junk(), main(), and timestart(). |
|
Referenced by ftruncate_test(), junk(), main(), pwrite_test(), readdir_test(), rmdir_test(), and runtest(). |
|
Referenced by playback(). |
|
|
|
|
|
Referenced by playback(), tc_keystroke(), and tc_setraw(). |
|
Referenced by showpginfo(). |
|
Referenced by showpginfo(). |
|
|
|
Referenced by playback(), tc_keystroke(), tc_restore(), and tc_setraw(). |
|
|
|
Referenced by Ux::DirStream::tell(). |
|
Referenced by Ux::Timestr::ctime(), getaddr(), Ux::Timetm::gmtime(), Ux::Timetm::localtime(), logfmt(), main(), print_date(), send_header_OK(), test_setblock(), and Ux::PosixSem::timedwait(). |
|
|
|
|
|
|
|
|
|
|
|
Referenced by timestart(), and timestop(). |
|
|
|
Referenced by main(). |
|
|
|
|
|
|
|
Referenced by Ux::Process::umask(). |
|
|
|
Referenced by main(). |
|
Referenced by backward_test(), cleanup_previous_run(), fcntl_example(), junk(), main(), run_client(), SimpleSemRemove(), smi_close_fifo(), smi_close_shm(), smi_open_fifo(), ssi_close(), ssi_open(), and unlock(). |
|
Referenced by pt_open_master(). |
|
|
|
Referenced by ev_sleep(), process_test(), and store(). |
|
|
|
|
|
Referenced by main(). |
|
|
|
Referenced by execute3(), fsort(), fsort0(), main(), pipewrite2(), pipewrite2bug(), thread_process(), Ux::Process::wait(), wait_and_display(), Ux::Process::waitpid(), who_wc(), and who_wc2(). |
|
|
|
Referenced by alarm_handler(), buildfile(), copy(), copy2(), copy2a(), fcn(), file_ctime_test(), fsort(), fsort0(), ftruncate_test(), handler(), junk(), main(), main1(), pcsync_unblock_children(), pcsync_wait_for_parent(), pipetest(), pipewrite(), pipewrite2(), pipewrite2bug(), playback(), pwrite_test(), run_client(), run_server(), setup_fdset(), smi_send_release_fifo(), synctest(), time_traffic(), writeall(), and writebuf(). |
|
|
|
DST? (not in FreeBSD) Definition at line 3957 of file SUS_Summary. |
|
Definition at line 2944 of file SUS_Summary. Referenced by setup_fdset(). |
|
Definition at line 3015 of file SUS_Summary. |
|
timezone in secs (not in FreeBSD) Definition at line 3958 of file SUS_Summary. |
|
timezone strings (not in FreeBSD) Definition at line 3959 of file SUS_Summary. |