These man pages describe the Linux programming interface, including these two sections:
2 = Linux system calls.
3 = Library calls (note that a more comprehensive source of information
may be found in the glibc-doc and glibc-doc-reference packages).
Original maintainer | Dr. Tobias Quathamer |
---|---|
Homepage | https://www.kernel.org/doc/man-pages/ |
5.05

5.04

5.02

4.16




4.15

4.13

4.10

4.04

Distribution | Version | Since | Package | Installed | Packager | |
---|---|---|---|---|---|---|
![]() | deb | 4.16-2 | 2019-06-17 | 2.13 MiB | 3.75 MiB | Martin Schulze |
![]() | deb | 5.04-1~bpo10+1 | 2019-11-26 | 2.16 MiB | 3.79 MiB | Dr. Tobias Quathamer |
![]() | deb | 4.10-2 | 2017-11-10 | 2.05 MiB | 3.65 MiB | Martin Schulze |
![]() | deb | 4.16-1~bpo9+1 | 2018-06-19 | 2.12 MiB | 3.73 MiB | Martin Schulze |
![]() | deb | 4.13-3 | 2017-11-10 | 2.1 MiB | 3.71 MiB | Ubuntu Developers |
![]() | deb | 4.15-1 | 2018-02-03 | 2.11 MiB | 3.73 MiB | Ubuntu Developers |
![]() | deb | 4.16-1 | 2019-01-14 | 2.12 MiB | 3.73 MiB | Ubuntu Developers |
![]() | deb | 4.16-1 | 2019-01-14 | 2.12 MiB | 3.73 MiB | Ubuntu Developers |
![]() | deb | 5.02-1 | 2019-08-03 | 2.15 MiB | 3.77 MiB | Ubuntu Developers |
![]() | deb | 5.05-1 | Feb 10 | 2.16 MiB | 3.79 MiB | Ubuntu Developers |
![]() | deb | 4.04-2 | 2017-11-10 | 1.95 MiB | 3.53 MiB | Ubuntu Developers |
Manual pages
accept(2)
accept, accept4 - accept a connection on a socket
access(2)
access, faccessat - check user’s permissions for a file
acct(2)
acct - switch process accounting on or off
add_key(2)
add_key - add a key to the kernel’s key management facility
adjtimex(2)
adjtimex, ntp_adjtime - tune kernel clock
alarm(2)
alarm - set an alarm clock for delivery of a signal
alloc_hugepages(2)
alloc_hugepages, free_hugepages - allocate or free huge pages
arch_prctl(2)
arch_prctl - set architecture-specific thread state
bdflush(2)
bdflush - start, flush, or tune buffer-dirty-flush daemon
bind(2)
bind - bind a name to a socket
bpf(2)
bpf - perform a command on an extended BPF map or program
brk(2)
brk, sbrk - change data segment size
cacheflush(2)
cacheflush - flush contents of instruction and/or data cache
capget(2)
capget, capset - set/get capabilities of thread(s)
chdir(2)
chdir, fchdir - change working directory
chmod(2)
chmod, fchmod, fchmodat - change permissions of a file
chown(2)
chown, fchown, lchown, fchownat - change ownership of a file
chroot(2)
chroot - change root directory
clock_getres(2)
clock_getres, clock_gettime, clock_settime - clock and time functions
clock_nanosleep(2)
clock_nanosleep - high-resolution sleep with specifiable clock
clone(2)
clone, __clone2, clone3 - create a child process
close(2)
close - close a file descriptor
connect(2)
connect - initiate a connection on a socket
copy_file_range(2)
copy_file_range - Copy a range of data from one file to another
create_module(2)
create_module - create a loadable module entry
delete_module(2)
delete_module - unload a kernel module
dup(2)
dup, dup2, dup3 - duplicate a file descriptor
epoll_create(2)
epoll_create, epoll_create1 - open an epoll file descriptor
epoll_ctl(2)
epoll_ctl - control interface for an epoll file descriptor
epoll_wait(2)
epoll_wait, epoll_pwait - wait for an I/O event on an epoll file descriptor
eventfd(2)
eventfd - create a file descriptor for event notification
execve(2)
execve - execute program
execveat(2)
execveat - execute program relative to a directory file descriptor
exit_group(2)
exit_group - exit all threads in a process
fallocate(2)
fallocate - manipulate file space
fanotify_init(2)
fanotify_init - create and initialize fanotify group
fanotify_mark(2)
fanotify_mark - add, remove, or modify an fanotify mark on a filesystem object
fcntl(2)
fcntl - manipulate file descriptor
flock(2)
flock - apply or remove an advisory lock on an open file
fork(2)
fork - create a child process
fsync(2)
fsync, fdatasync - synchronize a file’s in-core state with storage device
futex(2)
futex - fast user-space locking
futimesat(2)
futimesat - change timestamps of a file relative to a directory file descriptor
getcpu(2)
getcpu - determine CPU and NUMA node on which the calling thread is running
getdents(2)
getdents, getdents64 - get directory entries
getdomainname(2)
getdomainname, setdomainname - get/set NIS domain name
getgid(2)
getgid, getegid - get group identity
getgroups(2)
getgroups, setgroups - get/set list of supplementary group IDs
gethostname(2)
gethostname, sethostname - get/set hostname
getitimer(2)
getitimer, setitimer - get or set value of an interval timer
getpagesize(2)
getpagesize - get memory page size
getpeername(2)
getpeername - get name of connected peer socket
getpid(2)
getpid, getppid - get process identification
getpriority(2)
getpriority, setpriority - get/set program scheduling priority
getrandom(2)
getrandom - obtain a series of random bytes
getresuid(2)
getresuid, getresgid - get real, effective and saved user/group IDs
getrlimit(2)
getrlimit, setrlimit, prlimit - get/set resource limits
getrusage(2)
getrusage - get resource usage
getsid(2)
getsid - get session ID
getsockname(2)
getsockname - get socket name
getsockopt(2)
getsockopt, setsockopt - get and set options on sockets
gettid(2)
gettid - get thread identification
gettimeofday(2)
gettimeofday, settimeofday - get / set time
getuid(2)
getuid, geteuid - get user identity
getunwind(2)
getunwind - copy the unwind data to caller’s buffer
getxattr(2)
getxattr, lgetxattr, fgetxattr - retrieve an extended attribute value
get_kernel_syms(2)
get_kernel_syms - retrieve exported kernel and module symbols
get_mempolicy(2)
get_mempolicy - retrieve NUMA memory policy for a thread
get_robust_list(2)
get_robust_list, set_robust_list - get/set list of robust futexes
idle(2)
idle - make process 0 idle
init_module(2)
init_module, finit_module - load a kernel module
inotify_add_watch(2)
inotify_add_watch - add a watch to an initialized inotify instance
inotify_init(2)
inotify_init, inotify_init1 - initialize an inotify instance
inotify_rm_watch(2)
inotify_rm_watch - remove an existing watch from an inotify instance
ioctl(2)
ioctl - control device
ioctl_console(2)
ioctl_console - ioctls for console terminal and virtual consoles
ioctl_fat(2)
ioctl_fat - manipulating the FAT filesystem
ioctl_ficlonerange(2)
ioctl_ficlonerange, ioctl_ficlone - share some the data of one file with another file
ioctl_fideduperange(2)
ioctl_fideduperange - share some the data of one file with another file
ioctl_getfsmap(2)
ioctl_getfsmap - retrieve the physical layout of the filesystem
ioctl_iflags(2)
ioctl_iflags - ioctl() operations for inode flags
ioctl_list(2)
ioctl_list - list of ioctl calls in Linux/i386 kernel
ioctl_ns(2)
ioctl_ns - ioctl() operations for Linux namespaces
ioctl_tty(2)
ioctl_tty - ioctls for terminals and serial lines
ioctl_userfaultfd(2)
ioctl_userfaultfd - create a file descriptor for handling page faults in user space
ioperm(2)
ioperm - set port input/output permissions
iopl(2)
iopl - change I/O privilege level
ioprio_set(2)
ioprio_get, ioprio_set - get/set I/O scheduling class and priority
io_cancel(2)
io_cancel - cancel an outstanding asynchronous I/O operation
io_destroy(2)
io_destroy - destroy an asynchronous I/O context
io_getevents(2)
io_getevents - read asynchronous I/O events from the completion queue
io_setup(2)
io_setup - create an asynchronous I/O context
io_submit(2)
io_submit - submit asynchronous I/O blocks for processing
ipc(2)
ipc - System V IPC system calls
kcmp(2)
kcmp - compare two processes to determine if they share a kernel resource
kexec_load(2)
kexec_load, kexec_file_load - load a new kernel for later execution
keyctl(2)
keyctl - manipulate the kernel’s key management facility
kill(2)
kill - send signal to a process
killpg(2)
killpg - send signal to a process group
link(2)
link, linkat - make a new name for a file
listen(2)
listen - listen for connections on a socket
listxattr(2)
listxattr, llistxattr, flistxattr - list extended attribute names
llseek(2)
_llseek - reposition read/write file offset
lookup_dcookie(2)
lookup_dcookie - return a directory entry’s path
lseek(2)
lseek - reposition read/write file offset
madvise(2)
madvise - give advice about use of memory
mbind(2)
mbind - set memory policy for a memory range
membarrier(2)
membarrier - issue memory barriers on a set of threads
memfd_create(2)
memfd_create - create an anonymous file
migrate_pages(2)
migrate_pages - move all pages in a process to another set of nodes
mincore(2)
mincore - determine whether pages are resident in memory
mkdir(2)
mkdir, mkdirat - create a directory
mknod(2)
mknod, mknodat - create a special or ordinary file
mlock(2)
mlock, mlock2, munlock, mlockall, munlockall - lock and unlock memory
mmap(2)
mmap, munmap - map or unmap files or devices into memory
mmap2(2)
mmap2 - map files or devices into memory
modify_ldt(2)
modify_ldt - get or set a per-process LDT entry
mount(2)
mount - mount filesystem
move_pages(2)
move_pages - move individual pages of a process to another node
mprotect(2)
mprotect, pkey_mprotect - set protection on a region of memory
mq_getsetattr(2)
mq_getsetattr - get/set message queue attributes
mremap(2)
mremap - remap a virtual memory address
msgctl(2)
msgctl - System V message control operations
msgget(2)
msgget - get a System V message queue identifier
msgop(2)
msgrcv, msgsnd - System V message queue operations
msync(2)
msync - synchronize a file with a memory map
nanosleep(2)
nanosleep - high-resolution sleep
nfsservctl(2)
nfsservctl - syscall interface to kernel nfs daemon
nice(2)
nice - change process priority
open(2)
open, openat, creat - open and possibly create a file
open_by_handle_at(2)
name_to_handle_at, open_by_handle_at - obtain handle for a pathname and open file via a handle
outb(2)
outb, outw, outl, outsb, outsw, outsl, inb, inw, inl, insb, insw, insl, outb_p, outw_p, outl_p, inb_p, inw_p, inl_p - port I/O
pause(2)
pause - wait for signal
pciconfig_read(2)
pciconfig_read, pciconfig_write, pciconfig_iobase - pci device information handling
perfmonctl(2)
perfmonctl - interface to IA-64 performance monitoring unit
perf_event_open(2)
perf_event_open - set up performance monitoring
personality(2)
personality - set the process execution domain
pidfd_open(2)
pidfd_open - obtain a file descriptor that refers to a process
pidfd_send_signal(2)
pidfd_send_signal - send a signal to a process specified by a file descriptor
pipe(2)
pipe, pipe2 - create pipe
pivot_root(2)
pivot_root - change the root mount
pkey_alloc(2)
pkey_alloc, pkey_free - allocate or free a protection key
poll(2)
poll, ppoll - wait for some event on a file descriptor
posix_fadvise(2)
posix_fadvise - predeclare an access pattern for file data
prctl(2)
prctl - operations on a process
pread(2)
pread, pwrite - read from or write to a file descriptor at a given offset
process_vm_readv(2)
process_vm_readv, process_vm_writev - transfer data between process address spaces
ptrace(2)
ptrace - process trace
query_module(2)
query_module - query the kernel for various bits pertaining to modules
quotactl(2)
quotactl - manipulate disk quotas
read(2)
read - read from a file descriptor
readahead(2)
readahead - initiate file readahead into page cache
readdir(2)
readdir - read directory entry
readlink(2)
readlink, readlinkat - read value of a symbolic link
readv(2)
readv, writev, preadv, pwritev, preadv2, pwritev2 - read or write data into multiple buffers
reboot(2)
reboot - reboot or enable/disable Ctrl-Alt-Del
recv(2)
recv, recvfrom, recvmsg - receive a message from a socket
recvmmsg(2)
recvmmsg - receive multiple messages on a socket
remap_file_pages(2)
remap_file_pages - create a nonlinear file mapping
removexattr(2)
removexattr, lremovexattr, fremovexattr - remove an extended attribute
rename(2)
rename, renameat, renameat2 - change the name or location of a file
request_key(2)
request_key - request a key from the kernel’s key management facility
restart_syscall(2)
restart_syscall - restart a system call after interruption by a stop signal
rmdir(2)
rmdir - delete a directory
rt_sigqueueinfo(2)
rt_sigqueueinfo, rt_tgsigqueueinfo - queue a signal and data
s390_guarded_storage(2)
s390_guarded_storage - operations with z/Architecture guarded storage facility
s390_pci_mmio_write(2)
s390_pci_mmio_write, s390_pci_mmio_read - transfer data to/from PCI MMIO memory page
s390_runtime_instr(2)
s390_runtime_instr - enable/disable s390 CPU run-time instrumentation
s390_sthyi(2)
s390_sthyi - emulate STHYI instruction
sched_get_priority_max(2)
sched_get_priority_max, sched_get_priority_min - get static priority range
sched_rr_get_interval(2)
sched_rr_get_interval - get the SCHED_RR interval for the named process
sched_setaffinity(2)
sched_setaffinity, sched_getaffinity - set and get a thread’s CPU affinity mask
sched_setattr(2)
sched_setattr, sched_getattr - set and get scheduling policy and attributes
sched_setparam(2)
sched_setparam, sched_getparam - set and get scheduling parameters
sched_setscheduler(2)
sched_setscheduler, sched_getscheduler - set and get scheduling policy/parameters
sched_yield(2)
sched_yield - yield the processor
seccomp(2)
seccomp - operate on Secure Computing state of the process
select(2)
select, pselect, FD_CLR, FD_ISSET, FD_SET, FD_ZERO - synchronous I/O multiplexing
select_tut(2)
select, pselect, FD_CLR, FD_ISSET, FD_SET, FD_ZERO - synchronous I/O multiplexing
semctl(2)
semctl - System V semaphore control operations
semget(2)
semget - get a System V semaphore set identifier
semop(2)
semop, semtimedop - System V semaphore operations
send(2)
send, sendto, sendmsg - send a message on a socket
sendfile(2)
sendfile - transfer data between file descriptors
sendmmsg(2)
sendmmsg - send multiple messages on a socket
seteuid(2)
seteuid, setegid - set effective user or group ID
setfsgid(2)
setfsgid - set group identity used for filesystem checks
setfsuid(2)
setfsuid - set user identity used for filesystem checks
setgid(2)
setgid - set group identity
setns(2)
setns - reassociate thread with a namespace
setpgid(2)
setpgid, getpgid, setpgrp, getpgrp - set/get process group
setresuid(2)
setresuid, setresgid - set real, effective and saved user or group ID
setreuid(2)
setreuid, setregid - set real and/or effective user or group ID
setsid(2)
setsid - creates a session and sets the process group ID
setuid(2)
setuid - set user identity
setup(2)
setup - setup devices and filesystems, mount root filesystem
setxattr(2)
setxattr, lsetxattr, fsetxattr - set an extended attribute value
set_mempolicy(2)
set_mempolicy - set default NUMA memory policy for a thread and its children
set_thread_area(2)
get_thread_area, set_thread_area - manipulate thread-local storage information
set_tid_address(2)
set_tid_address - set pointer to thread ID
sgetmask(2)
sgetmask, ssetmask - manipulation of signal mask (obsolete)
shmctl(2)
shmctl - System V shared memory control
shmget(2)
shmget - allocates a System V shared memory segment
shmop(2)
shmat, shmdt - System V shared memory operations
shutdown(2)
shutdown - shut down part of a full-duplex connection
sigaction(2)
sigaction, rt_sigaction - examine and change a signal action
sigaltstack(2)
sigaltstack - set and/or get signal stack context
signal(2)
signal - ANSI C signal handling
signalfd(2)
signalfd - create a file descriptor for accepting signals
sigpending(2)
sigpending, rt_sigpending - examine pending signals
sigprocmask(2)
sigprocmask, rt_sigprocmask - examine and change blocked signals
sigreturn(2)
sigreturn, rt_sigreturn - return from signal handler and cleanup stack frame
sigsuspend(2)
sigsuspend, rt_sigsuspend - wait for a signal
sigwaitinfo(2)
sigwaitinfo, sigtimedwait, rt_sigtimedwait - synchronously wait for queued signals
socket(2)
socket - create an endpoint for communication
socketcall(2)
socketcall - socket system calls
socketpair(2)
socketpair - create a pair of connected sockets
splice(2)
splice - splice data to/from a pipe
spu_create(2)
spu_create - create a new spu context
spu_run(2)
spu_run - execute an SPU context
stat(2)
stat, fstat, lstat, fstatat - get file status
statfs(2)
statfs, fstatfs - get filesystem statistics
statx(2)
statx - get file status (extended)
stime(2)
stime - set time
subpage_prot(2)
subpage_prot - define a subpage protection for an address range
swapon(2)
swapon, swapoff - start/stop swapping to file/device
symlink(2)
symlink, symlinkat - make a new name for a file
sync(2)
sync, syncfs - commit filesystem caches to disk
sync_file_range(2)
sync_file_range - sync a file segment with disk
syscall(2)
syscall - indirect system call
syscalls(2)
syscalls - Linux system calls
sysctl(2)
sysctl - read/write system parameters
sysfs(2)
sysfs - get filesystem type information
sysinfo(2)
sysinfo - return system information
syslog(2)
syslog, klogctl - read and/or clear kernel message ring buffer; set console_loglevel
tee(2)
tee - duplicating pipe content
time(2)
time - get time in seconds
timerfd_create(2)
timerfd_create, timerfd_settime, timerfd_gettime - timers that notify via file descriptors
timer_create(2)
timer_create - create a POSIX per-process timer
timer_delete(2)
timer_delete - delete a POSIX per-process timer
timer_getoverrun(2)
timer_getoverrun - get overrun count for a POSIX per-process timer
timer_settime(2)
timer_settime, timer_gettime - arm/disarm and fetch state of POSIX per-process timer
times(2)
times - get process times
tkill(2)
tkill, tgkill - send a signal to a thread
truncate(2)
truncate, ftruncate - truncate a file to a specified length
umask(2)
umask - set file mode creation mask
umount(2)
umount, umount2 - unmount filesystem
uname(2)
uname - get name and information about current kernel
unimplemented(2)
afs_syscall, break, fattach, fdetach, ftime, getmsg, getpmsg, gtty, isastream, lock, madvise1, mpx, prof, profil, putmsg, putpmsg, security, stty, tuxcall, ulimit, vserver - unimplemented system calls
unlink(2)
unlink, unlinkat - delete a name and possibly the file it refers to
unshare(2)
unshare - disassociate parts of the process execution context
uselib(2)
uselib - load shared library
userfaultfd(2)
userfaultfd - create a file descriptor for handling page faults in user space
ustat(2)
ustat - get filesystem statistics
utime(2)
utime, utimes - change file last access and modification times
utimensat(2)
utimensat, futimens - change file timestamps with nanosecond precision
vfork(2)
vfork - create a child process and block parent
vhangup(2)
vhangup - virtually hangup the current terminal
vm86(2)
vm86old, vm86 - enter virtual 8086 mode
vmsplice(2)
vmsplice - splice user pages to/from a pipe
wait(2)
wait, waitpid, waitid - wait for process to change state
wait4(2)
wait3, wait4 - wait for process to change state, BSD style
write(2)
write - write to a file descriptor
_exit(2)
_exit, _Exit - terminate the calling process
_syscall(2)
_syscall - invoking a system call without library support (OBSOLETE)
a64l(3)
a64l, l64a - convert between long and base-64
abort(3)
abort - cause abnormal process termination
abs(3)
abs, labs, llabs, imaxabs - compute the absolute value of an integer
acos(3)
acos, acosf, acosl - arc cosine function
acosh(3)
acosh, acoshf, acoshl - inverse hyperbolic cosine function
addseverity(3)
addseverity - introduce new severity classes
adjtime(3)
adjtime - correct the time to synchronize the system clock
aio_cancel(3)
aio_cancel - cancel an outstanding asynchronous I/O request
aio_error(3)
aio_error - get error status of asynchronous I/O operation
aio_fsync(3)
aio_fsync - asynchronous file synchronization
aio_init(3)
aio_init - asynchronous I/O initialization
aio_read(3)
aio_read - asynchronous read
aio_return(3)
aio_return - get return status of asynchronous I/O operation
aio_suspend(3)
aio_suspend - wait for asynchronous I/O operation or timeout
aio_write(3)
aio_write - asynchronous write
alloca(3)
alloca - allocate memory that is automatically freed
argz_add(3)
argz_add, argz_add_sep, argz_append, argz_count, argz_create, argz_create_sep, argz_delete, argz_extract, argz_insert, argz_next, argz_replace, argz_stringify - functions to handle an argz list
asin(3)
asin, asinf, asinl - arc sine function
asinh(3)
asinh, asinhf, asinhl - inverse hyperbolic sine function
asprintf(3)
asprintf, vasprintf - print to allocated string
assert(3)
assert - abort the program if assertion is false
assert_perror(3)
assert_perror - test errnum and abort
atan(3)
atan, atanf, atanl - arc tangent function
atan2(3)
atan2, atan2f, atan2l - arc tangent function of two variables
atanh(3)
atanh, atanhf, atanhl - inverse hyperbolic tangent function
atexit(3)
atexit - register a function to be called at normal process termination
atof(3)
atof - convert a string to a double
atoi(3)
atoi, atol, atoll - convert a string to an integer
backtrace(3)
backtrace, backtrace_symbols, backtrace_symbols_fd - support for application self-debugging
basename(3)
basename, dirname - parse pathname components
bcmp(3)
bcmp - compare byte sequences
bcopy(3)
bcopy - copy byte sequence
bindresvport(3)
bindresvport - bind a socket to a privileged IP port
bsd_signal(3)
bsd_signal - signal handling with BSD semantics
bsearch(3)
bsearch - binary search of a sorted array
bstring(3)
bcmp, bcopy, bzero, memccpy, memchr, memcmp, memcpy, memfrob, memmem, memmove, memset - byte string operations
bswap(3)
bswap_16, bswap_32, bswap_64 - reverse order of bytes
btowc(3)
btowc - convert single byte to wide character
btree(3)
btree - btree database access method
byteorder(3)
htonl, htons, ntohl, ntohs - convert values between host and network byte order
bzero(3)
bzero, explicit_bzero - zero a byte string
cabs(3)
cabs, cabsf, cabsl - absolute value of a complex number
cacos(3)
cacos, cacosf, cacosl - complex arc cosine
cacosh(3)
cacosh, cacoshf, cacoshl - complex arc hyperbolic cosine
canonicalize_file_name(3)
canonicalize_file_name - return the canonicalized absolute pathname
carg(3)
carg, cargf, cargl - calculate the complex argument
casin(3)
casin, casinf, casinl - complex arc sine
casinh(3)
casinh, casinhf, casinhl - complex arc sine hyperbolic
catan(3)
catan, catanf, catanl - complex arc tangents
catanh(3)
catanh, catanhf, catanhl - complex arc tangents hyperbolic
catgets(3)
catgets - get message from a message catalog
catopen(3)
catopen, catclose - open/close a message catalog
cbrt(3)
cbrt, cbrtf, cbrtl - cube root function
ccos(3)
ccos, ccosf, ccosl - complex cosine function
ccosh(3)
ccosh, ccoshf, ccoshl - complex hyperbolic cosine
ceil(3)
ceil, ceilf, ceill - ceiling function: smallest integral value not less than argument
cexp(3)
cexp, cexpf, cexpl - complex exponential function
cexp2(3)
cexp2, cexp2f, cexp2l - base-2 exponent of a complex number
cfree(3)
cfree - free allocated memory
cimag(3)
cimag, cimagf, cimagl - get imaginary part of a complex number
clearenv(3)
clearenv - clear the environment
clock(3)
clock - determine processor time
clock_getcpuclockid(3)
clock_getcpuclockid - obtain ID of a process CPU-time clock
clog(3)
clog, clogf, clogl - natural logarithm of a complex number
clog10(3)
clog10, clog10f, clog10l - base-10 logarithm of a complex number
clog2(3)
clog2, clog2f, clog2l - base-2 logarithm of a complex number
closedir(3)
closedir - close a directory
cmsg(3)
CMSG_ALIGN, CMSG_SPACE, CMSG_NXTHDR, CMSG_FIRSTHDR - access ancillary data
confstr(3)
confstr - get configuration dependent string variables
conj(3)
conj, conjf, conjl - calculate the complex conjugate
copysign(3)
copysign, copysignf, copysignl - copy sign of a number
cos(3)
cos, cosf, cosl - cosine function
cosh(3)
cosh, coshf, coshl - hyperbolic cosine function
cpow(3)
cpow, cpowf, cpowl - complex power function
cproj(3)
cproj, cprojf, cprojl - project into Riemann Sphere
creal(3)
creal, crealf, creall - get real part of a complex number
crypt(3)
crypt, crypt_r, crypt_rn, crypt_ra - passphrase hashing
csin(3)
csin, csinf, csinl - complex sine function
csinh(3)
csinh, csinhf, csinhl - complex hyperbolic sine
csqrt(3)
csqrt, csqrtf, csqrtl - complex square root
ctan(3)
ctan, ctanf, ctanl - complex tangent function
ctanh(3)
ctanh, ctanhf, ctanhl - complex hyperbolic tangent
ctermid(3)
ctermid - get controlling terminal name
ctime(3)
asctime, ctime, gmtime, localtime, mktime, asctime_r, ctime_r, gmtime_r, localtime_r - transform date and time to broken-down time or ASCII
daemon(3)
daemon - run in the background
dbopen(3)
dbopen - database access methods
des_crypt(3)
des_crypt, ecb_crypt, cbc_crypt, des_setparity, DES_FAILED - fast DES encryption
difftime(3)
difftime - calculate time difference
dirfd(3)
dirfd - get directory stream file descriptor
div(3)
div, ldiv, lldiv, imaxdiv - compute quotient and remainder of an integer division
dladdr(3)
dladdr, dladdr1 - translate address to symbolic information
dlerror(3)
dlerror - obtain error diagnostic for functions in the dlopen API
dlinfo(3)
dlinfo - obtain information about a dynamically loaded object
dlopen(3)
dlclose, dlopen, dlmopen - open and close a shared object
dlsym(3)
dlsym, dlvsym - obtain address of a symbol in a shared object or executable
dl_iterate_phdr(3)
dl_iterate_phdr - walk through list of shared objects
drand48(3)
drand48, erand48, lrand48, nrand48, mrand48, jrand48, srand48, seed48, lcong48 - generate uniformly distributed pseudo-random numbers
drand48_r(3)
drand48_r, erand48_r, lrand48_r, nrand48_r, mrand48_r, jrand48_r, srand48_r, seed48_r, lcong48_r - generate uniformly distributed pseudo-random numbers reentrantly
duplocale(3)
duplocale - duplicate a locale object
dysize(3)
dysize - get number of days for a given year
ecvt(3)
ecvt, fcvt - convert a floating-point number to a string
ecvt_r(3)
ecvt_r, fcvt_r, qecvt_r, qfcvt_r - convert a floating-point number to a string
encrypt(3)
encrypt, setkey, encrypt_r, setkey_r - encrypt 64-bit messages
end(3)
etext, edata, end - end of program segments
endian(3)
htobe16, htole16, be16toh, le16toh, htobe32, htole32, be32toh, le32toh, htobe64, htole64, be64toh, le64toh - convert values between host and big-/little-endian byte order
envz_add(3)
envz_add, envz_entry, envz_get, envz_merge, envz_remove, envz_strip - environment string support
erf(3)
erf, erff, erfl, - error function
erfc(3)
erfc, erfcf, erfcl - complementary error function
err(3)
err, verr, errx, verrx, warn, vwarn, warnx, vwarnx - formatted error messages
errno(3)
errno - number of last error
error(3)
error, error_at_line, error_message_count, error_one_per_line, error_print_progname - glibc error reporting functions
ether_aton(3)
ether_aton, ether_ntoa, ether_ntohost, ether_hostton, ether_line, ether_ntoa_r, ether_aton_r - Ethernet address manipulation routines
euidaccess(3)
euidaccess, eaccess - check effective user’s permissions for a file
exec(3)
execl, execlp, execle, execv, execvp, execvpe - execute a file
exit(3)
exit - cause normal process termination
exp(3)
exp, expf, expl - base-e exponential function
exp10(3)
exp10, exp10f, exp10l - base-10 exponential function
exp2(3)
exp2, exp2f, exp2l - base-2 exponential function
expm1(3)
expm1, expm1f, expm1l - exponential minus 1
fabs(3)
fabs, fabsf, fabsl - absolute value of floating-point number
fclose(3)
fclose - close a stream
fcloseall(3)
fcloseall - close all open streams
fdim(3)
fdim, fdimf, fdiml - positive difference
fenv(3)
feclearexcept, fegetexceptflag, feraiseexcept, fesetexceptflag, fetestexcept, fegetenv, fegetround, feholdexcept, fesetround, fesetenv, feupdateenv, feenableexcept, fedisableexcept, fegetexcept - floating-point rounding and exception handling
ferror(3)
clearerr, feof, ferror, fileno - check and reset stream status
fexecve(3)
fexecve - execute program specified via file descriptor
fflush(3)
fflush - flush a stream
ffs(3)
ffs, ffsl, ffsll - find first bit set in a word
fgetc(3)
fgetc, fgets, getc, getchar, ungetc - input of characters and strings
fgetgrent(3)
fgetgrent - get group file entry
fgetpwent(3)
fgetpwent - get password file entry
fgetwc(3)
fgetwc, getwc - read a wide character from a FILE stream
fgetws(3)
fgetws - read a wide-character string from a FILE stream
finite(3)
finite, finitef, finitel, isinf, isinff, isinfl, isnan, isnanf, isnanl - BSD floating-point classification functions
flockfile(3)
flockfile, ftrylockfile, funlockfile - lock FILE for stdio
floor(3)
floor, floorf, floorl - largest integral value not greater than argument
fma(3)
fma, fmaf, fmal - floating-point multiply and add
fmax(3)
fmax, fmaxf, fmaxl - determine maximum of two floating-point numbers
fmemopen(3)
fmemopen - open memory as stream
fmin(3)
fmin, fminf, fminl - determine minimum of two floating-point numbers
fmod(3)
fmod, fmodf, fmodl - floating-point remainder function
fmtmsg(3)
fmtmsg - print formatted error messages
fnmatch(3)
fnmatch - match filename or pathname
fopen(3)
fopen, fdopen, freopen - stream open functions
fopencookie(3)
fopencookie - opening a custom stream
fpathconf(3)
fpathconf, pathconf - get configuration values for files
fpclassify(3)
fpclassify, isfinite, isnormal, isnan, isinf - floating-point classification macros
fpurge(3)
fpurge, __fpurge - purge a stream
fputwc(3)
fputwc, putwc - write a wide character to a FILE stream
fputws(3)
fputws - write a wide-character string to a FILE stream
fread(3)
fread, fwrite - binary stream input/output
frexp(3)
frexp, frexpf, frexpl - convert floating-point number to fractional and integral components
fseek(3)
fgetpos, fseek, fsetpos, ftell, rewind - reposition a stream
fseeko(3)
fseeko, ftello - seek to or report file position
ftime(3)
ftime - return date and time
ftok(3)
ftok - convert a pathname and a project identifier to a System V IPC key
fts(3)
fts, fts_open, fts_read, fts_children, fts_set, fts_close - traverse a file hierarchy
ftw(3)
ftw, nftw - file tree walk
futimes(3)
futimes, lutimes - change file timestamps
fwide(3)
fwide - set and determine the orientation of a FILE stream
gamma(3)
gamma, gammaf, gammal - (logarithm of the) gamma function
gcvt(3)
gcvt - convert a floating-point number to a string
getaddrinfo(3)
getaddrinfo, freeaddrinfo, gai_strerror - network address and service translation
getaddrinfo_a(3)
getaddrinfo_a, gai_suspend, gai_error, gai_cancel - asynchronous network address and service translation
getauxval(3)
getauxval - retrieve a value from the auxiliary vector
getcontext(3)
getcontext, setcontext - get or set the user context
getcwd(3)
getcwd, getwd, get_current_dir_name - get current working directory
getdate(3)
getdate, getdate_r - convert a date-plus-time string to broken-down time
getdirentries(3)
getdirentries - get directory entries in a filesystem-independent format
getdtablesize(3)
getdtablesize - get file descriptor table size
getentropy(3)
getentropy - fill a buffer with random bytes
getenv(3)
getenv, secure_getenv - get an environment variable
getfsent(3)
getfsent, getfsspec, getfsfile, setfsent, endfsent - handle fstab entries
getgrent(3)
getgrent, setgrent, endgrent - get group file entry
getgrent_r(3)
getgrent_r, fgetgrent_r - get group file entry reentrantly
getgrnam(3)
getgrnam, getgrnam_r, getgrgid, getgrgid_r - get group file entry
getgrouplist(3)
getgrouplist - get list of groups to which a user belongs
gethostbyname(3)
gethostbyname, gethostbyaddr, sethostent, gethostent, endhostent, h_errno, herror, hstrerror, gethostbyaddr_r, gethostbyname2, gethostbyname2_r, gethostbyname_r, gethostent_r - get network host entry
gethostid(3)
gethostid, sethostid - get or set the unique identifier of the current host
getifaddrs(3)
getifaddrs - get interface addresses
getipnodebyname(3)
getipnodebyname, getipnodebyaddr, freehostent - get network hostnames and addresses
getline(3)
getline, getdelim - delimited string input
getloadavg(3)
getloadavg - get system load averages
getlogin(3)
getlogin, getlogin_r, cuserid - get username
getmntent(3)
getmntent, setmntent, addmntent, endmntent, hasmntopt, getmntent_r - get filesystem descriptor file entry
getnameinfo(3)
getnameinfo - address-to-name translation in protocol-independent manner
getnetent(3)
getnetent, getnetbyname, getnetbyaddr, setnetent, endnetent - get network entry
getnetent_r(3)
getnetent_r, getnetbyname_r, getnetbyaddr_r - get network entry (reentrant)
getopt(3)
getopt, getopt_long, getopt_long_only, optarg, optind, opterr, optopt - Parse command-line options
getpass(3)
getpass - get a password
getprotoent(3)
getprotoent, getprotobyname, getprotobynumber, setprotoent, endprotoent - get protocol entry
getprotoent_r(3)
getprotoent_r, getprotobyname_r, getprotobynumber_r - get protocol entry (reentrant)
getpt(3)
getpt - open the pseudoterminal master (PTM)
getpw(3)
getpw - reconstruct password line entry
getpwent(3)
getpwent, setpwent, endpwent - get password file entry
getpwent_r(3)
getpwent_r, fgetpwent_r - get passwd file entry reentrantly
getpwnam(3)
getpwnam, getpwnam_r, getpwuid, getpwuid_r - get password file entry
getrpcent(3)
getrpcent, getrpcbyname, getrpcbynumber, setrpcent, endrpcent - get RPC entry
getrpcent_r(3)
getrpcent_r, getrpcbyname_r, getrpcbynumber_r - get RPC entry (reentrant)
getrpcport(3)
getrpcport - get RPC port number
gets(3)
gets - get a string from standard input (DEPRECATED)
getservent(3)
getservent, getservbyname, getservbyport, setservent, endservent - get service entry
getservent_r(3)
getservent_r, getservbyname_r, getservbyport_r - get service entry (reentrant)
getspnam(3)
getspnam, getspnam_r, getspent, getspent_r, setspent, endspent, fgetspent, fgetspent_r, sgetspent, sgetspent_r, putspent, lckpwdf, ulckpwdf - get shadow password file entry
getsubopt(3)
getsubopt - parse suboption arguments from a string
getttyent(3)
getttyent, getttynam, setttyent, endttyent - get ttys file entry
getumask(3)
getumask - get file creation mask
getusershell(3)
getusershell, setusershell, endusershell - get permitted user shells
getutent(3)
getutent, getutid, getutline, pututline, setutent, endutent, utmpname - access utmp file entries
getutmp(3)
getutmp, getutmpx - copy utmp structure to utmpx, and vice versa
getw(3)
getw, putw - input and output of words (ints)
getwchar(3)
getwchar - read a wide character from standard input
get_nprocs_conf(3)
get_nprocs, get_nprocs_conf - get number of processors
get_phys_pages(3)
get_phys_pages, get_avphys_pages - get total and available physical page counts
glob(3)
glob, globfree - find pathnames matching a pattern, free memory from glob()
gnu_get_libc_version(3)
gnu_get_libc_version, gnu_get_libc_release - get glibc version and release
grantpt(3)
grantpt - grant access to the slave pseudoterminal
group_member(3)
group_member - test whether a process is in a group
gsignal(3)
gsignal, ssignal - software signal facility
hash(3)
hash - hash database access method
hsearch(3)
hcreate, hdestroy, hsearch, hcreate_r, hdestroy_r, hsearch_r - hash table management
hypot(3)
hypot, hypotf, hypotl - Euclidean distance function
iconv(3)
iconv - perform character set conversion
iconv_close(3)
iconv_close - deallocate descriptor for character set conversion
iconv_open(3)
iconv_open - allocate descriptor for character set conversion
if_nameindex(3)
if_nameindex, if_freenameindex - get network interface names and indexes
if_nametoindex(3)
if_nametoindex, if_indextoname - mappings between network interface names and indexes
ilogb(3)
ilogb, ilogbf, ilogbl - get integer exponent of a floating-point value
index(3)
index, rindex - locate character in string
inet(3)
inet_aton, inet_addr, inet_network, inet_ntoa, inet_makeaddr, inet_lnaof, inet_netof - Internet address manipulation routines
inet_net_pton(3)
inet_net_pton, inet_net_ntop - Internet network number conversion
inet_ntop(3)
inet_ntop - convert IPv4 and IPv6 addresses from binary to text form
inet_pton(3)
inet_pton - convert IPv4 and IPv6 addresses from text to binary form
INFINITY(3)
INFINITY, NAN, HUGE_VAL, HUGE_VALF, HUGE_VALL - floating-point constants
infnan(3)
infnan - deal with infinite or not-a-number (NaN) result
initgroups(3)
initgroups - initialize the supplementary group access list
insque(3)
insque, remque - insert/remove an item from a queue
isatty(3)
isatty - test whether a file descriptor refers to a terminal
isfdtype(3)
isfdtype - test file type of a file descriptor
isgreater(3)
isgreater, isgreaterequal, isless, islessequal, islessgreater, isunordered - floating-point relational tests without exception for NaN
iswalnum(3)
iswalnum - test for alphanumeric wide character
iswalpha(3)
iswalpha - test for alphabetic wide character
iswblank(3)
iswblank - test for whitespace wide character
iswcntrl(3)
iswcntrl - test for control wide character
iswctype(3)
iswctype - wide-character classification
iswdigit(3)
iswdigit - test for decimal digit wide character
iswgraph(3)
iswgraph - test for graphic wide character
iswlower(3)
iswlower - test for lowercase wide character
iswprint(3)
iswprint - test for printing wide character
iswpunct(3)
iswpunct - test for punctuation or symbolic wide character
iswspace(3)
iswspace - test for whitespace wide character
iswupper(3)
iswupper - test for uppercase wide character
iswxdigit(3)
iswxdigit - test for hexadecimal digit wide character
j0(3)
j0, j0f, j0l, j1, j1f, j1l, jn, jnf, jnl - Bessel functions of the first kind
key_setsecret(3)
key_decryptsession, key_encryptsession, key_setsecret, key_gendes, key_secretkey_is_set - interfaces to rpc keyserver daemon
killpg(3)
killpg - send signal to a process group
ldexp(3)
ldexp, ldexpf, ldexpl - multiply floating-point number by integral power of 2
lgamma(3)
lgamma, lgammaf, lgammal, lgamma_r, lgammaf_r, lgammal_r, signgam - log gamma function
lio_listio(3)
lio_listio - initiate a list of I/O requests
localeconv(3)
localeconv - get numeric formatting information
lockf(3)
lockf - apply, test or remove a POSIX lock on an open file
log(3)
log, logf, logl - natural logarithmic function
log10(3)
log10, log10f, log10l - base-10 logarithmic function
log1p(3)
log1p, log1pf, log1pl - logarithm of 1 plus argument
log2(3)
log2, log2f, log2l - base-2 logarithmic function
logb(3)
logb, logbf, logbl - get exponent of a floating-point value
login(3)
login, logout - write utmp and wtmp entries
longjmp(3)
longjmp, siglongjmp - nonlocal jump to a saved stack context
lrint(3)
lrint, lrintf, lrintl, llrint, llrintf, llrintl - round to nearest integer
lround(3)
lround, lroundf, lroundl, llround, llroundf, llroundl - round to nearest integer
lsearch(3)
lfind, lsearch - linear search of an array
lseek64(3)
lseek64 - reposition 64-bit read/write file offset
makecontext(3)
makecontext, swapcontext - manipulate user context
makedev(3)
makedev, major, minor - manage a device number
mallinfo(3)
mallinfo - obtain memory allocation information
malloc(3)
malloc, free, calloc, realloc - allocate and free dynamic memory
malloc_get_state(3)
malloc_get_state, malloc_set_state - record and restore state of malloc implementation
malloc_hook(3)
__malloc_hook, __malloc_initialize_hook, __memalign_hook, __free_hook, __realloc_hook, __after_morecore_hook - malloc debugging variables
malloc_info(3)
malloc_info - export malloc state to a stream
malloc_stats(3)
malloc_stats - print memory allocation statistics
malloc_trim(3)
malloc_trim - release free memory from the heap
malloc_usable_size(3)
malloc_usable_size - obtain size of block of memory allocated from heap
mallopt(3)
mallopt - set memory allocation parameters
matherr(3)
matherr - SVID math library exception handling
mblen(3)
mblen - determine number of bytes in next multibyte character
mbrlen(3)
mbrlen - determine number of bytes in next multibyte character
mbrtowc(3)
mbrtowc - convert a multibyte sequence to a wide character
mbsinit(3)
mbsinit - test for initial shift state
mbsnrtowcs(3)
mbsnrtowcs - convert a multibyte string to a wide-character string
mbsrtowcs(3)
mbsrtowcs - convert a multibyte string to a wide-character string
mbstowcs(3)
mbstowcs - convert a multibyte string to a wide-character string
mbtowc(3)
mbtowc - convert a multibyte sequence to a wide character
MB_CUR_MAX(3)
MB_CUR_MAX - maximum length of a multibyte character in the current locale
MB_LEN_MAX(3)
MB_LEN_MAX - maximum multibyte length of a character across all locales
mcheck(3)
mcheck, mcheck_check_all, mcheck_pedantic, mprobe - heap consistency checking
memccpy(3)
memccpy - copy memory area
memchr(3)
memchr, memrchr, rawmemchr - scan memory for a character
memcmp(3)
memcmp - compare memory areas
memcpy(3)
memcpy - copy memory area
memfrob(3)
memfrob - frobnicate (encrypt) a memory area
memmem(3)
memmem - locate a substring
memmove(3)
memmove - copy memory area
mempcpy(3)
mempcpy, wmempcpy - copy memory area
memset(3)
memset - fill memory with a constant byte
mkdtemp(3)
mkdtemp - create a unique temporary directory
mkfifo(3)
mkfifo, mkfifoat - make a FIFO special file (a named pipe)
mkstemp(3)
mkstemp, mkostemp, mkstemps, mkostemps - create a unique temporary file
mktemp(3)
mktemp - make a unique temporary filename
modf(3)
modf, modff, modfl - extract signed integral and fractional values from floating-point number
mpool(3)
mpool - shared memory buffer pool
mq_close(3)
mq_close - close a message queue descriptor
mq_getattr(3)
mq_getattr, mq_setattr - get/set message queue attributes
mq_notify(3)
mq_notify - register for notification when a message is available
mq_open(3)
mq_open - open a message queue
mq_receive(3)
mq_receive, mq_timedreceive - receive a message from a message queue
mq_send(3)
mq_send, mq_timedsend - send a message to a message queue
mq_unlink(3)
mq_unlink - remove a message queue
mtrace(3)
mtrace, muntrace - malloc tracing
nan(3)
nan, nanf, nanl - return ’Not a Number’
netlink(3)
netlink - Netlink macros
newlocale(3)
newlocale, freelocale - create, modify, and free a locale object
nextafter(3)
nextafter, nextafterf, nextafterl, nexttoward, nexttowardf, nexttowardl - floating-point number manipulation
nextup(3)
nextup, nextupf, nextupl, nextdown, nextdownf, nextdownl - return next floating-point number toward positive/negative infinity
nl_langinfo(3)
nl_langinfo, nl_langinfo_l - query language and locale information
ntp_gettime(3)
ntp_gettime, ntp_gettimex - get time parameters (NTP daemon interface)
offsetof(3)
offsetof - offset of a structure member
on_exit(3)
on_exit - register a function to be called at normal process termination
opendir(3)
opendir, fdopendir - open a directory
openpty(3)
openpty, login_tty, forkpty - terminal utility functions
open_memstream(3)
open_memstream, open_wmemstream - open a dynamic memory buffer stream
perror(3)
perror - print a system error message
popen(3)
popen, pclose - pipe stream to or from a process
posix_fallocate(3)
posix_fallocate - allocate file space
posix_madvise(3)
posix_madvise - give advice about patterns of memory usage
posix_memalign(3)
posix_memalign, aligned_alloc, memalign, valloc, pvalloc - allocate aligned memory
posix_openpt(3)
posix_openpt - open a pseudoterminal device
posix_spawn(3)
posix_spawn, posix_spawnp - spawn a process
pow(3)
pow, powf, powl - power functions
pow10(3)
pow10, pow10f, pow10l - base-10 power functions
printf(3)
printf, fprintf, dprintf, sprintf, snprintf, vprintf, vfprintf, vdprintf, vsprintf, vsnprintf - formatted output conversion
profil(3)
profil - execution time profile
program_invocation_name(3)
program_invocation_name, program_invocation_short_name - obtain name used to invoke calling program
psignal(3)
psignal, psiginfo - print signal message
pthread_attr_init(3)
pthread_attr_init, pthread_attr_destroy - initialize and destroy thread attributes object
pthread_attr_setaffinity_np(3)
pthread_attr_setaffinity_np, pthread_attr_getaffinity_np - set/get CPU affinity attribute in thread attributes object
pthread_attr_setdetachstate(3)
pthread_attr_setdetachstate, pthread_attr_getdetachstate - set/get detach state attribute in thread attributes object
pthread_attr_setguardsize(3)
pthread_attr_setguardsize, pthread_attr_getguardsize - set/get guard size attribute in thread attributes object
pthread_attr_setinheritsched(3)
pthread_attr_setinheritsched, pthread_attr_getinheritsched - set/get inherit-scheduler attribute in thread attributes object
pthread_attr_setschedparam(3)
pthread_attr_setschedparam, pthread_attr_getschedparam - set/get scheduling parameter attributes in thread attributes object
pthread_attr_setschedpolicy(3)
pthread_attr_setschedpolicy, pthread_attr_getschedpolicy - set/get scheduling policy attribute in thread attributes object
pthread_attr_setscope(3)
pthread_attr_setscope, pthread_attr_getscope - set/get contention scope attribute in thread attributes object
pthread_attr_setstack(3)
pthread_attr_setstack, pthread_attr_getstack - set/get stack attributes in thread attributes object
pthread_attr_setstackaddr(3)
pthread_attr_setstackaddr, pthread_attr_getstackaddr - set/get stack address attribute in thread attributes object
pthread_attr_setstacksize(3)
pthread_attr_setstacksize, pthread_attr_getstacksize - set/get stack size attribute in thread attributes object
pthread_cancel(3)
pthread_cancel - send a cancellation request to a thread
pthread_cleanup_push(3)
pthread_cleanup_push, pthread_cleanup_pop - push and pop thread cancellation clean-up handlers
pthread_cleanup_push_defer_np(3)
pthread_cleanup_push_defer_np, pthread_cleanup_pop_restore_np - push and pop thread cancellation clean-up handlers while saving cancelability type
pthread_create(3)
pthread_create - create a new thread
pthread_detach(3)
pthread_detach - detach a thread
pthread_equal(3)
pthread_equal - compare thread IDs
pthread_exit(3)
pthread_exit - terminate calling thread
pthread_getattr_default_np(3)
pthread_getattr_default_np, pthread_setattr_default_np, - get or set default thread-creation attributes
pthread_getattr_np(3)
pthread_getattr_np - get attributes of created thread
pthread_getcpuclockid(3)
pthread_getcpuclockid - retrieve ID of a thread’s CPU time clock
pthread_join(3)
pthread_join - join with a terminated thread
pthread_kill(3)
pthread_kill - send a signal to a thread
pthread_kill_other_threads_np(3)
pthread_kill_other_threads_np - terminate all other threads in process
pthread_mutexattr_getpshared(3)
pthread_mutexattr_getpshared, pthread_mutexattr_setpshared - get/set process-shared mutex attribute
pthread_mutexattr_setrobust(3)
pthread_mutexattr_getrobust, pthread_mutexattr_setrobust - get and set the robustness attribute of a mutex attributes object
pthread_mutex_consistent(3)
pthread_mutex_consistent - make a robust mutex consistent
pthread_rwlockattr_setkind_np(3)
pthread_rwlockattr_setkind_np, pthread_rwlockattr_getkind_np - set/get the read-write lock kind of the thread read-write lock attribute object
pthread_self(3)
pthread_self - obtain ID of the calling thread
pthread_setaffinity_np(3)
pthread_setaffinity_np, pthread_getaffinity_np - set/get CPU affinity of a thread
pthread_setcancelstate(3)
pthread_setcancelstate, pthread_setcanceltype - set cancelability state and type
pthread_setconcurrency(3)
pthread_setconcurrency, pthread_getconcurrency - set/get the concurrency level
pthread_setname_np(3)
pthread_setname_np, pthread_getname_np - set/get the name of a thread
pthread_setschedparam(3)
pthread_setschedparam, pthread_getschedparam - set/get scheduling policy and parameters of a thread
pthread_setschedprio(3)
pthread_setschedprio - set scheduling priority of a thread
pthread_sigmask(3)
pthread_sigmask - examine and change mask of blocked signals
pthread_sigqueue(3)
pthread_sigqueue - queue a signal and data to a thread
pthread_spin_init(3)
pthread_spin_init, pthread_spin_destroy - initialize or destroy a spin lock
pthread_spin_lock(3)
pthread_spin_lock, pthread_spin_trylock, pthread_spin_unlock - lock and unlock a spin lock
pthread_testcancel(3)
pthread_testcancel - request delivery of any pending cancellation request
pthread_tryjoin_np(3)
pthread_tryjoin_np, pthread_timedjoin_np - try to join with a terminated thread
pthread_yield(3)
pthread_yield - yield the processor
ptsname(3)
ptsname, ptsname_r - get the name of the slave pseudoterminal
putenv(3)
putenv - change or add an environment variable
putgrent(3)
putgrent - write a group database entry to a file
putpwent(3)
putpwent - write a password file entry
puts(3)
fputc, fputs, putc, putchar, puts - output of characters and strings
putwchar(3)
putwchar - write a wide character to standard output
qecvt(3)
qecvt, qfcvt, qgcvt - convert a floating-point number to a string
qsort(3)
qsort, qsort_r - sort an array
raise(3)
raise - send a signal to the caller
rand(3)
rand, rand_r, srand - pseudo-random number generator
random(3)
random, srandom, initstate, setstate - random number generator
random_r(3)
random_r, srandom_r, initstate_r, setstate_r - reentrant random number generator
rcmd(3)
rcmd, rresvport, iruserok, ruserok, rcmd_af, rresvport_af, iruserok_af, ruserok_af - routines for returning a stream to a remote command
readdir(3)
readdir - read a directory
readdir_r(3)
readdir_r - read a directory
realpath(3)
realpath - return the canonicalized absolute pathname
recno(3)
recno - record number database access method
regex(3)
regcomp, regexec, regerror, regfree - POSIX regex functions
remainder(3)
drem, dremf, dreml, remainder, remainderf, remainderl - floating-point remainder function
remove(3)
remove - remove a file or directory
remquo(3)
remquo, remquof, remquol - remainder and part of quotient
resolver(3)
res_ninit, res_nclose, res_nquery, res_nsearch, res_nquerydomain, res_nmkquery, res_nsend, res_init, res_query, res_search, res_querydomain, res_mkquery, res_send, dn_comp, dn_expand - resolver routines
rewinddir(3)
rewinddir - reset directory stream
rexec(3)
rexec, rexec_af - return stream to a remote command
re_comp(3)
re_comp, re_exec - BSD regex functions
rint(3)
nearbyint, nearbyintf, nearbyintl, rint, rintf, rintl - round to nearest integer
round(3)
round, roundf, roundl - round to nearest integer, away from zero
rpc(3)
rpc - library routines for remote procedure calls
rpmatch(3)
rpmatch - determine if the answer to a question is affirmative or negative
rtime(3)
rtime - get time from a remote machine
rtnetlink(3)
rtnetlink - macros to manipulate rtnetlink messages
scalb(3)
scalb, scalbf, scalbl - multiply floating-point number by integral power of radix (OBSOLETE)
scalbln(3)
scalbn, scalbnf, scalbnl, scalbln, scalblnf, scalblnl - multiply floating-point number by integral power of radix
scandir(3)
scandir, scandirat, alphasort, versionsort - scan a directory for matching entries
scanf(3)
scanf, fscanf, sscanf, vscanf, vsscanf, vfscanf - input format conversion
sched_getcpu(3)
sched_getcpu - determine CPU on which the calling thread is running
seekdir(3)
seekdir - set the position of the next readdir() call in the directory stream.
sem_close(3)
sem_close - close a named semaphore
sem_destroy(3)
sem_destroy - destroy an unnamed semaphore
sem_getvalue(3)
sem_getvalue - get the value of a semaphore
sem_init(3)
sem_init - initialize an unnamed semaphore
sem_open(3)
sem_open - initialize and open a named semaphore
sem_post(3)
sem_post - unlock a semaphore
sem_unlink(3)
sem_unlink - remove a named semaphore
sem_wait(3)
sem_wait, sem_timedwait, sem_trywait - lock a semaphore
setaliasent(3)
setaliasent, endaliasent, getaliasent, getaliasent_r, getaliasbyname, getaliasbyname_r - read an alias entry
setbuf(3)
setbuf, setbuffer, setlinebuf, setvbuf - stream buffering operations
setenv(3)
setenv - change or add an environment variable
setjmp(3)
setjmp, sigsetjmp, longjmp, siglongjmp - performing a nonlocal goto
setlocale(3)
setlocale - set the current locale
setlogmask(3)
setlogmask - set log priority mask
setnetgrent(3)
setnetgrent, endnetgrent, getnetgrent, getnetgrent_r, innetgr - handle network group entries
shm_open(3)
shm_open, shm_unlink - create/open or unlink POSIX shared memory objects
siginterrupt(3)
siginterrupt - allow signals to interrupt system calls
signbit(3)
signbit - test sign of a real floating-point number
significand(3)
significand, significandf, significandl - get mantissa of floating-point number
sigpause(3)
sigpause - atomically release blocked signals and wait for interrupt
sigqueue(3)
sigqueue - queue a signal and data to a process
sigset(3)
sigset, sighold, sigrelse, sigignore - System V signal API
sigsetops(3)
sigemptyset, sigfillset, sigaddset, sigdelset, sigismember - POSIX signal set operations
sigvec(3)
sigvec, sigblock, sigsetmask, siggetmask, sigmask - BSD signal API
sigwait(3)
sigwait - wait for a signal
sin(3)
sin, sinf, sinl - sine function
sincos(3)
sincos, sincosf, sincosl - calculate sin and cos simultaneously
sinh(3)
sinh, sinhf, sinhl - hyperbolic sine function
sleep(3)
sleep - sleep for a specified number of seconds
sockatmark(3)
sockatmark - determine whether socket is at out-of-band mark
sqrt(3)
sqrt, sqrtf, sqrtl - square root function
statvfs(3)
statvfs, fstatvfs - get filesystem statistics
stdarg(3)
stdarg, va_start, va_arg, va_end, va_copy - variable argument lists
stdin(3)
stdin, stdout, stderr - standard I/O streams
stdio(3)
stdio - standard input/output library functions
stdio_ext(3)
__fbufsize, __flbf, __fpending, __fpurge, __freadable, __freading, __fsetlocking, __fwritable, __fwriting, _flushlbf - interfaces to stdio FILE structure
stpcpy(3)
stpcpy - copy a string returning a pointer to its end
stpncpy(3)
stpncpy - copy a fixed-size string, returning a pointer to its end
strcasecmp(3)
strcasecmp, strncasecmp - compare two strings ignoring case
strcat(3)
strcat, strncat - concatenate two strings
strchr(3)
strchr, strrchr, strchrnul - locate character in string
strcmp(3)
strcmp, strncmp - compare two strings
strcoll(3)
strcoll - compare two strings using the current locale
strcpy(3)
strcpy, strncpy - copy a string
strdup(3)
strdup, strndup, strdupa, strndupa - duplicate a string
strerror(3)
strerror, strerror_r, strerror_l - return string describing error number
strfmon(3)
strfmon, strfmon_l - convert monetary value to a string
strfromd(3)
strfromd, strfromf, strfroml - convert a floating-point value into a string
strfry(3)
strfry - randomize a string
strftime(3)
strftime - format date and time
string(3)
stpcpy, strcasecmp, strcat, strchr, strcmp, strcoll, strcpy, strcspn, strdup, strfry, strlen, strncat, strncmp, strncpy, strncasecmp, strpbrk, strrchr, strsep, strspn, strstr, strtok, strxfrm, index, rindex - string operations
strlen(3)
strlen - calculate the length of a string
strnlen(3)
strnlen - determine the length of a fixed-size string
strpbrk(3)
strpbrk - search a string for any of a set of bytes
strptime(3)
strptime - convert a string representation of time to a time tm structure
strsep(3)
strsep - extract token from string
strsignal(3)
strsignal - return string describing signal
strspn(3)
strspn, strcspn - get length of a prefix substring
strstr(3)
strstr, strcasestr - locate a substring
strtod(3)
strtod, strtof, strtold - convert ASCII string to floating-point number
strtoimax(3)
strtoimax, strtoumax - convert string to integer
strtok(3)
strtok, strtok_r - extract tokens from strings
strtol(3)
strtol, strtoll, strtoq - convert a string to a long integer
strtoul(3)
strtoul, strtoull, strtouq - convert a string to an unsigned long integer
strverscmp(3)
strverscmp - compare two version strings
strxfrm(3)
strxfrm - string transformation
swab(3)
swab - swap adjacent bytes
sysconf(3)
sysconf - get configuration information at run time
syslog(3)
closelog, openlog, syslog, vsyslog - send messages to the system logger
system(3)
system - execute a shell command
sysv_signal(3)
sysv_signal - signal handling with System V semantics
tan(3)
tan, tanf, tanl - tangent function
tanh(3)
tanh, tanhf, tanhl - hyperbolic tangent function
tcgetpgrp(3)
tcgetpgrp, tcsetpgrp - get and set terminal foreground process group
tcgetsid(3)
tcgetsid - get session ID
telldir(3)
telldir - return current location in directory stream
tempnam(3)
tempnam - create a name for a temporary file
termios(3)
termios, tcgetattr, tcsetattr, tcsendbreak, tcdrain, tcflush, tcflow, cfmakeraw, cfgetospeed, cfgetispeed, cfsetispeed, cfsetospeed, cfsetspeed - get and set terminal attributes, line control, get and set baud rate
tgamma(3)
tgamma, tgammaf, tgammal - true gamma function
timegm(3)
timegm, timelocal - inverses of gmtime and localtime
timeradd(3)
timeradd, timersub, timercmp, timerclear, timerisset - timeval operations
tmpfile(3)
tmpfile - create a temporary file
tmpnam(3)
tmpnam, tmpnam_r - create a name for a temporary file
toascii(3)
toascii - convert character to ASCII
toupper(3)
toupper, tolower, toupper_l, tolower_l - convert uppercase or lowercase
towctrans(3)
towctrans - wide-character transliteration
towlower(3)
towlower, towlower_l - convert a wide character to lowercase
towupper(3)
towupper, towupper_l - convert a wide character to uppercase
trunc(3)
trunc, truncf, truncl - round to integer, toward zero
tsearch(3)
tsearch, tfind, tdelete, twalk, tdestroy - manage a binary search tree
ttyname(3)
ttyname, ttyname_r - return name of a terminal
ttyslot(3)
ttyslot - find the slot of the current user’s terminal in some file
tzset(3)
tzset, tzname, timezone, daylight - initialize time conversion information
ualarm(3)
ualarm - schedule signal after given number of microseconds
ulimit(3)
ulimit - get and set user limits
undocumented(3)
undocumented - undocumented library functions
ungetwc(3)
ungetwc - push back a wide character onto a FILE stream
unlocked_stdio(3)
getc_unlocked, getchar_unlocked, putc_unlocked, putchar_unlocked - nonlocking stdio functions
unlockpt(3)
unlockpt - unlock a pseudoterminal master/slave pair
updwtmp(3)
updwtmp, logwtmp - append an entry to the wtmp file
uselocale(3)
uselocale - set/get the locale for the calling thread
usleep(3)
usleep - suspend execution for microsecond intervals
wcpcpy(3)
wcpcpy - copy a wide-character string, returning a pointer to its end
wcpncpy(3)
wcpncpy - copy a fixed-size string of wide characters, returning a pointer to its end
wcrtomb(3)
wcrtomb - convert a wide character to a multibyte sequence
wcscasecmp(3)
wcscasecmp - compare two wide-character strings, ignoring case
wcscat(3)
wcscat - concatenate two wide-character strings
wcschr(3)
wcschr - search a wide character in a wide-character string
wcscmp(3)
wcscmp - compare two wide-character strings
wcscpy(3)
wcscpy - copy a wide-character string
wcscspn(3)
wcscspn - search a wide-character string for any of a set of wide characters
wcsdup(3)
wcsdup - duplicate a wide-character string
wcslen(3)
wcslen - determine the length of a wide-character string
wcsncasecmp(3)
wcsncasecmp - compare two fixed-size wide-character strings, ignoring case
wcsncat(3)
wcsncat - concatenate two wide-character strings
wcsncmp(3)
wcsncmp - compare two fixed-size wide-character strings
wcsncpy(3)
wcsncpy - copy a fixed-size string of wide characters
wcsnlen(3)
wcsnlen - determine the length of a fixed-size wide-character string
wcsnrtombs(3)
wcsnrtombs - convert a wide-character string to a multibyte string
wcspbrk(3)
wcspbrk - search a wide-character string for any of a set of wide characters
wcsrchr(3)
wcsrchr - search a wide character in a wide-character string
wcsrtombs(3)
wcsrtombs - convert a wide-character string to a multibyte string
wcsspn(3)
wcsspn - advance in a wide-character string, skipping any of a set of wide characters
wcsstr(3)
wcsstr - locate a substring in a wide-character string
wcstoimax(3)
wcstoimax, wcstoumax - convert wide-character string to integer
wcstok(3)
wcstok - split wide-character string into tokens
wcstombs(3)
wcstombs - convert a wide-character string to a multibyte string
wcswidth(3)
wcswidth - determine columns needed for a fixed-size wide-character string
wctob(3)
wctob - try to represent a wide character as a single byte
wctomb(3)
wctomb - convert a wide character to a multibyte sequence
wctrans(3)
wctrans - wide-character translation mapping
wctype(3)
wctype - wide-character classification
wcwidth(3)
wcwidth - determine columns needed for a wide character
wmemchr(3)
wmemchr - search a wide character in a wide-character array
wmemcmp(3)
wmemcmp - compare two arrays of wide-characters
wmemcpy(3)
wmemcpy - copy an array of wide-characters
wmemmove(3)
wmemmove - copy an array of wide-characters
wmemset(3)
wmemset - fill an array of wide-characters with a constant wide character
wordexp(3)
wordexp, wordfree - perform word expansion like a posix-shell
wprintf(3)
wprintf, fwprintf, swprintf, vwprintf, vfwprintf, vswprintf - formatted wide-character output conversion
xcrypt(3)
xencrypt, xdecrypt, passwd2des - RFS password encryption
xdr(3)
xdr - library routines for external data representation
y0(3)
y0, y0f, y0l, y1, y1f, y1l, yn, ynf, ynl - Bessel functions of the second kind
__ppc_get_timebase(3)
__ppc_get_timebase, __ppc_get_timebase_freq - get the current value
of the Time Base Register on Power architecture and its frequency.
of the Time Base Register on Power architecture and its frequency.
__ppc_set_ppr_med(3)
__ppc_set_ppr_med, __ppc_set_ppr_very_low, __ppc_set_ppr_low, __ppc_set_ppr_med_low, __ppc_set_ppr_med_high - Set the Program Priority Register
__ppc_yield(3)
__ppc_yield, __ppc_mdoio, __ppc_mdoom - Hint the processor to release shared resources
__setfpucw(3)
__setfpucw - set FPU control word on i386 architecture (obsolete)
Latest updates

Ubuntu 20.04 focal/main: Updated from 5.04-1 to 5.05-1
Feb 10

Ubuntu 20.04 focal-proposed/main: Version 5.05-1 removed
Feb 10

Ubuntu 20.04 focal-proposed/main: Version 5.05-1 introduced
Feb 10

Ubuntu 20.04 focal/main: Version 5.04-1 introduced
2020-01-07

Debian 10.0 buster-backports/main: Updated from 5.02-1~bpo10+1 to 5.04-1~bpo10+1
2019-11-26

Debian 10.0 buster-backports/main: Version 5.02-1~bpo10+1 reintroduced
2019-11-24

Debian 10.0 buster-backports/main: Version 5.02-1~bpo10+1 removed
2019-11-24

Ubuntu 19.10 eoan/main: Version 5.02-1 reintroduced
2019-08-19

Ubuntu 19.10 eoan/main: Version 5.02-1 removed
2019-08-19

Debian 9.0 stretch-backports/main: Version 4.16-1~bpo9+1 reintroduced
2019-08-16

Debian 9.0 stretch-backports/main: Version 4.16-1~bpo9+1 removed
2019-08-15

Ubuntu 19.10 eoan/main: Version 5.02-1 reintroduced
2019-08-14

Ubuntu 19.10 eoan/main: Version 5.02-1 removed
2019-08-14

Debian 10.0 buster-backports/main: Version 5.02-1~bpo10+1 introduced
2019-08-13

Ubuntu 19.10 eoan/main: Updated from 5.01-1 to 5.02-1
2019-08-03

Ubuntu 19.10 eoan-proposed/main: Version 5.02-1 removed
2019-08-03

Ubuntu 19.10 eoan-proposed/main: Version 5.02-1 introduced
2019-08-03

Ubuntu 19.10 eoan/main: Version 5.01-1 reintroduced
2019-08-02

Ubuntu 19.10 eoan/main: Version 5.01-1 removed
2019-08-01

Debian 9.0 stretch-backports/main: Version 4.16-1~bpo9+1 reintroduced
2019-07-15
Related packages
manpages - Manual pages about using a GNU/Linux system