As well as being the maintainer of the Linux man-pages project, I'm also the author (*) or coauthor (+) of many of the manual pages, as listed below.
ldd(1) - print shared object dependencies (+)
locale(1) - get locale-specific information (*)
memusage(1) - profile memory usage of a program (+)
pldd(1) - display dynamic shared objects linked into a process (*)
sprof(1) - read and display shared object profiling data (*)
access(2) - check user's permissions for a file (+)
add_key(2) - add a key to the kernel's key management facility (+)
adjtimex(2) - tune kernel clock (+)
bind(2) - bind a name to a socket (+)
bpf(2) - perform a command on an extended BPF map or program (+)
brk(2) - change data segment size (+)
capget(2) - set/get capabilities of thread(s) (+)
chmod(2) - change permissions of a file (+)
chown(2) - change ownership of a file (+)
clock_getres(2) - clock and time functions (+)
clock_nanosleep(2) - high-resolution sleep with specifiable clock (*)
clone(2) - create a child process (+)
close(2) - close a file descriptor (+)
delete_module(2) - unload a kernel module (*)
dup(2) - duplicate a file descriptor (+)
epoll_create(2) - open an epoll file descriptor (+)
epoll_ctl(2) - control interface for 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 (*)
execve(2) - execute program (+)
execveat(2) - execute program relative to a directory file descriptor (+)
fcntl(2) - manipulate file descriptor (+)
flock(2) - apply or remove an advisory lock on an open file (+)
fork(2) - create a child process (*)
fsync(2) - synchronize a file's in-core state with storage device (+)
futex(2) - fast user-space locking (+)
futimesat(2) - change timestamps of a file relative to a directory file descriptor (*)
getdents(2) - get directory entries (+)
getgroups(2) - get/set list of supplementary group IDs (+)
getitimer(2) - get or set value of an interval timer (+)
getrandom(2) - obtain a series of random bytes (+)
getresuid(2) - get real, effective and saved user/group IDs (+)
getrlimit(2) - get/set resource limits (+)
get_robust_list(2) - get/set list of robust futexes (+)
getrusage(2) - get resource usage (+)
getsid(2) - get session ID (+)
gettid(2) - get thread identification (+)
getunwind(2) - copy the unwind data to caller's buffer (+)
init_module(2) - load a kernel module (+)
inotify_add_watch(2) - add a watch to an initialized inotify instance (+)
inotify_init(2) - initialize an inotify instance (+)
intro(2) - introduction to system calls (*)
ioctl_iflags(2) - ioctl() operations for inode flags (*)
ioctl_ns(2) - ioctl() operations for Linux namespaces (*)
ioctl_userfaultfd(2) - create a file descriptor for handling page faults in user space (+)
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 (+)
link(2) - make a new name for a file (+)
listen(2) - listen for connections on a socket (+)
lseek(2) - reposition read/write file offset (+)
memfd_create(2) - create an anonymous file (+)
mincore(2) - determine whether pages are resident in memory (+)
mkdir(2) - create a directory (+)
mknod(2) - create a special or ordinary file (+)
mlock(2) - lock and unlock memory (+)
mmap(2) - map or unmap files or devices into memory (+)
mmap2(2) - map files or devices into memory (*)
mount(2) - mount filesystem (+)
mprotect(2) - set protection on a region of memory (+)
mq_getsetattr(2) - get/set message queue attributes (*)
msgctl(2) - System V message control operations (+)
nanosleep(2) - high-resolution sleep (+)
open(2) - open and possibly create a file (+)
open_by_handle_at(2) - obtain handle for a pathname and open file via a handle (*)
perfmonctl(2) - interface to IA-64 performance monitoring unit (+)
personality(2) - set the process execution domain (+)
pidfd_getfd(2) - obtain a duplicate of another process's file descriptor (*)
pidfd_open(2) - obtain a file descriptor that refers to a process (*)
pidfd_send_signal(2) - send a signal to a process specified by a file descriptor (*)
pipe(2) - create pipe (*)
pivot_root(2) - change the root mount (*)
poll(2) - wait for some event on a file descriptor (*)
posix_fadvise(2) - predeclare an access pattern for file data (+)
prctl(2) - operations on a process (+)
process_vm_readv(2) - transfer data between process address spaces (+)
ptrace(2) - process trace (+)
quotactl(2) - manipulate disk quotas (+)
read(2) - read from a file descriptor (+)
readahead(2) - initiate file readahead into page cache (*)
readlink(2) - read value of a symbolic link (+)
readv(2) - read or write data into multiple buffers (+)
recvmmsg(2) - receive multiple messages on a socket (+)
remap_file_pages(2) - create a nonlinear file mapping (*)
rename(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 (*)
rt_sigqueueinfo(2) - queue a signal and data (*)
sched_setaffinity(2) - set and get a thread's CPU affinity mask (+)
sched_setattr(2) - set and get scheduling policy and attributes (+)
sched_setscheduler(2) - set and get scheduling policy/parameters (*)
seccomp(2) - operate on Secure Computing state of the process (+)
select(2) - synchronous I/O multiplexing (+)
semctl(2) - System V semaphore control operations (+)
semget(2) - get a System V semaphore set identifier (+)
sendmmsg(2) - send multiple messages on a socket (*)
setfsgid(2) - set group identity used for filesystem checks (+)
setfsuid(2) - set user identity used for filesystem checks (+)
setgid(2) - set group identity (+)
setns(2) - reassociate thread with a namespace (+)
setpgid(2) - set/get process group (+)
setresuid(2) - set real, effective and saved user or group ID (+)
setreuid(2) - set real and/or effective user or group ID (+)
setsid(2) - creates a session and sets the process group ID (+)
setuid(2) - set user identity (+)
sgetmask(2) - manipulation of signal mask (obsolete) (*)
shmctl(2) - System V shared memory control (+)
shmop(2) - System V shared memory operations (+)
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 (*)
sigpending(2) - examine pending signals (*)
sigprocmask(2) - examine and change blocked signals (*)
sigreturn(2) - return from signal handler and cleanup stack frame (*)
sigsuspend(2) - wait for a signal (*)
sigwaitinfo(2) - synchronously wait for queued signals (*)
splice(2) - splice data to/from a pipe (+)
stat(2) - get file status (+)
statx(2) - get file status (extended) (+)
subpage_prot(2) - define a subpage protection for an address range (*)
symlink(2) - make a new name for a file (+)
sync(2) - commit filesystem caches to disk (+)
sync_file_range(2) - sync a file segment with disk (+)
syscalls(2) - Linux system calls (+)
sysinfo(2) - return system information (+)
syslog(2) - read and/or clear kernel message ring buffer; set console_loglevel (+)
tee(2) - duplicating pipe content (+)
timer_create(2) - create a POSIX per-process timer (*)
timer_delete(2) - delete a POSIX per-process timer (*)
timerfd_create(2) - timers that notify via file descriptors (*)
timer_getoverrun(2) - get overrun count for a POSIX per-process timer (*)
timer_settime(2) - arm/disarm and fetch state of POSIX per-process timer (*)
tkill(2) - send a signal to a thread (+)
umask(2) - set file mode creation mask (*)
umount(2) - unmount filesystem (+)
unlink(2) - delete a name and possibly the file it refers to (+)
unshare(2) - disassociate parts of the process execution context (+)
userfaultfd(2) - create a file descriptor for handling page faults in user space (+)
utimensat(2) - change file timestamps with nanosecond precision (*)
vfork(2) - create a child process and block parent (+)
vmsplice(2) - splice user pages to/from a pipe (+)
wait(2) - wait for process to change state (+)
wait4(2) - wait for process to change state, BSD style (+)
write(2) - write to a file descriptor (+)
abort(3) - cause abnormal process termination (+)
acos(3) - arc cosine function (+)
acosh(3) - inverse hyperbolic cosine function (+)
adjtime(3) - correct the time to synchronize the system clock (*)
aio_init(3) - asynchronous I/O initialization (*)
aio_suspend(3) - wait for asynchronous I/O operation or timeout (+)
asin(3) - arc sine function (+)
asinh(3) - inverse hyperbolic sine function (+)
atan2(3) - arc tangent function of two variables (+)
atan(3) - arc tangent function (+)
atanh(3) - inverse hyperbolic tangent function (+)
backtrace(3) - support for application self-debugging (*)
basename(3) - parse pathname components (*)
bindresvport(3) - bind a socket to a privileged IP port (+)
bsd_signal(3) - signal handling with BSD semantics (*)
bswap(3) - reverse order of bytes (*)
bzero(3) - zero a byte string (*)
cacos(3) - complex arc cosine (+)
cacosh(3) - complex arc hyperbolic cosine (+)
canonicalize_file_name(3) - return the canonicalized absolute pathname (*)
catan(3) - complex arc tangents (+)
catanh(3) - complex arc tangents hyperbolic (+)
ceil(3) - ceiling function: smallest integral value not less than argument (+)
clock_getcpuclockid(3) - obtain ID of a process CPU-time clock (*)
cos(3) - cosine function (+)
cosh(3) - hyperbolic cosine function (+)
CPU_SET(3) - macros for manipulating CPU sets (+)
dladdr(3) - translate address to symbolic information (+)
dlerror(3) - obtain error diagnostic for functions in the dlopen API (+)
dlinfo(3) - obtain information about a dynamically loaded object (*)
dl_iterate_phdr(3) - walk through list of shared objects (*)
dlopen(3) - open and close a shared object (+)
dlsym(3) - obtain address of a symbol in a shared object or executable (+)
duplocale(3) - duplicate a locale object (*)
end(3) - end of program segments (*)
endian(3) - convert values between host and big-/little-endian byte order (+)
erf(3) - error function (+)
erfc(3) - complementary error function (*)
error(3) - glibc error reporting functions (+)
euidaccess(3) - check effective user's permissions for a file (*)
exp10(3) - base-10 exponential function (+)
exp2(3) - base-2 exponential function (+)
exp(3) - base-e exponential function (+)
expm1(3) - exponential minus 1 (+)
fcloseall(3) - close all open streams (*)
fdim(3) - positive difference (+)
fexecve(3) - execute program specified via file descriptor (*)
floor(3) - largest integral value not greater than argument (+)
fma(3) - floating-point multiply and add (+)
fmax(3) - determine maximum of two floating-point numbers (+)
fmemopen(3) - open memory as stream (*)
fmin(3) - determine minimum of two floating-point numbers (+)
fmod(3) - floating-point remainder function (+)
fopencookie(3) - opening a custom stream (*)
fpathconf(3) - get configuration values for files (+)
ftw(3) - file tree walk (+)
futimes(3) - change file timestamps (*)
getaddrinfo(3) - network address and service translation (+)
getaddrinfo_a(3) - asynchronous network address and service translation (+)
getauxval(3) - retrieve a value from the auxiliary vector (*)
getdate(3) - convert a date-plus-time string to broken-down time (+)
getentropy(3) - fill a buffer with random bytes (*)
getenv(3) - get an environment variable (+)
getgrouplist(3) - get list of groups to which a user belongs (*)
getifaddrs(3) - get interface addresses (+)
getnetent_r(3) - get network entry (reentrant) (*)
get_nprocs_conf(3) - get number of processors (+)
getopt(3) - Parse command-line options (+)
getprotoent_r(3) - get protocol entry (reentrant) (*)
getpwnam(3) - get password file entry (+)
getrpcent_r(3) - get RPC entry (reentrant) (*)
getservent_r(3) - get service entry (reentrant) (*)
getsubopt(3) - parse suboption arguments from a string (+)
getutmp(3) - copy utmp structure to utmpx, and vice versa (*)
gnu_get_libc_version(3) - get glibc version and release (*)
group_member(3) - test whether a process is in a group (*)
hsearch(3) - hash table management (+)
if_nameindex(3) - get network interface names and indexes (+)
ilogb(3) - get integer exponent of a floating-point value (+)
inet(3) - Internet address manipulation routines (+)
inet_net_pton(3) - Internet network number conversion (*)
inet_pton(3) - convert IPv4 and IPv6 addresses from text to binary form (+)
insque(3) - insert/remove an item from a queue (*)
intro(3) - introduction to library functions (*)
isatty(3) - test whether a file descriptor refers to a terminal (*)
isfdtype(3) - test file type of a file descriptor (*)
j0(3) - Bessel functions of the first kind (+)
ldexp(3) - multiply floating-point number by integral power of 2 (+)
lgamma(3) - log gamma function (+)
lio_listio(3) - initiate a list of I/O requests (*)
log10(3) - base-10 logarithmic function (+)
log1p(3) - logarithm of 1 plus argument (+)
log2(3) - base-2 logarithmic function (+)
log(3) - natural logarithmic function (+)
logb(3) - get exponent of a floating-point value (+)
lrint(3) - round to nearest integer (+)
lround(3) - round to nearest integer (+)
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_info(3) - export malloc state to a stream (*)
malloc_stats(3) - print memory allocation statistics (*)
malloc_trim(3) - release free memory from 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 (*)
mbstowcs(3) - convert a multibyte string to a wide-character string (+)
mcheck(3) - heap consistency checking (*)
memchr(3) - scan memory for a character (+)
memcpy(3) - copy memory area (+)
mkfifo(3) - make a FIFO special file (a named pipe) (+)
mkstemp(3) - create a unique temporary file (+)
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_unlink(3) - remove a message queue (*)
mtrace(3) - malloc tracing (*)
newlocale(3) - create, modify, and free a locale object (*)
nextafter(3) - floating-point number manipulation (+)
nextup(3) - return next floating-point number toward positive/negative infinity (*)
nl_langinfo(3) - query language and locale information (+)
ntp_gettime(3) - get time parameters (NTP daemon interface) (*)
offsetof(3) - offset of a structure member (+)
open_memstream(3) - open a dynamic memory buffer stream (*)
posix_fallocate(3) - allocate file space (*)
posix_madvise(3) - give advice about patterns of memory usage (*)
posix_openpt(3) - open a pseudoterminal device (*)
posix_spawn(3) - spawn a process (+)
pow(3) - power functions (+)
program_invocation_name(3) - obtain name used to invoke calling program (*)
pthread_atfork(3) - register fork handlers (*)
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_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_getattr_default_np(3) - get or set default thread-creation attributes (*)
pthread_getattr_np(3) - get attributes of created thread (*)
pthread_getcpuclockid(3) - retrieve ID of a thread's CPU time clock (*)
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_mutexattr_getpshared(3) - get/set process-shared mutex attribute (*)
pthread_mutexattr_init(3) - initialize and destroy a mutex attributes object (*)
pthread_mutexattr_setrobust(3) - get and set the robustness attribute of a mutex attributes object (+)
pthread_mutex_consistent(3) - make a robust mutex consistent (+)
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_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_spin_init(3) - initialize or destroy a spin lock (*)
pthread_spin_lock(3) - lock and unlock a spin lock (*)
pthread_testcancel(3) - request delivery of any pending cancellation request (*)
pthread_tryjoin_np(3) - try to join with a terminated thread (*)
pthread_yield(3) - yield the processor (*)
raise(3) - send a signal to the caller (+)
random_r(3) - reentrant random number generator (*)
readdir(3) - read a directory (+)
readdir_r(3) - read a directory (+)
remainder(3) - floating-point remainder function (+)
remquo(3) - remainder and part of quotient (+)
resolver(3) - resolver routines (+)
rint(3) - round to nearest integer (+)
round(3) - round to nearest integer, away from zero (+)
scalb(3) - multiply floating-point number by integral power of radix (OBSOLETE) (+)
scalbln(3) - multiply floating-point number by integral power of radix (+)
scandir(3) - scan a directory for matching entries (+)
sched_getcpu(3) - determine CPU on which the calling thread is running (*)
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_unlink(3) - remove a named semaphore (*)
sem_wait(3) - lock a semaphore (*)
setenv(3) - change or add an environment variable (+)
setjmp(3) - performing a nonlocal goto (*)
shm_open(3) - create/open or unlink POSIX shared memory objects (*)
signbit(3) - test sign of a real floating-point number (+)
sigqueue(3) - queue a signal and data to a process (*)
sigset(3) - System V signal API (*)
sigvec(3) - BSD signal API (*)
sigwait(3) - wait for a signal (*)
sin(3) - sine function (+)
sincos(3) - calculate sin and cos simultaneously (+)
sinh(3) - hyperbolic sine function (+)
sockatmark(3) - determine whether socket is at out-of-band mark (*)
sqrt(3) - square root function (+)
strcmp(3) - compare two strings (+)
strerror(3) - return string describing error number (+)
strtok(3) - extract tokens from strings (*)
strverscmp(3) - compare two version strings (+)
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 (+)
tanh(3) - hyperbolic tangent function (+)
termios(3) - get and set terminal attributes, line control, get and set baud rate (+)
tgamma(3) - true gamma function (+)
timeradd(3) - timeval operations (*)
toupper(3) - convert uppercase or lowercase (+)
towlower(3) - convert a wide character to lowercase (+)
towupper(3) - convert a wide character to uppercase (*)
uselocale(3) - set/get the locale for the calling thread (*)
y0(3) - Bessel functions of the second kind (+)
loop(4) - loop devices (+)
acct(5) - process accounting file (*)
core(5) - core dump file (*)
locale(5) - describes a locale definition file (+)
proc(5) - process information pseudo-filesystem (+)
slabinfo(5) - kernel slab allocator statistics (+)
sysfs(5) - a filesystem for exporting kernel objects (*)
tmpfs(5) - a virtual memory filesystem (*)
address_families(7) - socket address families (domains) (+)
aio(7) - POSIX asynchronous I/O overview (*)
capabilities(7) - overview of Linux capabilities (*)
cgroup_namespaces(7) - overview of Linux cgroup namespaces (*)
cgroups(7) - Linux control groups (+)
credentials(7) - process identifiers (*)
fanotify(7) - monitoring filesystem events (+)
feature_test_macros(7) - feature test macros (*)
inode(7) - file inode information (*)
inotify(7) - monitoring filesystem events (+)
ipc_namespaces(7) - overview of Linux IPC namespaces (*)
keyrings(7) - in-kernel key management and retention facility (+)
libc(7) - overview of standard C libraries on Linux (*)
locale(7) - description of multilanguage support (+)
man-pages(7) - conventions for writing Linux man pages (+)
math_error(7) - detecting errors from mathematical functions (*)
mount_namespaces(7) - overview of Linux mount namespaces (*)
mq_overview(7) - overview of POSIX message queues (*)
namespaces(7) - overview of Linux namespaces (+)
network_namespaces(7) - overview of Linux network namespaces (*)
nptl(7) - Native POSIX Threads Library (*)
numa(7) - overview of Non-Uniform Memory Architecture (+)
pid_namespaces(7) - overview of Linux PID namespaces (+)
pipe(7) - overview of pipes and FIFOs (*)
pthreads(7) - POSIX threads (*)
pty(7) - pseudoterminal interfaces (*)
rtld-audit(7) - auditing API for the dynamic linker (*)
sched(7) - overview of CPU scheduling (+)
sem_overview(7) - overview of POSIX semaphores (*)
shm_overview(7) - overview of POSIX shared memory (*)
sigevent(7) - structure for notification from asynchronous routines (+)
signal(7) - overview of signals (+)
signal-safety(7) - async-signal-safe functions (*)
standards(7) - C and UNIX Standards (*)
symlink(7) - symbolic link handling (+)
sysvipc(7) - System V interprocess communication mechanisms (*)
tcp(7) - TCP protocol (+)
termio(7) - System V terminal driver interface (*)
time(7) - overview of time and timers (*)
time_namespaces(7) - overview of Linux time namespaces (*)
unix(7) - sockets for local interprocess communication (+)
user_namespaces(7) - overview of Linux user namespaces (+)
uts_namespaces(7) - overview of Linux UTS namespaces (*)
intro(8) - introduction to administration and privileged commands (+)
sln(8) - create symbolic links (*)