Man Pages in manpages-dev

  1. Carta.tech
  2. Packages
  3. manpages-dev
  • 444

    Section 2: System calls

    _Exit.2
    Terminate the calling process
    __clone2.2
    Create a child process
    _llseek.2
    Reposition read/write file offset
    _newselect.2
    Synchronous i/o multiplexing
    _syscall.2
    Invoking a system call without library support (obsolete)
    _sysctl.2
    Read/write system parameters
    accept.2
    Accept a connection on a socket
    accept4.2
    Accept a connection on a socket
    access.2
    Check user's permissions for a file
    acct.2
    Switch process accounting on or off
    add_key.2
    Add a key to the kernel's key management facility
    adjtimex.2
    Tune kernel clock
    afs_syscall.2
    Unimplemented system calls
    alarm.2
    Set an alarm clock for delivery of a signal
    alloc_hugepages.2
    Allocate or free huge pages
    arch_prctl.2
    Set architecture-specific thread state
    arm_fadvise.2
    Predeclare an access pattern for file data
    arm_fadvise64_64.2
    Predeclare an access pattern for file data
    arm_sync_file_range.2
    Sync a file segment with disk
    bdflush.2
    Start, flush, or tune buffer-dirty-flush daemon
    bind.2
    Bind a name to a socket
    break.2
    Unimplemented system calls
    brk.2
    Change data segment size
    cacheflush.2
    Flush contents of instruction and/or data cache
    capget.2
    Set/get capabilities of thread(s)
    capset.2
    Set/get capabilities of thread(s)
    chdir.2
    Change working directory
    chmod.2
    Change permissions of a file
    chown.2
    Change ownership of a file
    chown32.2
    Change ownership of a file
    chroot.2
    Change root directory
    clock_getres.2
    Clock and time functions
    clock_gettime.2
    Clock and time functions
    clock_nanosleep.2
    High-resolution sleep with specifiable clock
    clock_settime.2
    Clock and time functions
    clone.2
    Create a child process
    clone2.2
    Create a child process
    close.2
    Close a file descriptor
    connect.2
    Initiate a connection on a socket
    creat.2
    Open and possibly create a file
    create_module.2
    Create a loadable module entry
    delete_module.2
    Unload a kernel module
    dup.2
    Duplicate a file descriptor
    dup2.2
    Duplicate a file descriptor
    dup3.2
    Duplicate a file descriptor
    epoll_create.2
    Open an epoll file descriptor
    epoll_create1.2
    Open an epoll file descriptor
    epoll_ctl.2
    Control interface for an epoll descriptor
    epoll_pwait.2
    Wait for an i/o event on an epoll file descriptor
    epoll_wait.2
    Wait for an i/o event on an epoll file descriptor
    eventfd.2
    Create a file descriptor for event notification
    eventfd2.2
    Create a file descriptor for event notification
    execve.2
    Execute program
    exit.2
    Terminate the calling process
    exit_group.2
    Exit all threads in a process
    faccessat.2
    Check user's permissions for a file
    fadvise64.2
    Predeclare an access pattern for file data
    fadvise64_64.2
    Predeclare an access pattern for file data
    fallocate.2
    Manipulate file space
    fanotify_init.2
    Create and initialize fanotify group
    fanotify_mark.2
    Add, remove, or modify an fanotify mark on a filesystem object
    fattach.2
    Unimplemented system calls
    fchdir.2
    Change working directory
    fchmod.2
    Change permissions of a file
    fchmodat.2
    Change permissions of a file
    fchown.2
    Change ownership of a file
    fchown32.2
    Change ownership of a file
    fchownat.2
    Change ownership of a file
    fcntl.2
    Manipulate file descriptor
    fcntl64.2
    Manipulate file descriptor
    fdatasync.2
    Synchronize a file's in-core state with storage device
    fdetach.2
    Unimplemented system calls
    finit_module.2
    Load a kernel module
    flock.2
    Apply or remove an advisory lock on an open file
    fork.2
    Create a child process
    free_hugepages.2
    Allocate or free huge pages
    fstat.2
    Get file status
    fstat64.2
    Get file status
    fstatat.2
    Get file status
    fstatat64.2
    Get file status
    fstatfs.2
    Get filesystem statistics
    fstatfs64.2
    Get filesystem statistics
    fstatvfs.2
    Get filesystem statistics
    fsync.2
    Synchronize a file's in-core state with storage device
    ftruncate.2
    Truncate a file to a specified length
    ftruncate64.2
    Truncate a file to a specified length
    futex.2
    Fast user-space locking
    futimesat.2
    Change timestamps of a file relative to a directory file descriptor
    get_kernel_syms.2
    Retrieve exported kernel and module symbols
    get_mempolicy.2
    Retrieve numa memory policy for a process
    get_robust_list.2
    Get/set list of robust futexes
    get_thread_area.2
    Get a thread-local storage (tls) area
    getcontext.2
    Get or set the user context
    getcpu.2
    Determine cpu and numa node on which the calling thread is running
    getcwd.2
    Get current working directory
    getdents.2
    Get directory entries
    getdents64.2
    Get directory entries
    getdomainname.2
    Get/set nis domain name
    getegid.2
    Get group identity
    getegid32.2
    Get group identity
    geteuid.2
    Get user identity
    geteuid32.2
    Get user identity
    getgid.2
    Get group identity
    getgid32.2
    Get group identity
    getgroups.2
    Get/set list of supplementary group ids
    getgroups32.2
    Get/set list of supplementary group ids
    gethostid.2
    Get or set the unique identifier of the current host
    gethostname.2
    Get/set hostname
    getitimer.2
    Get or set value of an interval timer
    getmsg.2
    Unimplemented system calls
    getpagesize.2
    Get memory page size
    getpeername.2
    Get name of connected peer socket
    getpgid.2
    Set/get process group
    getpgrp.2
    Set/get process group
    getpid.2
    Get process identification
    getpmsg.2
    Unimplemented system calls
    getppid.2
    Get process identification
    getpriority.2
    Get/set program scheduling priority
    getresgid.2
    Get real, effective and saved user/group ids
    getresgid32.2
    Get real, effective and saved user/group ids
    getresuid.2
    Get real, effective and saved user/group ids
    getresuid32.2
    Get real, effective and saved user/group ids
    getrlimit.2
    Get/set resource limits
    getrusage.2
    Get resource usage
    getsid.2
    Get session id
    getsockname.2
    Get socket name
    getsockopt.2
    Get and set options on sockets
    gettid.2
    Get thread identification
    gettimeofday.2
    Get / set time
    getuid.2
    Get user identity
    getuid32.2
    Get user identity
    getunwind.2
    Copy the unwind data to caller's buffer
    gtty.2
    Unimplemented system calls
    idle.2
    Make process 0 idle
    inb.2
    Port i/o
    inb_p.2
    Port i/o
    init_module.2
    Load a kernel module
    inl.2
    Port i/o
    inl_p.2
    Port i/o
    inotify_add_watch.2
    Add a watch to an initialized inotify instance
    inotify_init.2
    Initialize an inotify instance
    inotify_init1.2
    Initialize an inotify instance
    inotify_rm_watch.2
    Remove an existing watch from an inotify instance
    insb.2
    Port i/o
    insl.2
    Port i/o
    insw.2
    Port i/o
    inw.2
    Port i/o
    inw_p.2
    Port i/o
    io_cancel.2
    Cancel an outstanding asynchronous i/o operation
    io_destroy.2
    Destroy an asynchronous i/o context
    io_getevents.2
    Read asynchronous i/o events from the completion queue
    io_setup.2
    Create an asynchronous i/o context
    io_submit.2
    Submit asynchronous i/o blocks for processing
    ioctl.2
    Control device
    ioctl_list.2
    List of ioctl calls in linux/i386 kernel
    ioperm.2
    Set port input/output permissions
    iopl.2
    Change i/o privilege level
    ioprio_get.2
    Get/set i/o scheduling class and priority
    ioprio_set.2
    Get/set i/o scheduling class and priority
    ipc.2
    System v ipc system calls
    isastream.2
    Unimplemented system calls
    kcmp.2
    Compare two processes to determine if they share a kernel resource
    kexec_load.2
    Load a new kernel for later execution
    keyctl.2
    Manipulate the kernel's key management facility
    kill.2
    Send signal to a process
    killpg.2
    Send signal to a process group
    lchown.2
    Change ownership of a file
    lchown32.2
    Change ownership of a file
    link.2
    Make a new name for a file
    linkat.2
    Make a new name for a file
    listen.2
    Listen for connections on a socket
    llseek.2
    Reposition read/write file offset
    lock.2
    Unimplemented system calls
    lookup_dcookie.2
    Return a directory entry's path
    lseek.2
    Reposition read/write file offset
    lstat.2
    Get file status
    lstat64.2
    Get file status
    madvise.2
    Give advice about use of memory
    madvise1.2
    Unimplemented system calls
    mbind.2
    Set memory policy for a memory range
    migrate_pages.2
    Move all pages in a process to another set of nodes
    mincore.2
    Determine whether pages are resident in memory
    mkdir.2
    Create a directory
    mkdirat.2
    Create a directory
    mknod.2
    Create a special or ordinary file
    mknodat.2
    Create a special or ordinary file
    mlock.2
    Lock and unlock memory
    mlockall.2
    Lock and unlock memory
    mmap.2
    Map or unmap files or devices into memory
    mmap2.2
    Map files or devices into memory
    modify_ldt.2
    Get or set ldt
    mount.2
    Mount filesystem
    move_pages.2
    Move individual pages of a process to another node
    mprotect.2
    Set protection on a region of memory
    mpx.2
    Unimplemented system calls
    mq_getsetattr.2
    Get/set message queue attributes
    mq_notify.2
    Register for notification when a message is available
    mq_open.2
    Open a message queue
    mq_timedreceive.2
    Receive a message from a message queue
    mq_timedsend.2
    Send a message to a message queue
    mq_unlink.2
    Remove a message queue
    mremap.2
    Remap a virtual memory address
    msgctl.2
    System v message control operations
    msgget.2
    Get a system v message queue identifier
    msgop.2
    System v message queue operations
    msgrcv.2
    System v message queue operations
    msgsnd.2
    System v message queue operations
    msync.2
    Synchronize a file with a memory map
    munlock.2
    Lock and unlock memory
    munlockall.2
    Lock and unlock memory
    munmap.2
    Map or unmap files or devices into memory
    name_to_handle_at.2
    Obtain handle for a pathname and open file via a handle
    nanosleep.2
    High-resolution sleep
    nfsservctl.2
    Syscall interface to kernel nfs daemon
    nice.2
    Change process priority
    oldfstat.2
    Get file status
    oldlstat.2
    Get file status
    oldolduname.2
    Get name and information about current kernel
    oldstat.2
    Get file status
    olduname.2
    Get name and information about current kernel
    open.2
    Open and possibly create a file
    open_by_handle_at.2
    Obtain handle for a pathname and open file via a handle
    openat.2
    Open and possibly create a file
    outb.2
    Port i/o
    outb_p.2
    Port i/o
    outl.2
    Port i/o
    outl_p.2
    Port i/o
    outsb.2
    Port i/o
    outsl.2
    Port i/o
    outsw.2
    Port i/o
    outw.2
    Port i/o
    outw_p.2
    Port i/o
    pause.2
    Wait for signal
    pciconfig_iobase.2
    Pci device information handling
    pciconfig_read.2
    Pci device information handling
    pciconfig_write.2
    Pci device information handling
    perf_event_open.2
    Set up performance monitoring
    perfmonctl.2
    Interface to ia-64 performance monitoring unit
    personality.2
    Set the process execution domain
    phys.2
    Unimplemented system calls
    pipe.2
    Create pipe
    pipe2.2
    Create pipe
    pivot_root.2
    Change the root filesystem
    poll.2
    Wait for some event on a file descriptor
    posix_fadvise.2
    Predeclare an access pattern for file data
    ppoll.2
    Wait for some event on a file descriptor
    prctl.2
    Operations on a process
    pread.2
    Read from or write to a file descriptor at a given offset
    pread64.2
    Read from or write to a file descriptor at a given offset
    preadv.2
    Read or write data into multiple buffers
    prlimit.2
    Get/set resource limits
    process_vm_readv.2
    Transfer data between process address spaces
    process_vm_writev.2
    Transfer data between process address spaces
    prof.2
    Unimplemented system calls
    pselect.2
    Synchronous i/o multiplexing
    pselect6.2
    Synchronous i/o multiplexing
    ptrace.2
    Process trace
    putmsg.2
    Unimplemented system calls
    putpmsg.2
    Unimplemented system calls
    pwrite.2
    Read from or write to a file descriptor at a given offset
    pwrite64.2
    Read from or write to a file descriptor at a given offset
    pwritev.2
    Read or write data into multiple buffers
    quotactl.2
    Manipulate disk quotas
    read.2
    Read from a file descriptor
    readahead.2
    Initiate file readahead into page cache
    readdir.2
    Read directory entry
    readlink.2
    Read value of a symbolic link
    readlinkat.2
    Read value of a symbolic link
    readv.2
    Read or write data into multiple buffers
    reboot.2
    Reboot or enable/disable ctrl-alt-del
    recv.2
    Receive a message from a socket
    recvfrom.2
    Receive a message from a socket
    recvmmsg.2
    Receive multiple messages on a socket
    recvmsg.2
    Receive a message from a socket
    remap_file_pages.2
    Create a nonlinear file mapping
    rename.2
    Change the name or location of a file
    renameat.2
    Change the name or location of a file
    renameat2.2
    Change the name or location of a file
    request_key.2
    Request a key from the kernel's key management facility
    restart_syscall.2
    Restart a system call after interruption by a stop signal
    rmdir.2
    Delete a directory
    rt_sigaction.2
    Examine and change a signal action
    rt_sigpending.2
    Examine pending signals
    rt_sigprocmask.2
    Examine and change blocked signals
    rt_sigqueueinfo.2
    Queue a signal and data
    rt_sigreturn.2
    Return from signal handler and cleanup stack frame
    rt_sigsuspend.2
    Wait for a signal
    rt_sigtimedwait.2
    Synchronously wait for queued signals
    rt_tgsigqueueinfo.2
    Queue a signal and data
    s390_runtime_instr.2
    Enable/disable s390 cpu run-time instrumentation
    sbrk.2
    Change data segment size
    sched_get_priority_max.2
    Get static priority range
    sched_get_priority_min.2
    Get static priority range
    sched_getaffinity.2
    Set and get a thread's cpu affinity mask
    sched_getattr.2
    Set and get scheduling policy and attributes
    sched_getparam.2
    Set and get scheduling parameters
    sched_getscheduler.2
    Set and get scheduling policy/parameters
    sched_rr_get_interval.2
    Get the sched_rr interval for the named process
    sched_setaffinity.2
    Set and get a thread's cpu affinity mask
    sched_setattr.2
    Set and get scheduling policy and attributes
    sched_setparam.2
    Set and get scheduling parameters
    sched_setscheduler.2
    Set and get scheduling policy/parameters
    sched_yield.2
    Yield the processor
    security.2
    Unimplemented system calls
    select.2
    Synchronous i/o multiplexing
    select_tut.2
    Synchronous i/o multiplexing
    semctl.2
    System v semaphore control operations
    semget.2
    Get a system v semaphore set identifier
    semop.2
    System v semaphore operations
    semtimedop.2
    System v semaphore operations
    send.2
    Send a message on a socket
    sendfile.2
    Transfer data between file descriptors
    sendfile64.2
    Transfer data between file descriptors
    sendmmsg.2
    Send multiple messages on a socket
    sendmsg.2
    Send a message on a socket
    sendto.2
    Send a message on a socket
    set_robust_list.2
    Get/set list of robust futexes
    set_thread_area.2
    Set a thread local storage (tls) area
    set_tid_address.2
    Set pointer to thread id
    setcontext.2
    Get or set the user context
    setdomainname.2
    Get/set nis domain name
    setegid.2
    Set effective user or group id
    seteuid.2
    Set effective user or group id
    setfsgid.2
    Set group identity used for filesystem checks
    setfsgid32.2
    Set group identity used for filesystem checks
    setfsuid.2
    Set user identity used for filesystem checks
    setfsuid32.2
    Set user identity used for filesystem checks
    setgid.2
    Set group identity
    setgid32.2
    Set group identity
    setgroups.2
    Get/set list of supplementary group ids
    setgroups32.2
    Get/set list of supplementary group ids
    sethostid.2
    Get or set the unique identifier of the current host
    sethostname.2
    Get/set hostname
    setitimer.2
    Get or set value of an interval timer
    setns.2
    Reassociate thread with a namespace
    setpgid.2
    Set/get process group
    setpgrp.2
    Set/get process group
    setpriority.2
    Get/set program scheduling priority
    setregid.2
    Set real and/or effective user or group id
    setregid32.2
    Set real and/or effective user or group id
    setresgid.2
    Set real, effective and saved user or group id
    setresgid32.2
    Set real, effective and saved user or group id
    setresuid.2
    Set real, effective and saved user or group id
    setresuid32.2
    Set real, effective and saved user or group id
    setreuid.2
    Set real and/or effective user or group id
    setreuid32.2
    Set real and/or effective user or group id
    setrlimit.2
    Get/set resource limits
    setsid.2
    Creates a session and sets the process group id
    setsockopt.2
    Get and set options on sockets
    settimeofday.2
    Get / set time
    setuid.2
    Set user identity
    setuid32.2
    Set user identity
    setup.2
    Setup devices and filesystems, mount root filesystem
    sgetmask.2
    Manipulation of signal mask (obsolete)
    shmat.2
    System v shared memory operations
    shmctl.2
    System v shared memory control
    shmdt.2
    System v shared memory operations
    shmget.2
    Allocates a system v shared memory segment
    shmop.2
    System v shared memory operations
    shutdown.2
    Shut down part of a full-duplex connection
    sigaction.2
    Examine and change a signal action
    sigaltstack.2
    Set and/or get signal stack context
    signal.2
    Ansi c signal handling
    signalfd.2
    Create a file descriptor for accepting signals
    signalfd4.2
    Create a file descriptor for accepting signals
    sigpending.2
    Examine pending signals
    sigprocmask.2
    Examine and change blocked signals
    sigqueue.2
    Queue a signal and data to a process
    sigreturn.2
    Return from signal handler and cleanup stack frame
    sigsuspend.2
    Wait for a signal
    sigtimedwait.2
    Synchronously wait for queued signals
    sigwaitinfo.2
    Synchronously wait for queued signals
    socket.2
    Create an endpoint for communication
    socketcall.2
    Socket system calls
    socketpair.2
    Create a pair of connected sockets
    splice.2
    Splice data to/from a pipe
    spu_create.2
    Create a new spu context
    spu_run.2
    Execute an spu context
    ssetmask.2
    Manipulation of signal mask (obsolete)
    stat.2
    Get file status
    stat64.2
    Get file status
    statfs.2
    Get filesystem statistics
    statfs64.2
    Get filesystem statistics
    statvfs.2
    Get filesystem statistics
    stime.2
    Set time
    stty.2
    Unimplemented system calls
    subpage_prot.2
    Define a subpage protection for an address range
    swapoff.2
    Start/stop swapping to file/device
    swapon.2
    Start/stop swapping to file/device
    symlink.2
    Make a new name for a file
    symlinkat.2
    Make a new name for a file
    sync.2
    Commit buffer cache to disk
    sync_file_range.2
    Sync a file segment with disk
    sync_file_range2.2
    Sync a file segment with disk
    syncfs.2
    Commit buffer cache to disk
    syscall.2
    Indirect system call
    syscalls.2
    Linux system calls
    sysctl.2
    Read/write system parameters
    sysfs.2
    Get filesystem type information
    sysinfo.2
    Returns information on overall system statistics
    syslog.2
    Read and/or clear kernel message ring buffer; set console_loglevel
    tee.2
    Duplicating pipe content
    tgkill.2
    Send a signal to a thread
    time.2
    Get time in seconds
    timer_create.2
    Create a posix per-process timer
    timer_delete.2
    Delete a posix per-process timer
    timer_getoverrun.2
    Get overrun count for a posix per-process timer
    timer_gettime.2
    Arm/disarm and fetch state of posix per-process timer
    timer_settime.2
    Arm/disarm and fetch state of posix per-process timer
    timerfd_create.2
    Timers that notify via file descriptors
    timerfd_gettime.2
    Timers that notify via file descriptors
    timerfd_settime.2
    Timers that notify via file descriptors
    times.2
    Get process times
    tkill.2
    Send a signal to a thread
    truncate.2
    Truncate a file to a specified length
    truncate64.2
    Truncate a file to a specified length
    tuxcall.2
    Unimplemented system calls
    ugetrlimit.2
    Get/set resource limits
    umask.2
    Set file mode creation mask
    umount.2
    Unmount filesystem
    umount2.2
    Unmount filesystem
    uname.2
    Get name and information about current kernel
    unimplemented.2
    Unimplemented system calls
    unlink.2
    Delete a name and possibly the file it refers to
    unlinkat.2
    Delete a name and possibly the file it refers to
    unshare.2
    Disassociate parts of the process execution context
    uselib.2
    Load shared library
    ustat.2
    Get filesystem statistics
    utime.2
    Change file last access and modification times
    utimensat.2
    Change file timestamps with nanosecond precision
    utimes.2
    Change file last access and modification times
    vfork.2
    Create a child process and block parent
    vhangup.2
    Virtually hangup the current terminal
    vm86.2
    Enter virtual 8086 mode
    vm86old.2
    Enter virtual 8086 mode
    vmsplice.2
    Splice user pages into a pipe
    vserver.2
    Unimplemented system calls
    wait.2
    Wait for process to change state
    wait3.2
    Wait for process to change state, bsd style
    wait4.2
    Wait for process to change state, bsd style
    waitid.2
    Wait for process to change state
    waitpid.2
    Wait for process to change state
    write.2
    Write to a file descriptor
    writev.2
    Read or write data into multiple buffers
  • 1509

    Section 3: Library calls

    CIRCLEQ_ENTRY.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_HEAD.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_INIT.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_INSERT_AFTER.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_INSERT_BEFORE.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_INSERT_HEAD.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_INSERT_TAIL.3
    Implementations of lists, tail queues, and circular queues
    CIRCLEQ_REMOVE.3
    Implementations of lists, tail queues, and circular queues
    CMSG_ALIGN.3
    Access ancillary data
    CMSG_FIRSTHDR.3
    Access ancillary data
    CMSG_NXTHDR.3
    Access ancillary data
    CMSG_SPACE.3
    Access ancillary data
    CPU_ALLOC.3
    Macros for manipulating cpu sets
    CPU_ALLOC_SIZE.3
    Macros for manipulating cpu sets
    CPU_AND.3
    Macros for manipulating cpu sets
    CPU_AND_S.3
    Macros for manipulating cpu sets
    CPU_CLR.3
    Macros for manipulating cpu sets
    CPU_CLR_S.3
    Macros for manipulating cpu sets
    CPU_COUNT.3
    Macros for manipulating cpu sets
    CPU_COUNT_S.3
    Macros for manipulating cpu sets
    CPU_EQUAL.3
    Macros for manipulating cpu sets
    CPU_EQUAL_S.3
    Macros for manipulating cpu sets
    CPU_FREE.3
    Macros for manipulating cpu sets
    CPU_ISSET.3
    Macros for manipulating cpu sets
    CPU_ISSET_S.3
    Macros for manipulating cpu sets
    CPU_OR.3
    Macros for manipulating cpu sets
    CPU_OR_S.3
    Macros for manipulating cpu sets
    CPU_SET.3
    Macros for manipulating cpu sets
    CPU_SET_S.3
    Macros for manipulating cpu sets
    CPU_XOR.3
    Macros for manipulating cpu sets
    CPU_XOR_S.3
    Macros for manipulating cpu sets
    CPU_ZERO.3
    Macros for manipulating cpu sets
    CPU_ZERO_S.3
    Macros for manipulating cpu sets
    DES_FAILED.3
    Fast des encryption
    FD_CLR.3
    Synchronous i/o multiplexing
    FD_ISSET.3
    Synchronous i/o multiplexing
    FD_SET.3
    Synchronous i/o multiplexing
    FD_ZERO.3
    Synchronous i/o multiplexing
    HUGE_VAL.3
    Floating-point constants
    HUGE_VALF.3
    Floating-point constants
    HUGE_VALL.3
    Floating-point constants
    INFINITY.3
    Floating-point constants
    LIST_ENTRY.3
    Implementations of lists, tail queues, and circular queues
    LIST_HEAD.3
    Implementations of lists, tail queues, and circular queues
    LIST_INIT.3
    Implementations of lists, tail queues, and circular queues
    LIST_INSERT_AFTER.3
    Implementations of lists, tail queues, and circular queues
    LIST_INSERT_HEAD.3
    Implementations of lists, tail queues, and circular queues
    LIST_REMOVE.3
    Implementations of lists, tail queues, and circular queues
    MB_CUR_MAX.3
    Maximum length of a multibyte character in the current locale
    MB_LEN_MAX.3
    Maximum multibyte length of a character across all locales
    NAN.3
    Floating-point constants
    TAILQ_ENTRY.3
    Implementations of lists, tail queues, and circular queues
    TAILQ_HEAD.3
    Implementations of lists, tail queues, and circular queues
    TAILQ_INIT.3
    Implementations of lists, tail queues, and circular queues
    TAILQ_INSERT_AFTER.3
    Implementations of lists, tail queues, and circular queues
    TAILQ_INSERT_HEAD.3
    Implementations of lists, tail queues, and circular queues
    TAILQ_INSERT_TAIL.3
    Implementations of lists, tail queues, and circular queues
    TAILQ_REMOVE.3
    Implementations of lists, tail queues, and circular queues
    __after_morecore_hook.3
    Malloc debugging variables
    __fbufsize.3
    Interfaces to stdio file structure
    __flbf.3
    Interfaces to stdio file structure
    __fpending.3
    Interfaces to stdio file structure
    __fpurge.3
    Purge a stream
    __freadable.3
    Interfaces to stdio file structure
    __freading.3
    Interfaces to stdio file structure
    __free_hook.3
    Malloc debugging variables
    __fsetlocking.3
    Interfaces to stdio file structure
    __fwritable.3
    Interfaces to stdio file structure
    __fwriting.3
    Interfaces to stdio file structure
    __malloc_hook.3
    Malloc debugging variables
    __malloc_initialize_hook.3
    Malloc debugging variables
    __memalign_hook.3
    Malloc debugging variables
    __realloc_hook.3
    Malloc debugging variables
    __setfpucw.3
    Set fpu control word on i386 architecture (obsolete)
    _flushlbf.3
    Interfaces to stdio file structure
    a64l.3
    Convert between long and base-64
    abort.3
    Cause abnormal process termination
    abs.3
    Compute the absolute value of an integer
    acos.3
    Arc cosine function
    acosf.3
    Arc cosine function
    acosh.3
    Inverse hyperbolic cosine function
    acoshf.3
    Inverse hyperbolic cosine function
    acoshl.3
    Inverse hyperbolic cosine function
    acosl.3
    Arc cosine function
    addmntent.3
    Get filesystem descriptor file entry
    addseverity.3
    Introduce new severity classes
    adjtime.3
    Correct the time to synchronize the system clock
    aio_cancel.3
    Cancel an outstanding asynchronous i/o request
    aio_error.3
    Get error status of asynchronous i/o operation
    aio_fsync.3
    Asynchronous file synchronization
    aio_init.3
    Asynchronous i/o initialization
    aio_read.3
    Asynchronous read
    aio_return.3
    Get return status of asynchronous i/o operation
    aio_suspend.3
    Wait for asynchronous i/o operation or timeout
    aio_write.3
    Asynchronous write
    aligned_alloc.3
    Allocate aligned memory
    alloca.3
    Allocate memory that is automatically freed
    alphasort.3
    Scan a directory for matching entries
    argz.3
    Functions to handle an argz list
    argz_add.3
    Functions to handle an argz list
    argz_add_sep.3
    Functions to handle an argz list
    argz_append.3
    Functions to handle an argz list
    argz_count.3
    Functions to handle an argz list
    argz_create.3
    Functions to handle an argz list
    argz_create_sep.3
    Functions to handle an argz list
    argz_delete.3
    Functions to handle an argz list
    argz_extract.3
    Functions to handle an argz list
    argz_insert.3
    Functions to handle an argz list
    argz_next.3
    Functions to handle an argz list
    argz_replace.3
    Functions to handle an argz list
    argz_stringify.3
    Functions to handle an argz list
    asctime.3
    Transform date and time to broken-down time or ascii
    asctime_r.3
    Transform date and time to broken-down time or ascii
    asin.3
    Arc sine function
    asinf.3
    Arc sine function
    asinh.3
    Inverse hyperbolic sine function
    asinhf.3
    Inverse hyperbolic sine function
    asinhl.3
    Inverse hyperbolic sine function
    asinl.3
    Arc sine function
    asprintf.3
    Print to allocated string
    assert.3
    Abort the program if assertion is false
    assert_perror.3
    Test errnum and abort
    atan.3
    Arc tangent function
    atan2.3
    Arc tangent function of two variables
    atan2f.3
    Arc tangent function of two variables
    atan2l.3
    Arc tangent function of two variables
    atanf.3
    Arc tangent function
    atanh.3
    Inverse hyperbolic tangent function
    atanhf.3
    Inverse hyperbolic tangent function
    atanhl.3
    Inverse hyperbolic tangent function
    atanl.3
    Arc tangent function
    atexit.3
    Register a function to be called at normal process termination
    atof.3
    Convert a string to a double
    atoi.3
    Convert a string to an integer
    atol.3
    Convert a string to an integer
    atoll.3
    Convert a string to an integer
    atoq.3
    Convert a string to an integer
    auth_destroy.3
    Library routines for remote procedure calls
    authnone_create.3
    Library routines for remote procedure calls
    authunix_create.3
    Library routines for remote procedure calls
    authunix_create_default.3
    Library routines for remote procedure calls
    backtrace.3
    Support for application self-debugging
    backtrace_symbols.3
    Support for application self-debugging
    backtrace_symbols_fd.3
    Support for application self-debugging
    basename.3
    Parse pathname components
    bcmp.3
    Compare byte sequences
    bcopy.3
    Copy byte sequence
    be16toh.3
    Convert values between host and big-/little-endian byte order
    be32toh.3
    Convert values between host and big-/little-endian byte order
    be64toh.3
    Convert values between host and big-/little-endian byte order
    bindresvport.3
    Bind a socket to a privileged ip port
    bsd_signal.3
    Signal handling with bsd semantics
    bsearch.3
    Binary search of a sorted array
    bstring.3
    Byte string operations
    btowc.3
    Convert single byte to wide character
    btree.3
    Btree database access method
    byteorder.3
    Convert values between host and network byte order
    bzero.3
    Write zero-valued bytes
    cabs.3
    Absolute value of a complex number
    cabsf.3
    Absolute value of a complex number
    cabsl.3
    Absolute value of a complex number
    cacos.3
    Complex arc cosine
    cacosf.3
    Complex arc cosine
    cacosh.3
    Complex arc hyperbolic cosine
    cacoshf.3
    Complex arc hyperbolic cosine
    cacoshl.3
    Complex arc hyperbolic cosine
    cacosl.3
    Complex arc cosine
    calloc.3
    Allocate and free dynamic memory
    callrpc.3
    Library routines for remote procedure calls
    canonicalize_file_name.3
    Return the canonicalized absolute pathname
    carg.3
    Calculate the complex argument
    cargf.3
    Calculate the complex argument
    cargl.3
    Calculate the complex argument
    casin.3
    Complex arc sine
    casinf.3
    Complex arc sine
    casinh.3
    Complex arc sine hyperbolic
    casinhf.3
    Complex arc sine hyperbolic
    casinhl.3
    Complex arc sine hyperbolic
    casinl.3
    Complex arc sine
    catan.3
    Complex arc tangents
    catanf.3
    Complex arc tangents
    catanh.3
    Complex arc tangents hyperbolic
    catanhf.3
    Complex arc tangents hyperbolic
    catanhl.3
    Complex arc tangents hyperbolic
    catanl.3
    Complex arc tangents
    catclose.3
    Open/close a message catalog
    catgets.3
    Get message from a message catalog
    catopen.3
    Open/close a message catalog
    cbc_crypt.3
    Fast des encryption
    cbrt.3
    Cube root function
    cbrtf.3
    Cube root function
    cbrtl.3
    Cube root function
    ccos.3
    Complex cosine function
    ccosf.3
    Complex cosine function
    ccosh.3
    Complex hyperbolic cosine
    ccoshf.3
    Complex hyperbolic cosine
    ccoshl.3
    Complex hyperbolic cosine
    ccosl.3
    Complex cosine function
    ceil.3
    Ceiling function: smallest integral value not less than argument
    ceilf.3
    Ceiling function: smallest integral value not less than argument
    ceill.3
    Ceiling function: smallest integral value not less than argument
    cexp.3
    Complex exponential function
    cexp2.3
    Base-2 exponent of a complex number
    cexp2f.3
    Base-2 exponent of a complex number
    cexp2l.3
    Base-2 exponent of a complex number
    cexpf.3
    Complex exponential function
    cexpl.3
    Complex exponential function
    cfgetispeed.3
    Get and set terminal attributes, line control, get and set baud rate
    cfgetospeed.3
    Get and set terminal attributes, line control, get and set baud rate
    cfmakeraw.3
    Get and set terminal attributes, line control, get and set baud rate
    cfree.3
    Free allocated memory
    cfsetispeed.3
    Get and set terminal attributes, line control, get and set baud rate
    cfsetospeed.3
    Get and set terminal attributes, line control, get and set baud rate
    cfsetspeed.3
    Get and set terminal attributes, line control, get and set baud rate
    cimag.3
    Get imaginary part of a complex number
    cimagf.3
    Get imaginary part of a complex number
    cimagl.3
    Get imaginary part of a complex number
    clearenv.3
    Clear the environment
    clearerr.3
    Check and reset stream status
    clearerr_unlocked.3
    Nonlocking stdio functions
    clnt_broadcast.3
    Library routines for remote procedure calls
    clnt_call.3
    Library routines for remote procedure calls
    clnt_control.3
    Library routines for remote procedure calls
    clnt_create.3
    Library routines for remote procedure calls
    clnt_destroy.3
    Library routines for remote procedure calls
    clnt_freeres.3
    Library routines for remote procedure calls
    clnt_geterr.3
    Library routines for remote procedure calls
    clnt_pcreateerror.3
    Library routines for remote procedure calls
    clnt_perrno.3
    Library routines for remote procedure calls
    clnt_perror.3
    Library routines for remote procedure calls
    clnt_spcreateerror.3
    Library routines for remote procedure calls
    clnt_sperrno.3
    Library routines for remote procedure calls
    clnt_sperror.3
    Library routines for remote procedure calls
    clntraw_create.3
    Library routines for remote procedure calls
    clnttcp_create.3
    Library routines for remote procedure calls
    clntudp_bufcreate.3
    Library routines for remote procedure calls
    clntudp_create.3
    Library routines for remote procedure calls
    clock.3
    Determine processor time
    clock_getcpuclockid.3
    Obtain id of a process cpu-time clock
    clock_getres.3
    Clock and time functions
    clock_gettime.3
    Clock and time functions
    clock_settime.3
    Clock and time functions
    clog.3
    Natural logarithm of a complex number
    clog10.3
    Base-10 logarithm of a complex number
    clog10f.3
    Base-10 logarithm of a complex number
    clog10l.3
    Base-10 logarithm of a complex number
    clog2.3
    Base-2 logarithm of a complex number
    clog2f.3
    Base-2 logarithm of a complex number
    clog2l.3
    Base-2 logarithm of a complex number
    clogf.3
    Natural logarithm of a complex number
    clogl.3
    Natural logarithm of a complex number
    closedir.3
    Close a directory
    closelog.3
    Send messages to the system logger
    cmsg.3
    Access ancillary data
    confstr.3
    Get configuration dependent string variables
    conj.3
    Calculate the complex conjugate
    conjf.3
    Calculate the complex conjugate
    conjl.3
    Calculate the complex conjugate
    copysign.3
    Copy sign of a number
    copysignf.3
    Copy sign of a number
    copysignl.3
    Copy sign of a number
    cos.3
    Cosine function
    cosf.3
    Cosine function
    cosh.3
    Hyperbolic cosine function
    coshf.3
    Hyperbolic cosine function
    coshl.3
    Hyperbolic cosine function
    cosl.3
    Cosine function
    cpow.3
    Complex power function
    cpowf.3
    Complex power function
    cpowl.3
    Complex power function
    cproj.3
    Project into riemann sphere
    cprojf.3
    Project into riemann sphere
    cprojl.3
    Project into riemann sphere
    creal.3
    Get real part of a complex number
    crealf.3
    Get real part of a complex number
    creall.3
    Get real part of a complex number
    crypt.3
    Password and data encryption
    crypt_r.3
    Password and data encryption
    csin.3
    Complex sine function
    csinf.3
    Complex sine function
    csinh.3
    Complex hyperbolic sine
    csinhf.3
    Complex hyperbolic sine
    csinhl.3
    Complex hyperbolic sine
    csinl.3
    Complex sine function
    csqrt.3
    Complex square root
    csqrtf.3
    Complex square root
    csqrtl.3
    Complex square root
    ctan.3
    Complex tangent function
    ctanf.3
    Complex tangent function
    ctanh.3
    Complex hyperbolic tangent
    ctanhf.3
    Complex hyperbolic tangent
    ctanhl.3
    Complex hyperbolic tangent
    ctanl.3
    Complex tangent function
    ctermid.3
    Get controlling terminal name
    ctime.3
    Transform date and time to broken-down time or ascii
    ctime_r.3
    Transform date and time to broken-down time or ascii
    cuserid.3
    Get username
    daemon.3
    Run in the background
    daylight.3
    Initialize time conversion information
    db.3
    Database access methods
    dbopen.3
    Database access methods
    des_crypt.3
    Fast des encryption
    des_setparity.3
    Fast des encryption
    difftime.3
    Calculate time difference
    dirfd.3
    Get directory stream file descriptor
    dirname.3
    Parse pathname components
    div.3
    Compute quotient and remainder of an integer division
    dl_iterate_phdr.3
    Walk through list of shared objects
    dladdr.3
    Programming interface to dynamic linking loader
    dlclose.3
    Programming interface to dynamic linking loader
    dlerror.3
    Programming interface to dynamic linking loader
    dlopen.3
    Programming interface to dynamic linking loader
    dlsym.3
    Programming interface to dynamic linking loader
    dlvsym.3
    Programming interface to dynamic linking loader
    dn_comp.3
    Resolver routines
    dn_expand.3
    Resolver routines
    dprintf.3
    Print to a file descriptor
    drand48.3
    Generate uniformly distributed pseudo-random numbers
    drand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    drem.3
    Floating-point remainder function
    dremf.3
    Floating-point remainder function
    dreml.3
    Floating-point remainder function
    duplocale.3
    Duplicate a locale object
    dysize.3
    Get number of days for a given year
    eaccess.3
    Check effective user's permissions for a file
    ecb_crypt.3
    Fast des encryption
    ecvt.3
    Convert a floating-point number to a string
    ecvt_r.3
    Convert a floating-point number to a string
    edata.3
    End of program segments
    encrypt.3
    Encrypt 64-bit messages
    encrypt_r.3
    Encrypt 64-bit messages
    end.3
    End of program segments
    endaliasent.3
    Read an alias entry
    endfsent.3
    Handle fstab entries
    endgrent.3
    Get group file entry
    endhostent.3
    Get network host entry
    endian.3
    Convert values between host and big-/little-endian byte order
    endmntent.3
    Get filesystem descriptor file entry
    endnetent.3
    Get network entry
    endnetgrent.3
    Handle network group entries
    endprotoent.3
    Get protocol entry
    endpwent.3
    Get password file entry
    endrpcent.3
    Get rpc entry
    endservent.3
    Get service entry
    endspent.3
    Get shadow password file entry
    endttyent.3
    Get ttys file entry
    endusershell.3
    Get permitted user shells
    endutent.3
    Access utmp file entries
    endutxent.3
    Access utmp file entries
    envz.3
    Environment string support
    envz_add.3
    Environment string support
    envz_entry.3
    Environment string support
    envz_get.3
    Environment string support
    envz_merge.3
    Environment string support
    envz_remove.3
    Environment string support
    envz_strip.3
    Environment string support
    erand48.3
    Generate uniformly distributed pseudo-random numbers
    erand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    erf.3
    Error function
    erfc.3
    Complementary error function
    erfcf.3
    Complementary error function
    erfcl.3
    Complementary error function
    erff.3
    Error function
    erfl.3
    Error function
    err.3
    Formatted error messages
    errno.3
    Number of last error
    error.3
    Glibc error reporting functions
    error_at_line.3
    Glibc error reporting functions
    error_message_count.3
    Glibc error reporting functions
    error_one_per_line.3
    Glibc error reporting functions
    error_print_progname.3
    Glibc error reporting functions
    errx.3
    Formatted error messages
    etext.3
    End of program segments
    ether_aton.3
    Ethernet address manipulation routines
    ether_aton_r.3
    Ethernet address manipulation routines
    ether_hostton.3
    Ethernet address manipulation routines
    ether_line.3
    Ethernet address manipulation routines
    ether_ntoa.3
    Ethernet address manipulation routines
    ether_ntoa_r.3
    Ethernet address manipulation routines
    ether_ntohost.3
    Ethernet address manipulation routines
    euidaccess.3
    Check effective user's permissions for a file
    eventfd_read.3
    Create a file descriptor for event notification
    eventfd_write.3
    Create a file descriptor for event notification
    exec.3
    Execute a file
    execl.3
    Execute a file
    execle.3
    Execute a file
    execlp.3
    Execute a file
    execv.3
    Execute a file
    execvp.3
    Execute a file
    execvpe.3
    Execute a file
    exit.3
    Cause normal process termination
    exp.3
    Base-e exponential function
    exp10.3
    Base-10 exponential function
    exp10f.3
    Base-10 exponential function
    exp10l.3
    Base-10 exponential function
    exp2.3
    Base-2 exponential function
    exp2f.3
    Base-2 exponential function
    exp2l.3
    Base-2 exponential function
    expf.3
    Base-e exponential function
    expl.3
    Base-e exponential function
    expm1.3
    Exponential minus 1
    expm1f.3
    Exponential minus 1
    expm1l.3
    Exponential minus 1
    fabs.3
    Absolute value of floating-point number
    fabsf.3
    Absolute value of floating-point number
    fabsl.3
    Absolute value of floating-point number
    fclose.3
    Close a stream
    fcloseall.3
    Close all open streams
    fcvt.3
    Convert a floating-point number to a string
    fcvt_r.3
    Convert a floating-point number to a string
    fdim.3
    Positive difference
    fdimf.3
    Positive difference
    fdiml.3
    Positive difference
    fdopen.3
    Stream open functions
    fdopendir.3
    Open a directory
    feclearexcept.3
    Floating-point rounding and exception handling
    fedisableexcept.3
    Floating-point rounding and exception handling
    feenableexcept.3
    Floating-point rounding and exception handling
    fegetenv.3
    Floating-point rounding and exception handling
    fegetexcept.3
    Floating-point rounding and exception handling
    fegetexceptflag.3
    Floating-point rounding and exception handling
    fegetround.3
    Floating-point rounding and exception handling
    feholdexcept.3
    Floating-point rounding and exception handling
    fenv.3
    Floating-point rounding and exception handling
    feof.3
    Check and reset stream status
    feof_unlocked.3
    Nonlocking stdio functions
    feraiseexcept.3
    Floating-point rounding and exception handling
    ferror.3
    Check and reset stream status
    ferror_unlocked.3
    Nonlocking stdio functions
    fesetenv.3
    Floating-point rounding and exception handling
    fesetexceptflag.3
    Floating-point rounding and exception handling
    fesetround.3
    Floating-point rounding and exception handling
    fetestexcept.3
    Floating-point rounding and exception handling
    feupdateenv.3
    Floating-point rounding and exception handling
    fexecve.3
    Execute program specified via file descriptor
    fflush.3
    Flush a stream
    fflush_unlocked.3
    Nonlocking stdio functions
    ffs.3
    Find first bit set in a word
    ffsl.3
    Find first bit set in a word
    ffsll.3
    Find first bit set in a word
    fgetc.3
    Input of characters and strings
    fgetc_unlocked.3
    Nonlocking stdio functions
    fgetgrent.3
    Get group file entry
    fgetgrent_r.3
    Get group file entry reentrantly
    fgetpos.3
    Reposition a stream
    fgetpwent.3
    Get password file entry
    fgetpwent_r.3
    Get passwd file entry reentrantly
    fgets.3
    Input of characters and strings
    fgets_unlocked.3
    Nonlocking stdio functions
    fgetspent.3
    Get shadow password file entry
    fgetspent_r.3
    Get shadow password file entry
    fgetwc.3
    Read a wide character from a file stream
    fgetwc_unlocked.3
    Nonlocking stdio functions
    fgetws.3
    Read a wide-character string from a file stream
    fgetws_unlocked.3
    Nonlocking stdio functions
    fileno.3
    Check and reset stream status
    fileno_unlocked.3
    Nonlocking stdio functions
    finite.3
    Bsd floating-point classification functions
    finitef.3
    Bsd floating-point classification functions
    finitel.3
    Bsd floating-point classification functions
    flockfile.3
    Lock file for stdio
    floor.3
    Largest integral value not greater than argument
    floorf.3
    Largest integral value not greater than argument
    floorl.3
    Largest integral value not greater than argument
    fma.3
    Floating-point multiply and add
    fmaf.3
    Floating-point multiply and add
    fmal.3
    Floating-point multiply and add
    fmax.3
    Determine maximum of two floating-point numbers
    fmaxf.3
    Determine maximum of two floating-point numbers
    fmaxl.3
    Determine maximum of two floating-point numbers
    fmemopen.3
    Open memory as stream
    fmin.3
    Determine minimum of two floating-point numbers
    fminf.3
    Determine minimum of two floating-point numbers
    fminl.3
    Determine minimum of two floating-point numbers
    fmod.3
    Floating-point remainder function
    fmodf.3
    Floating-point remainder function
    fmodl.3
    Floating-point remainder function
    fmtmsg.3
    Print formatted error messages
    fnmatch.3
    Match filename or pathname
    fopen.3
    Stream open functions
    fopencookie.3
    Opening a custom stream
    forkpty.3
    Terminal utility functions
    fpathconf.3
    Get configuration values for files
    fpclassify.3
    Floating-point classification macros
    fprintf.3
    Formatted output conversion
    fpurge.3
    Purge a stream
    fputc.3
    Output of characters and strings
    fputc_unlocked.3
    Nonlocking stdio functions
    fputs.3
    Output of characters and strings
    fputs_unlocked.3
    Nonlocking stdio functions
    fputwc.3
    Write a wide character to a file stream
    fputwc_unlocked.3
    Nonlocking stdio functions
    fputws.3
    Write a wide-character string to a file stream
    fputws_unlocked.3
    Nonlocking stdio functions
    fread.3
    Binary stream input/output
    fread_unlocked.3
    Nonlocking stdio functions
    free.3
    Allocate and free dynamic memory
    freeaddrinfo.3
    Network address and service translation
    freehostent.3
    Get network hostnames and addresses
    freeifaddrs.3
    Get interface addresses
    freelocale.3
    Create, modify, and free a locale object
    freopen.3
    Stream open functions
    frexp.3
    Convert floating-point number to fractional and integral components
    frexpf.3
    Convert floating-point number to fractional and integral components
    frexpl.3
    Convert floating-point number to fractional and integral components
    fscanf.3
    Input format conversion
    fseek.3
    Reposition a stream
    fseeko.3
    Seek to or report file position
    fsetpos.3
    Reposition a stream
    fstatvfs.3
    Get filesystem statistics
    ftell.3
    Reposition a stream
    ftello.3
    Seek to or report file position
    ftime.3
    Return date and time
    ftok.3
    Convert a pathname and a project identifier to a system v ipc key
    ftrylockfile.3
    Lock file for stdio
    fts.3
    Traverse a file hierarchy
    fts_children.3
    Traverse a file hierarchy
    fts_close.3
    Traverse a file hierarchy
    fts_open.3
    Traverse a file hierarchy
    fts_read.3
    Traverse a file hierarchy
    fts_set.3
    Traverse a file hierarchy
    ftw.3
    File tree walk
    funlockfile.3
    Lock file for stdio
    futimens.3
    Change file timestamps with nanosecond precision
    futimes.3
    Change file timestamps
    fwide.3
    Set and determine the orientation of a file stream
    fwprintf.3
    Formatted wide-character output conversion
    fwrite.3
    Binary stream input/output
    fwrite_unlocked.3
    Nonlocking stdio functions
    gai_cancel.3
    Asynchronous network address and service translation
    gai_error.3
    Asynchronous network address and service translation
    gai_strerror.3
    Network address and service translation
    gai_suspend.3
    Asynchronous network address and service translation
    gamma.3
    (logarithm of the) gamma function
    gammaf.3
    (logarithm of the) gamma function
    gammal.3
    (logarithm of the) gamma function
    gcvt.3
    Convert a floating-point number to a string
    get_current_dir_name.3
    Get current working directory
    get_myaddress.3
    Library routines for remote procedure calls
    get_nprocs.3
    Get number of processors
    get_nprocs_conf.3
    Get number of processors
    getaddrinfo.3
    Network address and service translation
    getaddrinfo_a.3
    Asynchronous network address and service translation
    getaliasbyname.3
    Read an alias entry
    getaliasbyname_r.3
    Read an alias entry
    getaliasent.3
    Read an alias entry
    getaliasent_r.3
    Read an alias entry
    getauxval.3
    Retrieve a value from the auxiliary vector
    getc.3
    Input of characters and strings
    getc_unlocked.3
    Nonlocking stdio functions
    getchar.3
    Input of characters and strings
    getchar_unlocked.3
    Nonlocking stdio functions
    getcontext.3
    Get or set the user context
    getcwd.3
    Get current working directory
    getdate.3
    Convert a date-plus-time string to broken-down time
    getdate_err.3
    Convert a date-plus-time string to broken-down time
    getdate_r.3
    Convert a date-plus-time string to broken-down time
    getdelim.3
    Delimited string input
    getdirentries.3
    Get directory entries in a filesystem-independent format
    getdtablesize.3
    Get descriptor table size
    getenv.3
    Get an environment variable
    getfsent.3
    Handle fstab entries
    getfsfile.3
    Handle fstab entries
    getfsspec.3
    Handle fstab entries
    getgrent.3
    Get group file entry
    getgrent_r.3
    Get group file entry reentrantly
    getgrgid.3
    Get group file entry
    getgrgid_r.3
    Get group file entry
    getgrnam.3
    Get group file entry
    getgrnam_r.3
    Get group file entry
    getgrouplist.3
    Get list of groups to which a user belongs
    gethostbyaddr.3
    Get network host entry
    gethostbyaddr_r.3
    Get network host entry
    gethostbyname.3
    Get network host entry
    gethostbyname2.3
    Get network host entry
    gethostbyname2_r.3
    Get network host entry
    gethostbyname_r.3
    Get network host entry
    gethostent.3
    Get network host entry
    gethostent_r.3
    Get network host entry
    gethostid.3
    Get or set the unique identifier of the current host
    getifaddrs.3
    Get interface addresses
    getipnodebyaddr.3
    Get network hostnames and addresses
    getipnodebyname.3
    Get network hostnames and addresses
    getline.3
    Delimited string input
    getloadavg.3
    Get system load averages
    getlogin.3
    Get username
    getlogin_r.3
    Get username
    getmntent.3
    Get filesystem descriptor file entry
    getmntent_r.3
    Get filesystem descriptor file entry
    getnameinfo.3
    Address-to-name translation in protocol-independent manner
    getnetbyaddr.3
    Get network entry
    getnetbyaddr_r.3
    Get network entry (reentrant)
    getnetbyname.3
    Get network entry
    getnetbyname_r.3
    Get network entry (reentrant)
    getnetent.3
    Get network entry
    getnetent_r.3
    Get network entry (reentrant)
    getnetgrent.3
    Handle network group entries
    getnetgrent_r.3
    Handle network group entries
    getopt.3
    Parse command-line options
    getopt_long.3
    Parse command-line options
    getopt_long_only.3
    Parse command-line options
    getpass.3
    Get a password
    getprotobyname.3
    Get protocol entry
    getprotobyname_r.3
    Get protocol entry (reentrant)
    getprotobynumber.3
    Get protocol entry
    getprotobynumber_r.3
    Get protocol entry (reentrant)
    getprotoent.3
    Get protocol entry
    getprotoent_r.3
    Get protocol entry (reentrant)
    getpt.3
    Open the pseudoterminal master (ptm)
    getpw.3
    Reconstruct password line entry
    getpwent.3
    Get password file entry
    getpwent_r.3
    Get passwd file entry reentrantly
    getpwnam.3
    Get password file entry
    getpwnam_r.3
    Get password file entry
    getpwuid.3
    Get password file entry
    getpwuid_r.3
    Get password file entry
    getrpcbyname.3
    Get rpc entry
    getrpcbyname_r.3
    Get rpc entry (reentrant)
    getrpcbynumber.3
    Get rpc entry
    getrpcbynumber_r.3
    Get rpc entry (reentrant)
    getrpcent.3
    Get rpc entry
    getrpcent_r.3
    Get rpc entry (reentrant)
    getrpcport.3
    Get rpc port number
    gets.3
    Get a string from standard input (deprecated)
    getservbyname.3
    Get service entry
    getservbyname_r.3
    Get service entry (reentrant)
    getservbyport.3
    Get service entry
    getservbyport_r.3
    Get service entry (reentrant)
    getservent.3
    Get service entry
    getservent_r.3
    Get service entry (reentrant)
    getspent.3
    Get shadow password file entry
    getspent_r.3
    Get shadow password file entry
    getspnam.3
    Get shadow password file entry
    getspnam_r.3
    Get shadow password file entry
    getsubopt.3
    Parse suboption arguments from a string
    getttyent.3
    Get ttys file entry
    getttynam.3
    Get ttys file entry
    getumask.3
    Get file creation mask
    getusershell.3
    Get permitted user shells
    getutent.3
    Access utmp file entries
    getutent_r.3
    Access utmp file entries
    getutid.3
    Access utmp file entries
    getutid_r.3
    Access utmp file entries
    getutline.3
    Access utmp file entries
    getutline_r.3
    Access utmp file entries
    getutmp.3
    Copy utmp structure to utmpx, and vice versa
    getutmpx.3
    Copy utmp structure to utmpx, and vice versa
    getutxent.3
    Access utmp file entries
    getutxid.3
    Access utmp file entries
    getutxline.3
    Access utmp file entries
    getw.3
    Input and output of words (ints)
    getwc.3
    Read a wide character from a file stream
    getwc_unlocked.3
    Nonlocking stdio functions
    getwchar.3
    Read a wide character from standard input
    getwchar_unlocked.3
    Nonlocking stdio functions
    getwd.3
    Get current working directory
    glob.3
    Find pathnames matching a pattern, free memory from glob()
    globfree.3
    Find pathnames matching a pattern, free memory from glob()
    gmtime.3
    Transform date and time to broken-down time or ascii
    gmtime_r.3
    Transform date and time to broken-down time or ascii
    gnu_dev_major.3
    Manage a device number
    gnu_dev_makedev.3
    Manage a device number
    gnu_dev_minor.3
    Manage a device number
    gnu_get_libc_release.3
    Get glibc version and release
    gnu_get_libc_version.3
    Get glibc version and release
    grantpt.3
    Grant access to the slave pseudoterminal
    group_member.3
    Test whether a process is in a group
    gsignal.3
    Software signal facility
    h_errno.3
    Get network host entry
    hash.3
    Hash database access method
    hasmntopt.3
    Get filesystem descriptor file entry
    hcreate.3
    Hash table management
    hcreate_r.3
    Hash table management
    hdestroy.3
    Hash table management
    hdestroy_r.3
    Hash table management
    herror.3
    Get network host entry
    hsearch.3
    Hash table management
    hsearch_r.3
    Hash table management
    hstrerror.3
    Get network host entry
    htobe16.3
    Convert values between host and big-/little-endian byte order
    htobe32.3
    Convert values between host and big-/little-endian byte order
    htobe64.3
    Convert values between host and big-/little-endian byte order
    htole16.3
    Convert values between host and big-/little-endian byte order
    htole32.3
    Convert values between host and big-/little-endian byte order
    htole64.3
    Convert values between host and big-/little-endian byte order
    htonl.3
    Convert values between host and network byte order
    htons.3
    Convert values between host and network byte order
    hypot.3
    Euclidean distance function
    hypotf.3
    Euclidean distance function
    hypotl.3
    Euclidean distance function
    iconv.3
    Perform character set conversion
    iconv_close.3
    Deallocate descriptor for character set conversion
    iconv_open.3
    Allocate descriptor for character set conversion
    if_freenameindex.3
    Get network interface names and indexes
    if_indextoname.3
    Mappings between network interface names and indexes
    if_nameindex.3
    Get network interface names and indexes
    if_nametoindex.3
    Mappings between network interface names and indexes
    ilogb.3
    Get integer exponent of a floating-point value
    ilogbf.3
    Get integer exponent of a floating-point value
    ilogbl.3
    Get integer exponent of a floating-point value
    imaxabs.3
    Compute the absolute value of an integer
    imaxdiv.3
    Compute quotient and remainder of an integer division
    index.3
    Locate character in string
    inet.3
    Internet address manipulation routines
    inet_addr.3
    Internet address manipulation routines
    inet_aton.3
    Internet address manipulation routines
    inet_lnaof.3
    Internet address manipulation routines
    inet_makeaddr.3
    Internet address manipulation routines
    inet_net_ntop.3
    Internet network number conversion
    inet_net_pton.3
    Internet network number conversion
    inet_netof.3
    Internet address manipulation routines
    inet_network.3
    Internet address manipulation routines
    inet_ntoa.3
    Internet address manipulation routines
    inet_ntop.3
    Convert ipv4 and ipv6 addresses from binary to text form
    inet_pton.3
    Convert ipv4 and ipv6 addresses from text to binary form
    initgroups.3
    Initialize the supplementary group access list
    initstate.3
    Random number generator
    initstate_r.3
    Reentrant random number generator
    innetgr.3
    Handle network group entries
    insque.3
    Insert/remove an item from a queue
    iruserok.3
    Routines for returning a stream to a remote command
    iruserok_af.3
    Routines for returning a stream to a remote command
    isalnum.3
    Character classification functions
    isalnum_l.3
    Character classification functions
    isalpha.3
    Character classification functions
    isascii.3
    Character classification functions
    isascii_l.3
    Character classification functions
    isatty.3
    Test whether a file descriptor refers to a terminal
    isblank.3
    Character classification functions
    isblank_l.3
    Character classification functions
    iscntrl.3
    Character classification functions
    iscntrl_l.3
    Character classification functions
    isdigit.3
    Character classification functions
    isdigit_l.3
    Character classification functions
    isfdtype.3
    Test file type of a file descriptor
    isfinite.3
    Floating-point classification macros
    isgraph.3
    Character classification functions
    isgraph_l.3
    Character classification functions
    isgreater.3
    Floating-point relational tests without exception for nan
    isgreaterequal.3
    Floating-point relational tests without exception for nan
    isinf.3
    Floating-point classification macros
    isinff.3
    Bsd floating-point classification functions
    isinfl.3
    Bsd floating-point classification functions
    isless.3
    Floating-point relational tests without exception for nan
    islessequal.3
    Floating-point relational tests without exception for nan
    islessgreater.3
    Floating-point relational tests without exception for nan
    islower.3
    Character classification functions
    islower_l.3
    Character classification functions
    isnan.3
    Floating-point classification macros
    isnanf.3
    Bsd floating-point classification functions
    isnanl.3
    Bsd floating-point classification functions
    isnormal.3
    Floating-point classification macros
    isprint.3
    Character classification functions
    isprint_l.3
    Character classification functions
    ispunct.3
    Character classification functions
    ispunct_l.3
    Character classification functions
    isspace.3
    Character classification functions
    isspace_l.3
    Character classification functions
    isunordered.3
    Floating-point relational tests without exception for nan
    isupper.3
    Character classification functions
    isupper_l.3
    Character classification functions
    iswalnum.3
    Test for alphanumeric wide character
    iswalpha.3
    Test for alphabetic wide character
    iswblank.3
    Test for whitespace wide character
    iswcntrl.3
    Test for control wide character
    iswctype.3
    Wide-character classification
    iswdigit.3
    Test for decimal digit wide character
    iswgraph.3
    Test for graphic wide character
    iswlower.3
    Test for lowercase wide character
    iswprint.3
    Test for printing wide character
    iswpunct.3
    Test for punctuation or symbolic wide character
    iswspace.3
    Test for whitespace wide character
    iswupper.3
    Test for uppercase wide character
    iswxdigit.3
    Test for hexadecimal digit wide character
    isxdigit.3
    Character classification functions
    isxdigit_l.3
    Character classification functions
    j0.3
    Bessel functions of the first kind
    j0f.3
    Bessel functions of the first kind
    j0l.3
    Bessel functions of the first kind
    j1.3
    Bessel functions of the first kind
    j1f.3
    Bessel functions of the first kind
    j1l.3
    Bessel functions of the first kind
    jn.3
    Bessel functions of the first kind
    jnf.3
    Bessel functions of the first kind
    jnl.3
    Bessel functions of the first kind
    jrand48.3
    Generate uniformly distributed pseudo-random numbers
    jrand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    key_decryptsession.3
    Interfaces to rpc keyserver daemon
    key_encryptsession.3
    Interfaces to rpc keyserver daemon
    key_gendes.3
    Interfaces to rpc keyserver daemon
    key_secretkey_is_set.3
    Interfaces to rpc keyserver daemon
    key_setsecret.3
    Interfaces to rpc keyserver daemon
    klogctl.3
    Read and/or clear kernel message ring buffer; set console_loglevel
    l64a.3
    Convert between long and base-64
    labs.3
    Compute the absolute value of an integer
    lckpwdf.3
    Get shadow password file entry
    lcong48.3
    Generate uniformly distributed pseudo-random numbers
    lcong48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    ldexp.3
    Multiply floating-point number by integral power of 2
    ldexpf.3
    Multiply floating-point number by integral power of 2
    ldexpl.3
    Multiply floating-point number by integral power of 2
    ldiv.3
    Compute quotient and remainder of an integer division
    le16toh.3
    Convert values between host and big-/little-endian byte order
    le32toh.3
    Convert values between host and big-/little-endian byte order
    le64toh.3
    Convert values between host and big-/little-endian byte order
    lfind.3
    Linear search of an array
    lgamma.3
    Log gamma function
    lgamma_r.3
    Log gamma function
    lgammaf.3
    Log gamma function
    lgammaf_r.3
    Log gamma function
    lgammal.3
    Log gamma function
    lgammal_r.3
    Log gamma function
    lio_listio.3
    Initiate a list of i/o requests
    llabs.3
    Compute the absolute value of an integer
    lldiv.3
    Compute quotient and remainder of an integer division
    llrint.3
    Round to nearest integer
    llrintf.3
    Round to nearest integer
    llrintl.3
    Round to nearest integer
    llround.3
    Round to nearest integer, away from zero
    llroundf.3
    Round to nearest integer, away from zero
    llroundl.3
    Round to nearest integer, away from zero
    localeconv.3
    Get numeric formatting information
    localtime.3
    Transform date and time to broken-down time or ascii
    localtime_r.3
    Transform date and time to broken-down time or ascii
    lockf.3
    Apply, test or remove a posix lock on an open file
    log.3
    Natural logarithmic function
    log10.3
    Base-10 logarithmic function
    log10f.3
    Base-10 logarithmic function
    log10l.3
    Base-10 logarithmic function
    log1p.3
    Logarithm of 1 plus argument
    log1pf.3
    Logarithm of 1 plus argument
    log1pl.3
    Logarithm of 1 plus argument
    log2.3
    Base-2 logarithmic function
    log2f.3
    Base-2 logarithmic function
    log2l.3
    Base-2 logarithmic function
    logb.3
    Get exponent of a floating-point value
    logbf.3
    Get exponent of a floating-point value
    logbl.3
    Get exponent of a floating-point value
    logf.3
    Natural logarithmic function
    login.3
    Write utmp and wtmp entries
    login_tty.3
    Terminal utility functions
    logl.3
    Natural logarithmic function
    logout.3
    Write utmp and wtmp entries
    logwtmp.3
    Append an entry to the wtmp file
    longjmp.3
    Nonlocal jump to a saved stack context
    lrand48.3
    Generate uniformly distributed pseudo-random numbers
    lrand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    lrint.3
    Round to nearest integer
    lrintf.3
    Round to nearest integer
    lrintl.3
    Round to nearest integer
    lround.3
    Round to nearest integer, away from zero
    lroundf.3
    Round to nearest integer, away from zero
    lroundl.3
    Round to nearest integer, away from zero
    lsearch.3
    Linear search of an array
    lseek64.3
    Reposition 64-bit read/write file offset
    lutimes.3
    Change file timestamps
    major.3
    Manage a device number
    makecontext.3
    Manipulate user context
    makedev.3
    Manage a device number
    mallinfo.3
    Obtain memory allocation information
    malloc.3
    Allocate and free dynamic memory
    malloc_get_state.3
    Record and restore state of malloc implementation
    malloc_hook.3
    Malloc debugging variables
    malloc_info.3
    Export malloc state to a stream
    malloc_set_state.3
    Record and restore state of malloc implementation
    malloc_stats.3
    Print memory allocation statistics
    malloc_trim.3
    Release free memory from the top of the heap
    malloc_usable_size.3
    Obtain size of block of memory allocated from heap
    mallopt.3
    Set memory allocation parameters
    matherr.3
    Svid math library exception handling
    mblen.3
    Determine number of bytes in next multibyte character
    mbrlen.3
    Determine number of bytes in next multibyte character
    mbrtowc.3
    Convert a multibyte sequence to a wide character
    mbsinit.3
    Test for initial shift state
    mbsnrtowcs.3
    Convert a multibyte string to a wide-character string
    mbsrtowcs.3
    Convert a multibyte string to a wide-character string
    mbstowcs.3
    Convert a multibyte string to a wide-character string
    mbtowc.3
    Convert a multibyte sequence to a wide character
    mcheck.3
    Heap consistency checking
    mcheck_check_all.3
    Heap consistency checking
    mcheck_pedantic.3
    Heap consistency checking
    memalign.3
    Allocate aligned memory
    memccpy.3
    Copy memory area
    memchr.3
    Scan memory for a character
    memcmp.3
    Compare memory areas
    memcpy.3
    Copy memory area
    memfrob.3
    Frobnicate (encrypt) a memory area
    memmem.3
    Locate a substring
    memmove.3
    Copy memory area
    mempcpy.3
    Copy memory area
    memrchr.3
    Scan memory for a character
    memset.3
    Fill memory with a constant byte
    minor.3
    Manage a device number
    mkdtemp.3
    Create a unique temporary directory
    mkfifo.3
    Make a fifo special file (a named pipe)
    mkfifoat.3
    Make a fifo special file (a named pipe)
    mkostemp.3
    Create a unique temporary file
    mkostemps.3
    Create a unique temporary file
    mkstemp.3
    Create a unique temporary file
    mkstemps.3
    Create a unique temporary file
    mktemp.3
    Make a unique temporary filename
    mktime.3
    Transform date and time to broken-down time or ascii
    mmap64.3
    Map or unmap files or devices into memory
    modf.3
    Extract signed integral and fractional values from floating-point number
    modff.3
    Extract signed integral and fractional values from floating-point number
    modfl.3
    Extract signed integral and fractional values from floating-point number
    mpool.3
    Shared memory buffer pool
    mprobe.3
    Heap consistency checking
    mq_close.3
    Close a message queue descriptor
    mq_getattr.3
    Get/set message queue attributes
    mq_notify.3
    Register for notification when a message is available
    mq_open.3
    Open a message queue
    mq_receive.3
    Receive a message from a message queue
    mq_send.3
    Send a message to a message queue
    mq_setattr.3
    Get/set message queue attributes
    mq_timedreceive.3
    Receive a message from a message queue
    mq_timedsend.3
    Send a message to a message queue
    mq_unlink.3
    Remove a message queue
    mrand48.3
    Generate uniformly distributed pseudo-random numbers
    mrand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    mtrace.3
    Malloc tracing
    muntrace.3
    Malloc tracing
    nanf.3
    Return 'not a number'
    nanl.3
    Return 'not a number'
    nearbyint.3
    Round to nearest integer
    nearbyintf.3
    Round to nearest integer
    nearbyintl.3
    Round to nearest integer
    netlink.3
    Netlink macros
    newlocale.3
    Create, modify, and free a locale object
    nextafter.3
    Floating-point number manipulation
    nextafterf.3
    Floating-point number manipulation
    nextafterl.3
    Floating-point number manipulation
    nexttoward.3
    Floating-point number manipulation
    nexttowardf.3
    Floating-point number manipulation
    nexttowardl.3
    Floating-point number manipulation
    nftw.3
    File tree walk
    nl_langinfo.3
    Query language and locale information
    nrand48.3
    Generate uniformly distributed pseudo-random numbers
    nrand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    ntohl.3
    Convert values between host and network byte order
    ntohs.3
    Convert values between host and network byte order
    offsetof.3
    Offset of a structure member
    on_exit.3
    Register a function to be called at normal process termination
    open_memstream.3
    Open memory as stream
    open_wmemstream.3
    Open memory as stream
    opendir.3
    Open a directory
    openlog.3
    Send messages to the system logger
    openpty.3
    Terminal utility functions
    optarg.3
    Parse command-line options
    opterr.3
    Parse command-line options
    optind.3
    Parse command-line options
    optopt.3
    Parse command-line options
    passwd2des.3
    Rfs password encryption
    pathconf.3
    Get configuration values for files
    pclose.3
    Pipe stream to or from a process
    perror.3
    Print a system error message
    pmap_getmaps.3
    Library routines for remote procedure calls
    pmap_getport.3
    Library routines for remote procedure calls
    pmap_rmtcall.3
    Library routines for remote procedure calls
    pmap_set.3
    Library routines for remote procedure calls
    pmap_unset.3
    Library routines for remote procedure calls
    popen.3
    Pipe stream to or from a process
    posix_fallocate.3
    Allocate file space
    posix_memalign.3
    Allocate aligned memory
    posix_openpt.3
    Open a pseudoterminal device
    pow.3
    Power functions
    pow10.3
    Base-10 power functions
    pow10f.3
    Base-10 power functions
    pow10l.3
    Base-10 power functions
    powf.3
    Power functions
    powl.3
    Power functions
    printf.3
    Formatted output conversion
    profil.3
    Execution time profile
    program_invocation_name.3
    Obtain name used to invoke calling program
    program_invocation_short_name.3
    Obtain name used to invoke calling program
    psiginfo.3
    Print signal message
    psignal.3
    Print signal message
    pthread_attr_destroy.3
    Initialize and destroy thread attributes object
    pthread_attr_getaffinity_np.3
    Set/get cpu affinity attribute in thread attributes object
    pthread_attr_getdetachstate.3
    Set/get detach state attribute in thread attributes object
    pthread_attr_getguardsize.3
    Set/get guard size attribute in thread attributes object
    pthread_attr_getinheritsched.3
    Set/get inherit-scheduler attribute in thread attributes object
    pthread_attr_getschedparam.3
    Set/get scheduling parameter attributes in thread attributes object
    pthread_attr_getschedpolicy.3
    Set/get scheduling policy attribute in thread attributes object
    pthread_attr_getscope.3
    Set/get contention scope attribute in thread attributes object
    pthread_attr_getstack.3
    Set/get stack attributes in thread attributes object
    pthread_attr_getstackaddr.3
    Set/get stack address attribute in thread attributes object
    pthread_attr_getstacksize.3
    Set/get stack size attribute in thread attributes object
    pthread_attr_init.3
    Initialize and destroy thread attributes object
    pthread_attr_setaffinity_np.3
    Set/get cpu affinity attribute in thread attributes object
    pthread_attr_setdetachstate.3
    Set/get detach state attribute in thread attributes object
    pthread_attr_setguardsize.3
    Set/get guard size attribute in thread attributes object
    pthread_attr_setinheritsched.3
    Set/get inherit-scheduler attribute in thread attributes object
    pthread_attr_setschedparam.3
    Set/get scheduling parameter attributes in thread attributes object
    pthread_attr_setschedpolicy.3
    Set/get scheduling policy attribute in thread attributes object
    pthread_attr_setscope.3
    Set/get contention scope attribute in thread attributes object
    pthread_attr_setstack.3
    Set/get stack attributes in thread attributes object
    pthread_attr_setstackaddr.3
    Set/get stack address attribute in thread attributes object
    pthread_attr_setstacksize.3
    Set/get stack size attribute in thread attributes object
    pthread_cancel.3
    Send a cancellation request to a thread
    pthread_cleanup_pop.3
    Push and pop thread cancellation clean-up handlers
    pthread_cleanup_pop_restore_np.3
    Push and pop thread cancellation clean-up handlers while saving cancelability type
    pthread_cleanup_push.3
    Push and pop thread cancellation clean-up handlers
    pthread_cleanup_push_defer_np.3
    Push and pop thread cancellation clean-up handlers while saving cancelability type
    pthread_create.3
    Create a new thread
    pthread_detach.3
    Detach a thread
    pthread_equal.3
    Compare thread ids
    pthread_exit.3
    Terminate calling thread
    pthread_getaffinity_np.3
    Set/get cpu affinity of a thread
    pthread_getattr_np.3
    Get attributes of created thread
    pthread_getconcurrency.3
    Set/get the concurrency level
    pthread_getcpuclockid.3
    Retrieve id of a thread's cpu time clock
    pthread_getname_np.3
    Set/get the name of a thread
    pthread_getschedparam.3
    Set/get scheduling policy and parameters of a thread
    pthread_join.3
    Join with a terminated thread
    pthread_kill.3
    Send a signal to a thread
    pthread_kill_other_threads_np.3
    Terminate all other threads in process
    pthread_self.3
    Obtain id of the calling thread
    pthread_setaffinity_np.3
    Set/get cpu affinity of a thread
    pthread_setcancelstate.3
    Set cancelability state and type
    pthread_setcanceltype.3
    Set cancelability state and type
    pthread_setconcurrency.3
    Set/get the concurrency level
    pthread_setname_np.3
    Set/get the name of a thread
    pthread_setschedparam.3
    Set/get scheduling policy and parameters of a thread
    pthread_setschedprio.3
    Set scheduling priority of a thread
    pthread_sigmask.3
    Examine and change mask of blocked signals
    pthread_sigqueue.3
    Queue a signal and data to a thread
    pthread_testcancel.3
    Request delivery of any pending cancellation request
    pthread_timedjoin_np.3
    Try to join with a terminated thread
    pthread_tryjoin_np.3
    Try to join with a terminated thread
    pthread_yield.3
    Yield the processor
    ptsname.3
    Get the name of the slave pseudoterminal
    ptsname_r.3
    Get the name of the slave pseudoterminal
    putc.3
    Output of characters and strings
    putc_unlocked.3
    Nonlocking stdio functions
    putchar.3
    Output of characters and strings
    putchar_unlocked.3
    Nonlocking stdio functions
    putenv.3
    Change or add an environment variable
    putgrent.3
    Write a group database entry to a file
    putpwent.3
    Write a password file entry
    puts.3
    Output of characters and strings
    putspent.3
    Get shadow password file entry
    pututline.3
    Access utmp file entries
    pututxline.3
    Access utmp file entries
    putw.3
    Input and output of words (ints)
    putwc.3
    Write a wide character to a file stream
    putwc_unlocked.3
    Nonlocking stdio functions
    putwchar.3
    Write a wide character to standard output
    putwchar_unlocked.3
    Nonlocking stdio functions
    pvalloc.3
    Allocate aligned memory
    qecvt.3
    Convert a floating-point number to a string
    qecvt_r.3
    Convert a floating-point number to a string
    qfcvt.3
    Convert a floating-point number to a string
    qfcvt_r.3
    Convert a floating-point number to a string
    qgcvt.3
    Convert a floating-point number to a string
    qsort.3
    Sort an array
    qsort_r.3
    Sort an array
    queue.3
    Implementations of lists, tail queues, and circular queues
    raise.3
    Send a signal to the caller
    rand.3
    Pseudo-random number generator
    rand_r.3
    Pseudo-random number generator
    random.3
    Random number generator
    random_r.3
    Reentrant random number generator
    rawmemchr.3
    Scan memory for a character
    rcmd.3
    Routines for returning a stream to a remote command
    rcmd_af.3
    Routines for returning a stream to a remote command
    re_comp.3
    Bsd regex functions
    re_exec.3
    Bsd regex functions
    readdir.3
    Read a directory
    readdir_r.3
    Read a directory
    realloc.3
    Allocate and free dynamic memory
    realpath.3
    Return the canonicalized absolute pathname
    recno.3
    Record number database access method
    regcomp.3
    Posix regex functions
    regerror.3
    Posix regex functions
    regex.3
    Posix regex functions
    regexec.3
    Posix regex functions
    regfree.3
    Posix regex functions
    registerrpc.3
    Library routines for remote procedure calls
    remainder.3
    Floating-point remainder function
    remainderf.3
    Floating-point remainder function
    remainderl.3
    Floating-point remainder function
    remove.3
    Remove a file or directory
    remque.3
    Insert/remove an item from a queue
    remquo.3
    Remainder and part of quotient
    remquof.3
    Remainder and part of quotient
    remquol.3
    Remainder and part of quotient
    res_init.3
    Resolver routines
    res_mkquery.3
    Resolver routines
    res_query.3
    Resolver routines
    res_querydomain.3
    Resolver routines
    res_search.3
    Resolver routines
    res_send.3
    Resolver routines
    resolver.3
    Resolver routines
    rewind.3
    Reposition a stream
    rewinddir.3
    Reset directory stream
    rexec.3
    Return stream to a remote command
    rexec_af.3
    Return stream to a remote command
    rindex.3
    Locate character in string
    rint.3
    Round to nearest integer
    rintf.3
    Round to nearest integer
    rintl.3
    Round to nearest integer
    round.3
    Round to nearest integer, away from zero
    roundf.3
    Round to nearest integer, away from zero
    roundl.3
    Round to nearest integer, away from zero
    rpc.3
    Library routines for remote procedure calls
    rpmatch.3
    Determine if the answer to a question is affirmative or negative
    rresvport.3
    Routines for returning a stream to a remote command
    rresvport_af.3
    Routines for returning a stream to a remote command
    rtime.3
    Get time from a remote machine
    rtnetlink.3
    Macros to manipulate rtnetlink messages
    ruserok.3
    Routines for returning a stream to a remote command
    ruserok_af.3
    Routines for returning a stream to a remote command
    scalb.3
    Multiply floating-point number by integral power of radix (obsolete)
    scalbf.3
    Multiply floating-point number by integral power of radix (obsolete)
    scalbl.3
    Multiply floating-point number by integral power of radix (obsolete)
    scalbln.3
    Multiply floating-point number by integral power of radix
    scalblnf.3
    Multiply floating-point number by integral power of radix
    scalblnl.3
    Multiply floating-point number by integral power of radix
    scalbn.3
    Multiply floating-point number by integral power of radix
    scalbnf.3
    Multiply floating-point number by integral power of radix
    scalbnl.3
    Multiply floating-point number by integral power of radix
    scandir.3
    Scan a directory for matching entries
    scandirat.3
    Scan a directory for matching entries
    scanf.3
    Input format conversion
    sched_getcpu.3
    Determine cpu on which the calling thread is running
    secure_getenv.3
    Get an environment variable
    seed48.3
    Generate uniformly distributed pseudo-random numbers
    seed48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    seekdir.3
    Set the position of the next readdir() call in the directory stream.
    sem_close.3
    Close a named semaphore
    sem_destroy.3
    Destroy an unnamed semaphore
    sem_getvalue.3
    Get the value of a semaphore
    sem_init.3
    Initialize an unnamed semaphore
    sem_open.3
    Initialize and open a named semaphore
    sem_post.3
    Unlock a semaphore
    sem_timedwait.3
    Lock a semaphore
    sem_trywait.3
    Lock a semaphore
    sem_unlink.3
    Remove a named semaphore
    sem_wait.3
    Lock a semaphore
    setaliasent.3
    Read an alias entry
    setbuf.3
    Stream buffering operations
    setbuffer.3
    Stream buffering operations
    setcontext.3
    Get or set the user context
    setenv.3
    Change or add an environment variable
    setfsent.3
    Handle fstab entries
    setgrent.3
    Get group file entry
    sethostent.3
    Get network host entry
    sethostid.3
    Get or set the unique identifier of the current host
    setjmp.3
    Save stack context for nonlocal goto
    setkey.3
    Encrypt 64-bit messages
    setkey_r.3
    Encrypt 64-bit messages
    setlinebuf.3
    Stream buffering operations
    setlocale.3
    Set the current locale
    setlogmask.3
    Set log priority mask
    setmntent.3
    Get filesystem descriptor file entry
    setnetent.3
    Get network entry
    setnetgrent.3
    Handle network group entries
    setprotoent.3
    Get protocol entry
    setpwent.3
    Get password file entry
    setrpcent.3
    Get rpc entry
    setservent.3
    Get service entry
    setspent.3
    Get shadow password file entry
    setstate.3
    Random number generator
    setstate_r.3
    Reentrant random number generator
    setttyent.3
    Get ttys file entry
    setusershell.3
    Get permitted user shells
    setutent.3
    Access utmp file entries
    setutxent.3
    Access utmp file entries
    setvbuf.3
    Stream buffering operations
    sgetspent.3
    Get shadow password file entry
    sgetspent_r.3
    Get shadow password file entry
    shm_open.3
    Create/open or unlink posix shared memory objects
    shm_unlink.3
    Create/open or unlink posix shared memory objects
    sigaddset.3
    Posix signal set operations
    sigandset.3
    Posix signal set operations
    sigblock.3
    Bsd signal api
    sigdelset.3
    Posix signal set operations
    sigemptyset.3
    Posix signal set operations
    sigfillset.3
    Posix signal set operations
    siggetmask.3
    Bsd signal api
    sighold.3
    System v signal api
    sigignore.3
    System v signal api
    siginterrupt.3
    Allow signals to interrupt system calls
    sigisemptyset.3
    Posix signal set operations
    sigismember.3
    Posix signal set operations
    siglongjmp.3
    Nonlocal jump to a saved stack context
    sigmask.3
    Bsd signal api
    signbit.3
    Test sign of a real floating-point number
    signgam.3
    Log gamma function
    significand.3
    Get mantissa of floating-point number
    significandf.3
    Get mantissa of floating-point number
    significandl.3
    Get mantissa of floating-point number
    sigorset.3
    Posix signal set operations
    sigpause.3
    Atomically release blocked signals and wait for interrupt
    sigqueue.3
    Queue a signal and data to a process
    sigrelse.3
    System v signal api
    sigset.3
    System v signal api
    sigsetjmp.3
    Save stack context for nonlocal goto
    sigsetmask.3
    Bsd signal api
    sigsetops.3
    Posix signal set operations
    sigstack.3
    Set and/or get signal stack context
    sigvec.3
    Bsd signal api
    sigwait.3
    Wait for a signal
    sin.3
    Sine function
    sincos.3
    Calculate sin and cos simultaneously
    sincosf.3
    Calculate sin and cos simultaneously
    sincosl.3
    Calculate sin and cos simultaneously
    sinf.3
    Sine function
    sinh.3
    Hyperbolic sine function
    sinhf.3
    Hyperbolic sine function
    sinhl.3
    Hyperbolic sine function
    sinl.3
    Sine function
    sleep.3
    Sleep for the specified number of seconds
    snprintf.3
    Formatted output conversion
    sockatmark.3
    Determine whether socket is at out-of-band mark
    sprintf.3
    Formatted output conversion
    sqrt.3
    Square root function
    sqrtf.3
    Square root function
    sqrtl.3
    Square root function
    srand.3
    Pseudo-random number generator
    srand48.3
    Generate uniformly distributed pseudo-random numbers
    srand48_r.3
    Generate uniformly distributed pseudo-random numbers reentrantly
    srandom.3
    Random number generator
    srandom_r.3
    Reentrant random number generator
    sscanf.3
    Input format conversion
    ssignal.3
    Software signal facility
    statvfs.3
    Get filesystem statistics
    stdarg.3
    Variable argument lists
    stderr.3
    Standard i/o streams
    stdin.3
    Standard i/o streams
    stdio.3
    Standard input/output library functions
    stdio_ext.3
    Interfaces to stdio file structure
    stdout.3
    Standard i/o streams
    stpcpy.3
    Copy a string returning a pointer to its end
    stpncpy.3
    Copy a fixed-size string, returning a pointer to its end
    strcasecmp.3
    Compare two strings ignoring case
    strcasestr.3
    Locate a substring
    strcat.3
    Concatenate two strings
    strchr.3
    Locate character in string
    strchrnul.3
    Locate character in string
    strcmp.3
    Compare two strings
    strcoll.3
    Compare two strings using the current locale
    strcpy.3
    Copy a string
    strcspn.3
    Get length of a prefix substring
    strdup.3
    Duplicate a string
    strdupa.3
    Duplicate a string
    strerror.3
    Return string describing error number
    strerror_r.3
    Return string describing error number
    strfmon.3
    Convert monetary value to a string
    strfry.3
    Randomize a string
    strftime.3
    Format date and time
    string.3
    String operations
    strlen.3
    Calculate the length of a string
    strncasecmp.3
    Compare two strings ignoring case
    strncat.3
    Concatenate two strings
    strncmp.3
    Compare two strings
    strncpy.3
    Copy a string
    strndup.3
    Duplicate a string
    strndupa.3
    Duplicate a string
    strnlen.3
    Determine the length of a fixed-size string
    strpbrk.3
    Search a string for any of a set of bytes
    strptime.3
    Convert a string representation of time to a time tm structure
    strrchr.3
    Locate character in string
    strsep.3
    Extract token from string
    strsignal.3
    Return string describing signal
    strspn.3
    Get length of a prefix substring
    strstr.3
    Locate a substring
    strtod.3
    Convert ascii string to floating-point number
    strtof.3
    Convert ascii string to floating-point number
    strtoimax.3
    Convert string to integer
    strtok.3
    Extract tokens from strings
    strtok_r.3
    Extract tokens from strings
    strtol.3
    Convert a string to a long integer
    strtold.3
    Convert ascii string to floating-point number
    strtoll.3
    Convert a string to a long integer
    strtoq.3
    Convert a string to a long integer
    strtoul.3
    Convert a string to an unsigned long integer
    strtoull.3
    Convert a string to an unsigned long integer
    strtoumax.3
    Convert string to integer
    strtouq.3
    Convert a string to an unsigned long integer
    strverscmp.3
    Compare two version strings
    strxfrm.3
    String transformation
    svc_destroy.3
    Library routines for remote procedure calls
    svc_freeargs.3
    Library routines for remote procedure calls
    svc_getargs.3
    Library routines for remote procedure calls
    svc_getcaller.3
    Library routines for remote procedure calls
    svc_getreq.3
    Library routines for remote procedure calls
    svc_getreqset.3
    Library routines for remote procedure calls
    svc_register.3
    Library routines for remote procedure calls
    svc_run.3
    Library routines for remote procedure calls
    svc_sendreply.3
    Library routines for remote procedure calls
    svc_unregister.3
    Library routines for remote procedure calls
    svcerr_auth.3
    Library routines for remote procedure calls
    svcerr_decode.3
    Library routines for remote procedure calls
    svcerr_noproc.3
    Library routines for remote procedure calls
    svcerr_noprog.3
    Library routines for remote procedure calls
    svcerr_progvers.3
    Library routines for remote procedure calls
    svcerr_systemerr.3
    Library routines for remote procedure calls
    svcerr_weakauth.3
    Library routines for remote procedure calls
    svcfd_create.3
    Library routines for remote procedure calls
    svcraw_create.3
    Library routines for remote procedure calls
    svctcp_create.3
    Library routines for remote procedure calls
    svcudp_bufcreate.3
    Library routines for remote procedure calls
    svcudp_create.3
    Library routines for remote procedure calls
    swab.3
    Swap adjacent bytes
    swapcontext.3
    Manipulate user context
    swprintf.3
    Formatted wide-character output conversion
    sys_errlist.3
    Print a system error message
    sys_nerr.3
    Print a system error message
    sysconf.3
    Get configuration information at run time
    syslog.3
    Send messages to the system logger
    system.3
    Execute a shell command
    sysv_signal.3
    Signal handling with system v semantics
    tan.3
    Tangent function
    tanf.3
    Tangent function
    tanh.3
    Hyperbolic tangent function
    tanhf.3
    Hyperbolic tangent function
    tanhl.3
    Hyperbolic tangent function
    tanl.3
    Tangent function
    tcdrain.3
    Get and set terminal attributes, line control, get and set baud rate
    tcflow.3
    Get and set terminal attributes, line control, get and set baud rate
    tcflush.3
    Get and set terminal attributes, line control, get and set baud rate
    tcgetattr.3
    Get and set terminal attributes, line control, get and set baud rate
    tcgetpgrp.3
    Get and set terminal foreground process group
    tcgetsid.3
    Get session id
    tcsendbreak.3
    Get and set terminal attributes, line control, get and set baud rate
    tcsetattr.3
    Get and set terminal attributes, line control, get and set baud rate
    tcsetpgrp.3
    Get and set terminal foreground process group
    tdelete.3
    Manage a binary tree
    tdestroy.3
    Manage a binary tree
    telldir.3
    Return current location in directory stream
    tempnam.3
    Create a name for a temporary file
    termios.3
    Get and set terminal attributes, line control, get and set baud rate
    tfind.3
    Manage a binary tree
    tgamma.3
    True gamma function
    tgammaf.3
    True gamma function
    tgammal.3
    True gamma function
    timegm.3
    Inverses of gmtime and localtime
    timelocal.3
    Inverses of gmtime and localtime
    timeradd.3
    Timeval operations
    timerclear.3
    Timeval operations
    timercmp.3
    Timeval operations
    timerisset.3
    Timeval operations
    timersub.3
    Timeval operations
    timezone.3
    Initialize time conversion information
    tmpfile.3
    Create a temporary file
    tmpnam.3
    Create a name for a temporary file
    tmpnam_r.3
    Create a name for a temporary file
    toascii.3
    Convert character to ascii
    tolower.3
    Convert uppercase or lowercase
    tolower_l.3
    Convert uppercase or lowercase
    toupper.3
    Convert uppercase or lowercase
    toupper_l.3
    Convert uppercase or lowercase
    towctrans.3
    Wide-character transliteration
    towlower.3
    Convert a wide character to lowercase
    towlower_l.3
    Convert a wide character to lowercase
    towupper.3
    Convert a wide character to uppercase
    towupper_l.3
    Convert a wide character to uppercase
    trunc.3
    Round to integer, toward zero
    truncf.3
    Round to integer, toward zero
    truncl.3
    Round to integer, toward zero
    tsearch.3
    Manage a binary tree
    ttyname.3
    Return name of a terminal
    ttyname_r.3
    Return name of a terminal
    ttyslot.3
    Find the slot of the current user's terminal in some file
    twalk.3
    Manage a binary tree
    tzname.3
    Initialize time conversion information
    tzset.3
    Initialize time conversion information
    ualarm.3
    Schedule signal after given number of microseconds
    ulckpwdf.3
    Get shadow password file entry
    ulimit.3
    Get and set user limits
    undocumented.3
    Undocumented library functions
    ungetc.3
    Input of characters and strings
    ungetwc.3
    Push back a wide character onto a file stream
    unlocked_stdio.3
    Nonlocking stdio functions
    unlockpt.3
    Unlock a pseudoterminal master/slave pair
    unsetenv.3
    Change or add an environment variable
    updwtmp.3
    Append an entry to the wtmp file
    updwtmpx.3
    Append an entry to the wtmp file
    uselocale.3
    Set/get the locale for the calling thread
    usleep.3
    Suspend execution for microsecond intervals
    utmpname.3
    Access utmp file entries
    utmpxname.3
    Access utmp file entries
    va_arg.3
    Variable argument lists
    va_copy.3
    Variable argument lists
    va_end.3
    Variable argument lists
    va_start.3
    Variable argument lists
    valloc.3
    Allocate aligned memory
    vasprintf.3
    Print to allocated string
    vdprintf.3
    Print to a file descriptor
    verr.3
    Formatted error messages
    verrx.3
    Formatted error messages
    versionsort.3
    Scan a directory for matching entries
    vfprintf.3
    Formatted output conversion
    vfscanf.3
    Input format conversion
    vfwprintf.3
    Formatted wide-character output conversion
    vlimit.3
    Get/set resource limits
    vprintf.3
    Formatted output conversion
    vscanf.3
    Input format conversion
    vsnprintf.3
    Formatted output conversion
    vsprintf.3
    Formatted output conversion
    vsscanf.3
    Input format conversion
    vswprintf.3
    Formatted wide-character output conversion
    vsyslog.3
    Send messages to the system logger
    vtimes.3
    Get resource usage
    vwarn.3
    Formatted error messages
    vwarnx.3
    Formatted error messages
    vwprintf.3
    Formatted wide-character output conversion
    warn.3
    Formatted error messages
    warnx.3
    Formatted error messages
    wcpcpy.3
    Copy a wide-character string, returning a pointer to its end
    wcpncpy.3
    Copy a fixed-size string of wide characters, returning a pointer to its end
    wcrtomb.3
    Convert a wide character to a multibyte sequence
    wcscasecmp.3
    Compare two wide-character strings, ignoring case
    wcscat.3
    Concatenate two wide-character strings
    wcschr.3
    Search a wide character in a wide-character string
    wcscmp.3
    Compare two wide-character strings
    wcscpy.3
    Copy a wide-character string
    wcscspn.3
    Search a wide-character string for any of a set of wide characters
    wcsdup.3
    Duplicate a wide-character string
    wcslen.3
    Determine the length of a wide-character string
    wcsncasecmp.3
    Compare two fixed-size wide-character strings, ignoring case
    wcsncat.3
    Concatenate two wide-character strings
    wcsncmp.3
    Compare two fixed-size wide-character strings
    wcsncpy.3
    Copy a fixed-size string of wide characters
    wcsnlen.3
    Determine the length of a fixed-size wide-character string
    wcsnrtombs.3
    Convert a wide-character string to a multibyte string
    wcspbrk.3
    Search a wide-character string for any of a set of wide characters
    wcsrchr.3
    Search a wide character in a wide-character string
    wcsrtombs.3
    Convert a wide-character string to a multibyte string
    wcsspn.3
    Advance in a wide-character string, skipping any of a set of wide characters
    wcsstr.3
    Locate a substring in a wide-character string
    wcstoimax.3
    Convert wide-character string to integer
    wcstok.3
    Split wide-character string into tokens
    wcstombs.3
    Convert a wide-character string to a multibyte string
    wcstoumax.3
    Convert wide-character string to integer
    wcswidth.3
    Determine columns needed for a fixed-size wide-character string
    wctob.3
    Try to represent a wide character as a single byte
    wctomb.3
    Convert a wide character to a multibyte sequence
    wctrans.3
    Wide-character translation mapping
    wctype.3
    Wide-character classification
    wcwidth.3
    Determine columns needed for a wide character
    wmemchr.3
    Search a wide character in a wide-character array
    wmemcmp.3
    Compare two arrays of wide-characters
    wmemcpy.3
    Copy an array of wide-characters
    wmemmove.3
    Copy an array of wide-characters
    wmempcpy.3
    Copy memory area
    wmemset.3
    Fill an array of wide-characters with a constant wide character
    wordexp.3
    Perform word expansion like a posix-shell
    wordfree.3
    Perform word expansion like a posix-shell
    wprintf.3
    Formatted wide-character output conversion
    xcrypt.3
    Rfs password encryption
    xdecrypt.3
    Rfs password encryption
    xdr.3
    Library routines for external data representation
    xdr_accepted_reply.3
    Library routines for remote procedure calls
    xdr_array.3
    Library routines for external data representation
    xdr_authunix_parms.3
    Library routines for remote procedure calls
    xdr_bool.3
    Library routines for external data representation
    xdr_bytes.3
    Library routines for external data representation
    xdr_callhdr.3
    Library routines for remote procedure calls
    xdr_callmsg.3
    Library routines for remote procedure calls
    xdr_char.3
    Library routines for external data representation
    xdr_destroy.3
    Library routines for external data representation
    xdr_double.3
    Library routines for external data representation
    xdr_enum.3
    Library routines for external data representation
    xdr_float.3
    Library routines for external data representation
    xdr_free.3
    Library routines for external data representation
    xdr_getpos.3
    Library routines for external data representation
    xdr_inline.3
    Library routines for external data representation
    xdr_int.3
    Library routines for external data representation
    xdr_long.3
    Library routines for external data representation
    xdr_opaque.3
    Library routines for external data representation
    xdr_opaque_auth.3
    Library routines for remote procedure calls
    xdr_pmap.3
    Library routines for remote procedure calls
    xdr_pmaplist.3
    Library routines for remote procedure calls
    xdr_pointer.3
    Library routines for external data representation
    xdr_reference.3
    Library routines for external data representation
    xdr_rejected_reply.3
    Library routines for remote procedure calls
    xdr_replymsg.3
    Library routines for remote procedure calls
    xdr_setpos.3
    Library routines for external data representation
    xdr_short.3
    Library routines for external data representation
    xdr_string.3
    Library routines for external data representation
    xdr_u_char.3
    Library routines for external data representation
    xdr_u_int.3
    Library routines for external data representation
    xdr_u_long.3
    Library routines for external data representation
    xdr_u_short.3
    Library routines for external data representation
    xdr_union.3
    Library routines for external data representation
    xdr_vector.3
    Library routines for external data representation
    xdr_void.3
    Library routines for external data representation
    xdr_wrapstring.3
    Library routines for external data representation
    xdrmem_create.3
    Library routines for external data representation
    xdrrec_create.3
    Library routines for external data representation
    xdrrec_endofrecord.3
    Library routines for external data representation
    xdrrec_eof.3
    Library routines for external data representation
    xdrrec_skiprecord.3
    Library routines for external data representation
    xdrstdio_create.3
    Library routines for external data representation
    xencrypt.3
    Rfs password encryption
    xprt_register.3
    Library routines for remote procedure calls
    xprt_unregister.3
    Library routines for remote procedure calls
    y0.3
    Bessel functions of the second kind
    y0f.3
    Bessel functions of the second kind
    y0l.3
    Bessel functions of the second kind
    y1.3
    Bessel functions of the second kind
    y1f.3
    Bessel functions of the second kind
    y1l.3
    Bessel functions of the second kind
    yn.3
    Bessel functions of the second kind
    ynf.3
    Bessel functions of the second kind
    ynl.3
    Bessel functions of the second kind