AMD64 linux syscall number table

generated at [2023-05-31 21:59:01Z] from

syscall # C type signature
0long read (unsigned int fd, char __user *buf, size_t count);
1long write (unsigned int fd, const char __user *buf, size_t count);
2long open (const char __user *filename, int flags, umode_t mode);
3long close (unsigned int fd);
4long newstat (const char __user *filename, struct stat __user *statbuf);
5long newfstat (unsigned int fd, struct stat __user *statbuf);
6long newlstat (const char __user *filename, struct stat __user *statbuf);
7long poll (struct pollfd __user *ufds, unsigned int nfds, int timeout);
8long lseek (unsigned int fd, off_t offset, unsigned int whence);
9MISSING mmap
10long mprotect (unsigned long start, size_t len, unsigned long prot);
11long munmap (unsigned long addr, size_t len);
12long brk (unsigned long brk);
13long rt_sigaction (int, const struct sigaction __user *, struct sigaction __user *, size_t);
14long rt_sigprocmask (int how, sigset_t __user *set, sigset_t __user *oset, size_t sigsetsize);
15MISSING rt_sigreturn
16long ioctl (unsigned int fd, unsigned int cmd, unsigned long arg);
17long pread64 (unsigned int fd, char __user *buf, size_t count, loff_t pos);
18long pwrite64 (unsigned int fd, const char __user *buf, size_t count, loff_t pos);
19long readv (unsigned long fd, const struct iovec __user *vec, unsigned long vlen);
20long writev (unsigned long fd, const struct iovec __user *vec, unsigned long vlen);
21long access (const char __user *filename, int mode);
22long pipe (int __user *fildes);
23long select (int n, fd_set __user *inp, fd_set __user *outp, fd_set __user *exp, struct __kernel_old_timeval __user *tvp);
24long sched_yield (void);
25long mremap (unsigned long addr, unsigned long old_len, unsigned long new_len, unsigned long flags, unsigned long new_addr);
26long msync (unsigned long start, size_t len, int flags);
27long mincore (unsigned long start, size_t len, unsigned char __user * vec);
28long madvise (unsigned long start, size_t len, int behavior);
29long shmget (key_t key, size_t size, int flag);
30long shmat (int shmid, char __user *shmaddr, int shmflg);
31long shmctl (int shmid, int cmd, struct shmid_ds __user *buf);
32long dup (unsigned int fildes);
33long dup2 (unsigned int oldfd, unsigned int newfd);
34long pause (void);
35long nanosleep (struct __kernel_timespec __user *rqtp, struct __kernel_timespec __user *rmtp);
36long getitimer (int which, struct __kernel_old_itimerval __user *value);
37long alarm (unsigned int seconds);
38long setitimer (int which, struct __kernel_old_itimerval __user *value, struct __kernel_old_itimerval __user *ovalue);
39long getpid (void);
40long sendfile64 (int out_fd, int in_fd, loff_t __user *offset, size_t count);
41long socket (int, int, int);
42long connect (int, struct sockaddr __user *, int);
43long accept (int, struct sockaddr __user *, int __user *);
44long sendto (int, void __user *, size_t, unsigned, struct sockaddr __user *, int);
45long recvfrom (int, void __user *, size_t, unsigned, struct sockaddr __user *, int __user *);
46long sendmsg (int fd, struct user_msghdr __user *msg, unsigned flags);
47long recvmsg (int fd, struct user_msghdr __user *msg, unsigned flags);
48long shutdown (int, int);
49long bind (int, struct sockaddr __user *, int);
50long listen (int, int);
51long getsockname (int, struct sockaddr __user *, int __user *);
52long getpeername (int, struct sockaddr __user *, int __user *);
53long socketpair (int, int, int, int __user *);
54long setsockopt (int fd, int level, int optname, char __user *optval, int optlen);
55long getsockopt (int fd, int level, int optname, char __user *optval, int __user *optlen);
56long clone (unsigned long, unsigned long, int __user *, int __user *, unsigned long);
57long fork (void);
58long vfork (void);
59long execve (const char __user *filename, const char __user *const __user *argv, const char __user *const __user *envp);
60long exit (int error_code);
61long wait4 (pid_t pid, int __user *stat_addr, int options, struct rusage __user *ru);
62long kill (pid_t pid, int sig);
63long newuname (struct new_utsname __user *name);
64long semget (key_t key, int nsems, int semflg);
65long semop (int semid, struct sembuf __user *sops, unsigned nsops);
66long semctl (int semid, int semnum, int cmd, unsigned long arg);
67long shmdt (char __user *shmaddr);
68long msgget (key_t key, int msgflg);
69long msgsnd (int msqid, struct msgbuf __user *msgp, size_t msgsz, int msgflg);
70long msgrcv (int msqid, struct msgbuf __user *msgp, size_t msgsz, long msgtyp, int msgflg);
71long msgctl (int msqid, int cmd, struct msqid_ds __user *buf);
72long fcntl (unsigned int fd, unsigned int cmd, unsigned long arg);
73long flock (unsigned int fd, unsigned int cmd);
74long fsync (unsigned int fd);
75long fdatasync (unsigned int fd);
76long truncate (const char __user *path, long length);
77long ftruncate (unsigned int fd, unsigned long length);
78long getdents (unsigned int fd, struct linux_dirent __user *dirent, unsigned int count);
79long getcwd (char __user *buf, unsigned long size);
80long chdir (const char __user *filename);
81long fchdir (unsigned int fd);
82long rename (const char __user *oldname, const char __user *newname);
83long mkdir (const char __user *pathname, umode_t mode);
84long rmdir (const char __user *pathname);
85long creat (const char __user *pathname, umode_t mode);
86long link (const char __user *oldname, const char __user *newname);
87long unlink (const char __user *pathname);
88long symlink (const char __user *old, const char __user *new);
89MISSING readlink
90long chmod (const char __user *filename, umode_t mode);
91long fchmod (unsigned int fd, umode_t mode);
92long chown (const char __user *filename, uid_t user, gid_t group);
93long fchown (unsigned int fd, uid_t user, gid_t group);
94long lchown (const char __user *filename, uid_t user, gid_t group);
95long umask (int mask);
96long gettimeofday (struct __kernel_old_timeval __user *tv, struct timezone __user *tz);
97long getrlimit (unsigned int resource, struct rlimit __user *rlim);
98long getrusage (int who, struct rusage __user *ru);
99long sysinfo (struct sysinfo __user *info);
100long times (struct tms __user *tbuf);
101long ptrace (long request, long pid, unsigned long addr, unsigned long data);
102long getuid (void);
103long syslog (int type, char __user *buf, int len);
104long getgid (void);
105long setuid (uid_t uid);
106long setgid (gid_t gid);
107long geteuid (void);
108long getegid (void);
109long setpgid (pid_t pid, pid_t pgid);
110long getppid (void);
111long getpgrp (void);
112long setsid (void);
113long setreuid (uid_t ruid, uid_t euid);
114long setregid (gid_t rgid, gid_t egid);
115long getgroups (int gidsetsize, gid_t __user *grouplist);
116long setgroups (int gidsetsize, gid_t __user *grouplist);
117long setresuid (uid_t ruid, uid_t euid, uid_t suid);
118long getresuid (uid_t __user *ruid, uid_t __user *euid, uid_t __user *suid);
119long setresgid (gid_t rgid, gid_t egid, gid_t sgid);
120long getresgid (gid_t __user *rgid, gid_t __user *egid, gid_t __user *sgid);
121long getpgid (pid_t pid);
122long setfsuid (uid_t uid);
123long setfsgid (gid_t gid);
124long getsid (pid_t pid);
125long capget (cap_user_header_t header, cap_user_data_t dataptr);
126long capset (cap_user_header_t header, const cap_user_data_t data);
127long rt_sigpending (sigset_t __user *set, size_t sigsetsize);
128long rt_sigtimedwait (const sigset_t __user *uthese, siginfo_t __user *uinfo, const struct __kernel_timespec __user *uts, size_t sigsetsize);
129long rt_sigqueueinfo (pid_t pid, int sig, siginfo_t __user *uinfo);
130long rt_sigsuspend (sigset_t __user *unewset, size_t sigsetsize);
131long sigaltstack (const struct sigaltstack __user *uss, struct sigaltstack __user *uoss);
132long utime (char __user *filename, struct utimbuf __user *times);
133long mknod (const char __user *filename, umode_t mode, unsigned dev);
134long uselib (const char __user *library);
135long personality (unsigned int personality);
136long ustat (unsigned dev, struct ustat __user *ubuf);
137long statfs (const char __user * path, struct statfs __user *buf);
138long fstatfs (unsigned int fd, struct statfs __user *buf);
139long sysfs (int option, unsigned long arg1, unsigned long arg2);
140long getpriority (int which, int who);
141long setpriority (int which, int who, int niceval);
142long sched_setparam (pid_t pid, struct sched_param __user *param);
143long sched_getparam (pid_t pid, struct sched_param __user *param);
144long sched_setscheduler (pid_t pid, int policy, struct sched_param __user *param);
145long sched_getscheduler (pid_t pid);
146long sched_get_priority_max (int policy);
147long sched_get_priority_min (int policy);
148long sched_rr_get_interval (pid_t pid, struct __kernel_timespec __user *interval);
149long mlock (unsigned long start, size_t len);
150long munlock (unsigned long start, size_t len);
151long mlockall (int flags);
152long munlockall (void);
153long vhangup (void);
154MISSING modify_ldt
155long pivot_root (const char __user *new_root, const char __user *put_old);
156long ni_syscall (void);
157long prctl (int option, unsigned long arg2, unsigned long arg3, unsigned long arg4, unsigned long arg5);
158MISSING arch_prctl
159long adjtimex (struct __kernel_timex __user *txc_p);
160long setrlimit (unsigned int resource, struct rlimit __user *rlim);
161long chroot (const char __user *filename);
162long sync (void);
163long acct (const char __user *name);
164long settimeofday (struct __kernel_old_timeval __user *tv, struct timezone __user *tz);
165long mount (char __user *dev_name, char __user *dir_name, char __user *type, unsigned long flags, void __user *data);
166long umount (char __user *name, int flags);
167long swapon (const char __user *specialfile, int swap_flags);
168long swapoff (const char __user *specialfile);
169long reboot (int magic1, int magic2, unsigned int cmd, void __user *arg);
170long sethostname (char __user *name, int len);
171long setdomainname (char __user *name, int len);
172MISSING iopl
173long ioperm (unsigned long from, unsigned long num, int on);
174MISSING create_module
175long init_module (void __user *umod, unsigned long len, const char __user *uargs);
176long delete_module (const char __user *name_user, unsigned int flags);
177MISSING get_kernel_syms
178MISSING query_module
179long quotactl (unsigned int cmd, const char __user *special, qid_t id, void __user *addr);
180MISSING nfsservctl
181MISSING getpmsg
182MISSING putpmsg
183MISSING afs_syscall
184MISSING tuxcall
185MISSING security
186long gettid (void);
187long readahead (int fd, loff_t offset, size_t count);
188long setxattr (const char __user *path, const char __user *name, const void __user *value, size_t size, int flags);
189long lsetxattr (const char __user *path, const char __user *name, const void __user *value, size_t size, int flags);
190long fsetxattr (int fd, const char __user *name, const void __user *value, size_t size, int flags);
191long getxattr (const char __user *path, const char __user *name, void __user *value, size_t size);
192long lgetxattr (const char __user *path, const char __user *name, void __user *value, size_t size);
193long fgetxattr (int fd, const char __user *name, void __user *value, size_t size);
194long listxattr (const char __user *path, char __user *list, size_t size);
195long llistxattr (const char __user *path, char __user *list, size_t size);
196long flistxattr (int fd, char __user *list, size_t size);
197long removexattr (const char __user *path, const char __user *name);
198long lremovexattr (const char __user *path, const char __user *name);
199long fremovexattr (int fd, const char __user *name);
200long tkill (pid_t pid, int sig);
201long time (__kernel_old_time_t __user *tloc);
202long futex (u32 __user *uaddr, int op, u32 val, const struct __kernel_timespec __user *utime, u32 __user *uaddr2, u32 val3);
203long sched_setaffinity (pid_t pid, unsigned int len, unsigned long __user *user_mask_ptr);
204long sched_getaffinity (pid_t pid, unsigned int len, unsigned long __user *user_mask_ptr);
205MISSING set_thread_area
206long io_setup (unsigned nr_reqs, aio_context_t __user *ctx);
207long io_destroy (aio_context_t ctx);
208long io_getevents (aio_context_t ctx_id, long min_nr, long nr, struct io_event __user *events, struct __kernel_timespec __user *timeout);
209long io_submit (aio_context_t, long, struct iocb __user * __user *);
210long io_cancel (aio_context_t ctx_id, struct iocb __user *iocb, struct io_event __user *result);
211MISSING get_thread_area
212long lookup_dcookie (u64 cookie64, char __user *buf, size_t len);
213long epoll_create (int size);
214MISSING epoll_ctl_old
215MISSING epoll_wait_old
216long remap_file_pages (unsigned long start, unsigned long size, unsigned long prot, unsigned long pgoff, unsigned long flags);
217long getdents64 (unsigned int fd, struct linux_dirent64 __user *dirent, unsigned int count);
218long set_tid_address (int __user *tidptr);
219long restart_syscall (void);
220long semtimedop (int semid, struct sembuf __user *sops, unsigned nsops, const struct __kernel_timespec __user *timeout);
221long fadvise64 (int fd, loff_t offset, size_t len, int advice);
222long timer_create (clockid_t which_clock, struct sigevent __user *timer_event_spec, timer_t __user * created_timer_id);
223long timer_settime (timer_t timer_id, int flags, const struct __kernel_itimerspec __user *new_setting, struct __kernel_itimerspec __user *old_setting);
224long timer_gettime (timer_t timer_id, struct __kernel_itimerspec __user *setting);
225long timer_getoverrun (timer_t timer_id);
226long timer_delete (timer_t timer_id);
227long clock_settime (clockid_t which_clock, const struct __kernel_timespec __user *tp);
228long clock_gettime (clockid_t which_clock, struct __kernel_timespec __user *tp);
229long clock_getres (clockid_t which_clock, struct __kernel_timespec __user *tp);
230long clock_nanosleep (clockid_t which_clock, int flags, const struct __kernel_timespec __user *rqtp, struct __kernel_timespec __user *rmtp);
231long exit_group (int error_code);
232long epoll_wait (int epfd, struct epoll_event __user *events, int maxevents, int timeout);
233long epoll_ctl (int epfd, int op, int fd, struct epoll_event __user *event);
234long tgkill (pid_t tgid, pid_t pid, int sig);
235long utimes (char __user *filename, struct __kernel_old_timeval __user *utimes);
236MISSING vserver
237long mbind (unsigned long start, unsigned long len, unsigned long mode, const unsigned long __user *nmask, unsigned long maxnode, unsigned flags);
238long set_mempolicy (int mode, const unsigned long __user *nmask, unsigned long maxnode);
239long get_mempolicy (int __user *policy, unsigned long __user *nmask, unsigned long maxnode, unsigned long addr, unsigned long flags);
240long mq_open (const char __user *name, int oflag, umode_t mode, struct mq_attr __user *attr);
241long mq_unlink (const char __user *name);
242long mq_timedsend (mqd_t mqdes, const char __user *msg_ptr, size_t msg_len, unsigned int msg_prio, const struct __kernel_timespec __user *abs_timeout);
243long mq_timedreceive (mqd_t mqdes, char __user *msg_ptr, size_t msg_len, unsigned int __user *msg_prio, const struct __kernel_timespec __user *abs_timeout);
244long mq_notify (mqd_t mqdes, const struct sigevent __user *notification);
245long mq_getsetattr (mqd_t mqdes, const struct mq_attr __user *mqstat, struct mq_attr __user *omqstat);
246long kexec_load (unsigned long entry, unsigned long nr_segments, struct kexec_segment __user *segments, unsigned long flags);
247long waitid (int which, pid_t pid, struct siginfo __user *infop, int options, struct rusage __user *ru);
248long add_key (const char __user *_type, const char __user *_description, const void __user *_payload, size_t plen, key_serial_t destringid);
249long request_key (const char __user *_type, const char __user *_description, const char __user *_callout_info, key_serial_t destringid);
250long keyctl (int cmd, unsigned long arg2, unsigned long arg3, unsigned long arg4, unsigned long arg5);
251long ioprio_set (int which, int who, int ioprio);
252long ioprio_get (int which, int who);
253long inotify_init (void);
254long inotify_add_watch (int fd, const char __user *path, u32 mask);
255long inotify_rm_watch (int fd, __s32 wd);
256long migrate_pages (pid_t pid, unsigned long maxnode, const unsigned long __user *from, const unsigned long __user *to);
257long openat (int dfd, const char __user *filename, int flags, umode_t mode);
258long mkdirat (int dfd, const char __user * pathname, umode_t mode);
259long mknodat (int dfd, const char __user * filename, umode_t mode, unsigned dev);
260long fchownat (int dfd, const char __user *filename, uid_t user, gid_t group, int flag);
261long futimesat (int dfd, const char __user *filename, struct __kernel_old_timeval __user *utimes);
262long newfstatat (int dfd, const char __user *filename, struct stat __user *statbuf, int flag);
263long unlinkat (int dfd, const char __user * pathname, int flag);
264long renameat (int olddfd, const char __user * oldname, int newdfd, const char __user * newname);
265long linkat (int olddfd, const char __user *oldname, int newdfd, const char __user *newname, int flags);
266long symlinkat (const char __user * oldname, int newdfd, const char __user * newname);
267long readlinkat (int dfd, const char __user *path, char __user *buf, int bufsiz);
268long fchmodat (int dfd, const char __user * filename, umode_t mode);
269long faccessat (int dfd, const char __user *filename, int mode);
270long pselect6 (int, fd_set __user *, fd_set __user *, fd_set __user *, struct __kernel_timespec __user *, void __user *);
271long ppoll (struct pollfd __user *, unsigned int, struct __kernel_timespec __user *, const sigset_t __user *, size_t);
272long unshare (unsigned long unshare_flags);
273long set_robust_list (struct robust_list_head __user *head, size_t len);
274long get_robust_list (int pid, struct robust_list_head __user * __user *head_ptr, size_t __user *len_ptr);
275long splice (int fd_in, loff_t __user *off_in, int fd_out, loff_t __user *off_out, size_t len, unsigned int flags);
276long tee (int fdin, int fdout, size_t len, unsigned int flags);
277long sync_file_range (int fd, loff_t offset, loff_t nbytes, unsigned int flags);
278long vmsplice (int fd, const struct iovec __user *iov, unsigned long nr_segs, unsigned int flags);
279long move_pages (pid_t pid, unsigned long nr_pages, const void __user * __user *pages, const int __user *nodes, int __user *status, int flags);
280long utimensat (int dfd, const char __user *filename, struct __kernel_timespec __user *utimes, int flags);
281long epoll_pwait (int epfd, struct epoll_event __user *events, int maxevents, int timeout, const sigset_t __user *sigmask, size_t sigsetsize);
282long signalfd (int ufd, sigset_t __user *user_mask, size_t sizemask);
283long timerfd_create (int clockid, int flags);
284long eventfd (unsigned int count);
285long fallocate (int fd, int mode, loff_t offset, loff_t len);
286long timerfd_settime (int ufd, int flags, const struct __kernel_itimerspec __user *utmr, struct __kernel_itimerspec __user *otmr);
287long timerfd_gettime (int ufd, struct __kernel_itimerspec __user *otmr);
288long accept4 (int, struct sockaddr __user *, int __user *, int);
289long signalfd4 (int ufd, sigset_t __user *user_mask, size_t sizemask, int flags);
290long eventfd2 (unsigned int count, int flags);
291long epoll_create1 (int flags);
292long dup3 (unsigned int oldfd, unsigned int newfd, int flags);
293long pipe2 (int __user *fildes, int flags);
294long inotify_init1 (int flags);
295long preadv (unsigned long fd, const struct iovec __user *vec, unsigned long vlen, unsigned long pos_l, unsigned long pos_h);
296long pwritev (unsigned long fd, const struct iovec __user *vec, unsigned long vlen, unsigned long pos_l, unsigned long pos_h);
297long rt_tgsigqueueinfo (pid_t tgid, pid_t pid, int sig, siginfo_t __user *uinfo);
298long perf_event_open ( struct perf_event_attr __user *attr_uptr, pid_t pid, int cpu, int group_fd, unsigned long flags);
299long recvmmsg (int fd, struct mmsghdr __user *msg, unsigned int vlen, unsigned flags, struct __kernel_timespec __user *timeout);
300long fanotify_init (unsigned int flags, unsigned int event_f_flags);
301long fanotify_mark (int fanotify_fd, unsigned int flags, u64 mask, int fd, const char __user *pathname);
302long prlimit64 (pid_t pid, unsigned int resource, const struct rlimit64 __user *new_rlim, struct rlimit64 __user *old_rlim);
303long name_to_handle_at (int dfd, const char __user *name, struct file_handle __user *handle, int __user *mnt_id, int flag);
304long open_by_handle_at (int mountdirfd, struct file_handle __user *handle, int flags);
305long clock_adjtime (clockid_t which_clock, struct __kernel_timex __user *tx);
306long syncfs (int fd);
307long sendmmsg (int fd, struct mmsghdr __user *msg, unsigned int vlen, unsigned flags);
308long setns (int fd, int nstype);
309long getcpu (unsigned __user *cpu, unsigned __user *node, struct getcpu_cache __user *cache);
310long process_vm_readv (pid_t pid, const struct iovec __user *lvec, unsigned long liovcnt, const struct iovec __user *rvec, unsigned long riovcnt, unsigned long flags);
311long process_vm_writev (pid_t pid, const struct iovec __user *lvec, unsigned long liovcnt, const struct iovec __user *rvec, unsigned long riovcnt, unsigned long flags);
312long kcmp (pid_t pid1, pid_t pid2, int type, unsigned long idx1, unsigned long idx2);
313long finit_module (int fd, const char __user *uargs, int flags);
314long sched_setattr (pid_t pid, struct sched_attr __user *attr, unsigned int flags);
315long sched_getattr (pid_t pid, struct sched_attr __user *attr, unsigned int size, unsigned int flags);
316long renameat2 (int olddfd, const char __user *oldname, int newdfd, const char __user *newname, unsigned int flags);
317long seccomp (unsigned int op, unsigned int flags, void __user *uargs);
318long getrandom (char __user *buf, size_t count, unsigned int flags);
319long memfd_create (const char __user *uname_ptr, unsigned int flags);
320MISSING kexec_file_load
321long bpf (int cmd, union bpf_attr *attr, unsigned int size);
322long execveat (int dfd, const char __user *filename, const char __user *const __user *argv, const char __user *const __user *envp, int flags);
323long userfaultfd (int flags);
324long membarrier (int cmd, unsigned int flags, int cpu_id);
325long mlock2 (unsigned long start, size_t len, int flags);
326long copy_file_range (int fd_in, loff_t __user *off_in, int fd_out, loff_t __user *off_out, size_t len, unsigned int flags);
327long preadv2 (unsigned long fd, const struct iovec __user *vec, unsigned long vlen, unsigned long pos_l, unsigned long pos_h, rwf_t flags);
328long pwritev2 (unsigned long fd, const struct iovec __user *vec, unsigned long vlen, unsigned long pos_l, unsigned long pos_h, rwf_t flags);
329long pkey_mprotect (unsigned long start, size_t len, unsigned long prot, int pkey);
330long pkey_alloc (unsigned long flags, unsigned long init_val);
331long pkey_free (int pkey);
332long statx (int dfd, const char __user *path, unsigned flags, unsigned mask, struct statx __user *buffer);
333long io_pgetevents (aio_context_t ctx_id, long min_nr, long nr, struct io_event __user *events, struct __kernel_timespec __user *timeout, const struct __aio_sigset *sig);
334long rseq (struct rseq __user *rseq, uint32_t rseq_len, int flags, uint32_t sig);
424long pidfd_send_signal (int pidfd, int sig, siginfo_t __user *info, unsigned int flags);
425long io_uring_setup (u32 entries, struct io_uring_params __user *p);
426long io_uring_enter (unsigned int fd, u32 to_submit, u32 min_complete, u32 flags, const void __user *argp, size_t argsz);
427long io_uring_register (unsigned int fd, unsigned int op, void __user *arg, unsigned int nr_args);
428long open_tree (int dfd, const char __user *path, unsigned flags);
429long move_mount (int from_dfd, const char __user *from_path, int to_dfd, const char __user *to_path, unsigned int ms_flags);
430long fsopen (const char __user *fs_name, unsigned int flags);
431long fsconfig (int fs_fd, unsigned int cmd, const char __user *key, const void __user *value, int aux);
432long fsmount (int fs_fd, unsigned int flags, unsigned int ms_flags);
433long fspick (int dfd, const char __user *path, unsigned int flags);
434long pidfd_open (pid_t pid, unsigned int flags);
435long clone3 (struct clone_args __user *uargs, size_t size);
436long close_range (unsigned int fd, unsigned int max_fd, unsigned int flags);
437long openat2 (int dfd, const char __user *filename, struct open_how *how, size_t size);
438long pidfd_getfd (int pidfd, int fd, unsigned int flags);
439long faccessat2 (int dfd, const char __user *filename, int mode, int flags);
440long process_madvise (int pidfd, const struct iovec __user *vec, size_t vlen, int behavior, unsigned int flags);
441long epoll_pwait2 (int epfd, struct epoll_event __user *events, int maxevents, const struct __kernel_timespec __user *timeout, const sigset_t __user *sigmask, size_t sigsetsize);
442long mount_setattr (int dfd, const char __user *path, unsigned int flags, struct mount_attr __user *uattr, size_t usize);
443long quotactl_fd (unsigned int fd, unsigned int cmd, qid_t id, void __user *addr);
444long landlock_create_ruleset (const struct landlock_ruleset_attr __user *attr, size_t size, __u32 flags);
445long landlock_add_rule (int ruleset_fd, enum landlock_rule_type rule_type, const void __user *rule_attr, __u32 flags);
446long landlock_restrict_self (int ruleset_fd, __u32 flags);
447long memfd_secret (unsigned int flags);
448long process_mrelease (int pidfd, unsigned int flags);
449long futex_waitv (struct futex_waitv *waiters, unsigned int nr_futexes, unsigned int flags, struct __kernel_timespec __user *timeout, clockid_t clockid);
450long set_mempolicy_home_node (unsigned long start, unsigned long len, unsigned long home_node, unsigned long flags);